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

A

AbProto - Class in org.hyperledger.fabric.protos.orderer
 
ABSOLUTE_MAX_BYTES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BatchSize
 
ACK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
Acknowledgement - Class in org.hyperledger.fabric.protos.gossip
Protobuf type gossip.Acknowledgement
Acknowledgement.Builder - Class in org.hyperledger.fabric.protos.gossip
Protobuf type gossip.Acknowledgement
AcknowledgementOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
ACLs - Class in org.hyperledger.fabric.protos.peer
ACLs provides mappings for resources in a channel.
ACLs.Builder - Class in org.hyperledger.fabric.protos.peer
ACLs provides mappings for resources in a channel.
ACLS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ACLs
 
ACLsOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ACTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
ACTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Transaction
 
ACTIVE_NODES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
addActions(TransactionAction) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
addActions(int, TransactionAction) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
addActions(TransactionAction.Builder) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
addActions(int, TransactionAction.Builder) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
addActionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
addActionsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
addActiveNodes(long) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
Indicates active nodes in cluster that are reacheable by Raft leader
addAddresses(String) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
addAddressesBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
addAdmins(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity denoting the administrator of this MSP
addAlive(Envelope) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
addAlive(int, Envelope) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
addAlive(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
addAlive(int, Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
addAliveBuilder() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
addAliveBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
addAllActions(Iterable<? extends TransactionAction>) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
addAllActiveNodes(Iterable<? extends Long>) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
Indicates active nodes in cluster that are reacheable by Raft leader
addAllAddresses(Iterable<String>) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
addAllAdmins(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity denoting the administrator of this MSP
addAllAlive(Iterable<? extends Envelope>) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
addAllAnchorPeers(Iterable<? extends AnchorPeer>) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
addAllArgs(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
repeated bytes args = 1 [json_name = "args"];
addAllBlockNumbers(Iterable<? extends Long>) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
addAllBrokers(Iterable<String>) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
addAllChaincodeActions(Iterable<? extends FilteredChaincodeAction>) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
addAllChaincodeDefinitions(Iterable<? extends QueryChaincodeDefinitionsResult.ChaincodeDefinition>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
addAllChaincodes(Iterable<? extends Chaincode>) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
addAllChaincodes(Iterable<? extends ChaincodeCall>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
addAllChaincodes(Iterable<? extends ChaincodeInfo>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
addAllChaincodes(Iterable<? extends QueryInstalledChaincodeResult.Chaincode>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addAllChaincodes(Iterable<? extends QueryInstalledChaincodesResult.Chaincode>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addAllChannels(Iterable<? extends ChannelInfo>) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
addAllCollectionHashedRwset(Iterable<? extends CollectionHashedReadWriteSet>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
addAllCollectionNames(Iterable<String>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
addAllCollectionPvtRwset(Iterable<? extends CollectionPvtReadWriteSet>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
addAllConfig(Iterable<? extends CollectionConfig>) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
addAllConfig(Iterable<? extends CollectionConfig>) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
addAllConsenterIds(Iterable<? extends Long>) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
addAllConsenters(Iterable<? extends Consenter>) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
addAllContent(Iterable<? extends EndorsementDescriptor>) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
addAllData(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
repeated bytes data = 1 [json_name = "data"];
addAllData(Iterable<? extends Envelope>) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
addAllDead(Iterable<? extends Envelope>) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
addAllDetails(Iterable<? extends Any>) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
addAllDigests(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
Maybe change this to bitmap later on
addAllDigests(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
repeated bytes digests = 2 [json_name = "digests"];
addAllDigests(Iterable<? extends PvtDataDigest>) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
addAllElements(Iterable<? extends PvtDataElement>) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
addAllElements(Iterable<? extends Envelope>) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
addAllEndorsements(Iterable<? extends Endorsement>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
addAllEndorsingOrganizations(Iterable<String>) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
addAllEndorsingOrganizations(Iterable<String>) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
addAllEndpoint(Iterable<? extends Endpoint>) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
addAllEntries(Iterable<? extends KVMetadataEntry>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addAllEntries(Iterable<? extends KVMetadataEntry>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addAllEntries(Iterable<? extends StateMetadata>) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
addAllEvents(Iterable<? extends ChaincodeEvent>) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
addAllFields(Iterable<String>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
addAllFilteredTransactions(Iterable<? extends FilteredTransaction>) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
addAllHashedReads(Iterable<? extends KVReadHash>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
addAllHashedWrites(Iterable<? extends KVWriteHash>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
addAllIdentities(Iterable<? extends MSPPrincipal>) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
addAllInstalledChaincodes(Iterable<? extends QueryInstalledChaincodesResult.InstalledChaincode>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
addAllInterests(Iterable<? extends ChaincodeInterest>) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
addAllIntermediateCerts(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
addAllKeyPolicies(Iterable<? extends SignaturePolicyEnvelope>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
addAllKnown(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
repeated bytes known = 2 [json_name = "known"];
addAllKvReads(Iterable<? extends KVRead>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
addAllLayouts(Iterable<? extends Layout>) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
addAllMaxLevelHashes(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
addAllMetadata(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
repeated bytes metadata = 1 [json_name = "metadata"];
addAllMetadataWrites(Iterable<? extends KVMetadataWriteHash>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
addAllMetadataWrites(Iterable<? extends KVMetadataWrite>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
addAllNsPvtRwset(Iterable<? extends NsPvtReadWriteSet>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
addAllNsRwset(Iterable<? extends NsReadWriteSet>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
addAllOrganizationalUnitIdentifiers(Iterable<? extends FabricOUIdentifier>) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
addAllOwnerEndorsements(Iterable<? extends Endorsement>) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
addAllPayload(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
the payload is a marshaled kvrwset.KVRWSet
addAllPayloads(Iterable<? extends Payload>) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
addAllPeers(Iterable<? extends Peer>) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
addAllPrincipals(Iterable<? extends MSPPrincipal>) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
addAllPrivateData(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
repeated bytes private_data = 3 [json_name = "privateData"];
addAllQueries(Iterable<? extends Query>) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
addAllRangeQueriesInfo(Iterable<? extends RangeQueryInfo>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
addAllReads(Iterable<? extends KVRead>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
addAllResults(Iterable<? extends QueryResult>) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
addAllResults(Iterable<? extends QueryResultBytes>) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
addAllRevocationList(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity revocation list
addAllRootCerts(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
addAllRules(Iterable<? extends SignaturePolicy>) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
addAllSignatures(Iterable<? extends ConfigSignature>) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
addAllSignatures(Iterable<? extends MetadataSignature>) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
addAllTargetOrganizations(Iterable<String>) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
addAllTlsIntermediateCerts(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
addAllTlsRootCerts(Iterable<? extends ByteString>) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS root certificates trusted by this MSP.
addAllWrites(Iterable<? extends KVWrite>) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
addAnchorPeers(AnchorPeer) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
addAnchorPeers(int, AnchorPeer) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
addAnchorPeers(AnchorPeer.Builder) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
addAnchorPeers(int, AnchorPeer.Builder) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
addAnchorPeersBuilder() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
addAnchorPeersBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
addArgs(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
repeated bytes args = 1 [json_name = "args"];
addBlockNumbers(long) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
addBrokers(String) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
addBrokersBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
addChaincodeActions(FilteredChaincodeAction) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
addChaincodeActions(int, FilteredChaincodeAction) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
addChaincodeActions(FilteredChaincodeAction.Builder) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
addChaincodeActions(int, FilteredChaincodeAction.Builder) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
addChaincodeActionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
addChaincodeActionsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
addChaincodeDefinitions(QueryChaincodeDefinitionsResult.ChaincodeDefinition) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
addChaincodeDefinitions(int, QueryChaincodeDefinitionsResult.ChaincodeDefinition) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
addChaincodeDefinitions(QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
addChaincodeDefinitions(int, QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
addChaincodeDefinitionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
addChaincodeDefinitionsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
addChaincodes(Chaincode) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
addChaincodes(int, Chaincode) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
addChaincodes(Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
addChaincodes(int, Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
addChaincodes(ChaincodeCall) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(int, ChaincodeCall) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(ChaincodeCall.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(int, ChaincodeCall.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(ChaincodeInfo) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(int, ChaincodeInfo) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(ChaincodeInfo.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(int, ChaincodeInfo.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(QueryInstalledChaincodeResult.Chaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(int, QueryInstalledChaincodeResult.Chaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(QueryInstalledChaincodeResult.Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(int, QueryInstalledChaincodeResult.Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(QueryInstalledChaincodesResult.Chaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(int, QueryInstalledChaincodesResult.Chaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(QueryInstalledChaincodesResult.Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodes(int, QueryInstalledChaincodesResult.Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodesBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
addChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
addChaincodesBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
addChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
addChaincodesBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
addChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
addChaincodesBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodesBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
addChannels(ChannelInfo) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
addChannels(int, ChannelInfo) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
addChannels(ChannelInfo.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
addChannels(int, ChannelInfo.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
addChannelsBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
addChannelsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
addCollectionHashedRwset(CollectionHashedReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
addCollectionHashedRwset(int, CollectionHashedReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
addCollectionHashedRwset(CollectionHashedReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
addCollectionHashedRwset(int, CollectionHashedReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
addCollectionHashedRwsetBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
addCollectionHashedRwsetBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
addCollectionNames(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
addCollectionNamesBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
addCollectionPvtRwset(CollectionPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
addCollectionPvtRwset(int, CollectionPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
addCollectionPvtRwset(CollectionPvtReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
addCollectionPvtRwset(int, CollectionPvtReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
addCollectionPvtRwsetBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
addCollectionPvtRwsetBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
addConfig(CollectionConfig) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
addConfig(int, CollectionConfig) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
addConfig(CollectionConfig.Builder) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
addConfig(int, CollectionConfig.Builder) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
addConfig(CollectionConfig) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
addConfig(int, CollectionConfig) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
addConfig(CollectionConfig.Builder) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
addConfig(int, CollectionConfig.Builder) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
addConfigBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
addConfigBuilder(int) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
addConfigBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
addConfigBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
addConsenterIds(long) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
addConsenters(Consenter) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
addConsenters(int, Consenter) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
addConsenters(Consenter.Builder) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
addConsenters(int, Consenter.Builder) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
addConsentersBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
addConsentersBuilder(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
addContent(EndorsementDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
addContent(int, EndorsementDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
addContent(EndorsementDescriptor.Builder) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
addContent(int, EndorsementDescriptor.Builder) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
addContentBuilder() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
addContentBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
addData(ByteString) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
repeated bytes data = 1 [json_name = "data"];
addData(Envelope) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
addData(int, Envelope) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
addData(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
addData(int, Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
addDataBuilder() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
addDataBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
addDead(Envelope) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
addDead(int, Envelope) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
addDead(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
addDead(int, Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
addDeadBuilder() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
addDeadBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
addDetails(Any) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
addDetails(int, Any) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
addDetails(Any.Builder) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
addDetails(int, Any.Builder) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
addDetailsBuilder() - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
addDetailsBuilder(int) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
addDigests(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
Maybe change this to bitmap later on
addDigests(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
repeated bytes digests = 2 [json_name = "digests"];
addDigests(PvtDataDigest) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
addDigests(int, PvtDataDigest) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
addDigests(PvtDataDigest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
addDigests(int, PvtDataDigest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
addDigestsBuilder() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
addDigestsBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
addElements(PvtDataElement) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
addElements(int, PvtDataElement) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
addElements(PvtDataElement.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
addElements(int, PvtDataElement.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
addElements(Envelope) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
addElements(int, Envelope) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
addElements(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
addElements(int, Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
addElementsBuilder() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
addElementsBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
addElementsBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
addElementsBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
addEndorsements(Endorsement) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
addEndorsements(int, Endorsement) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
addEndorsements(Endorsement.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
addEndorsements(int, Endorsement.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
addEndorsementsBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
addEndorsementsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
addEndorsingOrganizations(String) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
addEndorsingOrganizations(String) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
addEndorsingOrganizationsBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
addEndorsingOrganizationsBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
addEndpoint(Endpoint) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
addEndpoint(int, Endpoint) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
addEndpoint(Endpoint.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
addEndpoint(int, Endpoint.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
addEndpointBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
addEndpointBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
addEntries(KVMetadataEntry) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntries(int, KVMetadataEntry) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntries(KVMetadataEntry.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntries(int, KVMetadataEntry.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntries(KVMetadataEntry) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntries(int, KVMetadataEntry) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntries(KVMetadataEntry.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntries(int, KVMetadataEntry.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntries(StateMetadata) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
addEntries(int, StateMetadata) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
addEntries(StateMetadata.Builder) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
addEntries(int, StateMetadata.Builder) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
addEntriesBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntriesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntriesBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntriesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
addEntriesBuilder() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
addEntriesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
addEvents(ChaincodeEvent) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
addEvents(int, ChaincodeEvent) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
addEvents(ChaincodeEvent.Builder) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
addEvents(int, ChaincodeEvent.Builder) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
addEventsBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
addEventsBuilder(int) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
addFields(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
addFieldsBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
addFilteredTransactions(FilteredTransaction) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
addFilteredTransactions(int, FilteredTransaction) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
addFilteredTransactions(FilteredTransaction.Builder) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
addFilteredTransactions(int, FilteredTransaction.Builder) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
addFilteredTransactionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
addFilteredTransactionsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
addHashedReads(KVReadHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
addHashedReads(int, KVReadHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
addHashedReads(KVReadHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
addHashedReads(int, KVReadHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
addHashedReadsBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
addHashedReadsBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
addHashedWrites(KVWriteHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
addHashedWrites(int, KVWriteHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
addHashedWrites(KVWriteHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
addHashedWrites(int, KVWriteHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
addHashedWritesBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
addHashedWritesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
addIdentities(MSPPrincipal) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
addIdentities(int, MSPPrincipal) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
addIdentities(MSPPrincipal.Builder) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
addIdentities(int, MSPPrincipal.Builder) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
addIdentitiesBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
addIdentitiesBuilder(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
addInstalledChaincodes(QueryInstalledChaincodesResult.InstalledChaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
addInstalledChaincodes(int, QueryInstalledChaincodesResult.InstalledChaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
addInstalledChaincodes(QueryInstalledChaincodesResult.InstalledChaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
addInstalledChaincodes(int, QueryInstalledChaincodesResult.InstalledChaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
addInstalledChaincodesBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
addInstalledChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
addInterests(ChaincodeInterest) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
addInterests(int, ChaincodeInterest) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
addInterests(ChaincodeInterest.Builder) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
addInterests(int, ChaincodeInterest.Builder) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
addInterestsBuilder() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
addInterestsBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
addIntermediateCerts(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
addKeyPolicies(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
addKeyPolicies(int, SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
addKeyPolicies(SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
addKeyPolicies(int, SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
addKeyPoliciesBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
addKeyPoliciesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
addKnown(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
repeated bytes known = 2 [json_name = "known"];
addKvReads(KVRead) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
addKvReads(int, KVRead) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
addKvReads(KVRead.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
addKvReads(int, KVRead.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
addKvReadsBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
addKvReadsBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
addLayouts(Layout) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
addLayouts(int, Layout) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
addLayouts(Layout.Builder) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
addLayouts(int, Layout.Builder) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
addLayoutsBuilder() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
addLayoutsBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
addMaxLevelHashes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
addMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
repeated bytes metadata = 1 [json_name = "metadata"];
addMetadataWrites(KVMetadataWriteHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
addMetadataWrites(int, KVMetadataWriteHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
addMetadataWrites(KVMetadataWriteHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
addMetadataWrites(int, KVMetadataWriteHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
addMetadataWrites(KVMetadataWrite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
addMetadataWrites(int, KVMetadataWrite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
addMetadataWrites(KVMetadataWrite.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
addMetadataWrites(int, KVMetadataWrite.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
addMetadataWritesBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
addMetadataWritesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
addMetadataWritesBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
addMetadataWritesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
addNsPvtRwset(NsPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
addNsPvtRwset(int, NsPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
addNsPvtRwset(NsPvtReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
addNsPvtRwset(int, NsPvtReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
addNsPvtRwsetBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
addNsPvtRwsetBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
addNsRwset(NsReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
addNsRwset(int, NsReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
addNsRwset(NsReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
addNsRwset(int, NsReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
addNsRwsetBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
addNsRwsetBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
addOrganizationalUnitIdentifiers(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
addOrganizationalUnitIdentifiers(int, FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
addOrganizationalUnitIdentifiers(FabricOUIdentifier.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
addOrganizationalUnitIdentifiers(int, FabricOUIdentifier.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
addOrganizationalUnitIdentifiersBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
addOrganizationalUnitIdentifiersBuilder(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
addOwnerEndorsements(Endorsement) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
addOwnerEndorsements(int, Endorsement) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
addOwnerEndorsements(Endorsement.Builder) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
addOwnerEndorsements(int, Endorsement.Builder) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
addOwnerEndorsementsBuilder() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
addOwnerEndorsementsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
addPayload(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
the payload is a marshaled kvrwset.KVRWSet
addPayloads(Payload) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
addPayloads(int, Payload) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
addPayloads(Payload.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
addPayloads(int, Payload.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
addPayloadsBuilder() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
addPayloadsBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
addPeers(Peer) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
addPeers(int, Peer) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
addPeers(Peer.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
addPeers(int, Peer.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
addPeersBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
addPeersBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
addPrincipals(MSPPrincipal) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
addPrincipals(int, MSPPrincipal) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
addPrincipals(MSPPrincipal.Builder) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
addPrincipals(int, MSPPrincipal.Builder) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
addPrincipalsBuilder() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
addPrincipalsBuilder(int) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
addPrivateData(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
repeated bytes private_data = 3 [json_name = "privateData"];
addQueries(Query) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
addQueries(int, Query) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
addQueries(Query.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
addQueries(int, Query.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
addQueriesBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
addQueriesBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
addRangeQueriesInfo(RangeQueryInfo) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
addRangeQueriesInfo(int, RangeQueryInfo) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
addRangeQueriesInfo(RangeQueryInfo.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
addRangeQueriesInfo(int, RangeQueryInfo.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
addRangeQueriesInfoBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
addRangeQueriesInfoBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
addReads(KVRead) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
addReads(int, KVRead) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
addReads(KVRead.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
addReads(int, KVRead.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
addReadsBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
addReadsBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.google.rpc.Status.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
ADDRESS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
ADDRESSES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
addResults(QueryResult) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
addResults(int, QueryResult) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
addResults(QueryResult.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
addResults(int, QueryResult.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
addResults(QueryResultBytes) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
addResults(int, QueryResultBytes) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
addResults(QueryResultBytes.Builder) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
addResults(int, QueryResultBytes.Builder) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
addResultsBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
addResultsBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
addResultsBuilder() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
addResultsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
addRevocationList(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity revocation list
addRootCerts(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
addRules(SignaturePolicy) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
addRules(int, SignaturePolicy) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
addRules(SignaturePolicy.Builder) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
addRules(int, SignaturePolicy.Builder) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
addRulesBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
addRulesBuilder(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
addSignatures(ConfigSignature) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
addSignatures(int, ConfigSignature) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
addSignatures(ConfigSignature.Builder) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
addSignatures(int, ConfigSignature.Builder) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
addSignatures(MetadataSignature) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
addSignatures(int, MetadataSignature) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
addSignatures(MetadataSignature.Builder) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
addSignatures(int, MetadataSignature.Builder) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
addSignaturesBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
addSignaturesBuilder(int) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
addSignaturesBuilder() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
addSignaturesBuilder(int) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
addTargetOrganizations(String) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
addTargetOrganizationsBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
addTlsIntermediateCerts(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
addTlsRootCerts(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS root certificates trusted by this MSP.
addWrites(KVWrite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
addWrites(int, KVWrite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
addWrites(KVWrite.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
addWrites(int, KVWrite.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
addWritesBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
addWritesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
ADMIN_OU_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
ADMIN_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
Represents an MSP Admin
ADMINS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
AFTER_TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
ALIVE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
ALIVE_MSG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
AliveMessage - Class in org.hyperledger.fabric.protos.gossip
AliveMessage is sent to inform remote peers of a peer's existence and activity
AliveMessage.Builder - Class in org.hyperledger.fabric.protos.gossip
AliveMessage is sent to inform remote peers of a peer's existence and activity
AliveMessageOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
ALL_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
Requires all of the sub-policies be satisfied
ANCHOR_PEERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
AnchorPeer - Class in org.hyperledger.fabric.protos.peer
AnchorPeer message structure which provides information about anchor peer, it includes host name, port number and peer certificate.
AnchorPeer.Builder - Class in org.hyperledger.fabric.protos.peer
AnchorPeer message structure which provides information about anchor peer, it includes host name, port number and peer certificate.
AnchorPeerOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
AnchorPeers - Class in org.hyperledger.fabric.protos.peer
AnchorPeers simply represents list of anchor peers which is used in ConfigurationItem
AnchorPeers.Builder - Class in org.hyperledger.fabric.protos.peer
AnchorPeers simply represents list of anchor peers which is used in ConfigurationItem
AnchorPeersOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ANONYMITY_TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
ANONYMITY_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
identity
ANONYMOUS_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
Represents an anonymous MSP Identity
ANY_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
Requires any of the sub-policies be satisfied, if no sub-policies exist, always returns true
APIResource - Class in org.hyperledger.fabric.protos.peer
APIResource represents an API resource in the peer whose ACL is determined by the policy_ref field
APIResource.Builder - Class in org.hyperledger.fabric.protos.peer
APIResource represents an API resource in the peer whose ACL is determined by the policy_ref field
APIResourceOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ApplicationPolicy - Class in org.hyperledger.fabric.protos.common
Deprecated.
ApplicationPolicy - Class in org.hyperledger.fabric.protos.peer
ApplicationPolicy captures the diffenrent policy types that are set and evaluted at the application level.
ApplicationPolicy.Builder - Class in org.hyperledger.fabric.protos.common
Deprecated.
ApplicationPolicy captures the diffenrent policy types that are set and evaluted at the application level.
ApplicationPolicy.Builder - Class in org.hyperledger.fabric.protos.peer
ApplicationPolicy captures the diffenrent policy types that are set and evaluted at the application level.
ApplicationPolicy.TypeCase - Enum in org.hyperledger.fabric.protos.common
Deprecated.
 
ApplicationPolicy.TypeCase - Enum in org.hyperledger.fabric.protos.peer
 
ApplicationPolicyOrBuilder - Interface in org.hyperledger.fabric.protos.common
Deprecated.
ApplicationPolicyOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
APPROVALS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
APPROVALS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
ApproveChaincodeDefinitionForMyOrgArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
ApproveChaincodeDefinitionForMyOrgArgs is the message used as arguments to `_lifecycle.ApproveChaincodeDefinitionForMyOrg`.
ApproveChaincodeDefinitionForMyOrgArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
ApproveChaincodeDefinitionForMyOrgArgs is the message used as arguments to `_lifecycle.ApproveChaincodeDefinitionForMyOrg`.
ApproveChaincodeDefinitionForMyOrgArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
ApproveChaincodeDefinitionForMyOrgResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
ApproveChaincodeDefinitionForMyOrgResult is the message returned by `_lifecycle.ApproveChaincodeDefinitionForMyOrg`.
ApproveChaincodeDefinitionForMyOrgResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
ApproveChaincodeDefinitionForMyOrgResult is the message returned by `_lifecycle.ApproveChaincodeDefinitionForMyOrg`.
ApproveChaincodeDefinitionForMyOrgResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
ARGS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
ARGUMENT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
AtomicBroadcastGrpc - Class in org.hyperledger.fabric.protos.orderer
 
AtomicBroadcastGrpc.AtomicBroadcastBlockingStub - Class in org.hyperledger.fabric.protos.orderer
 
AtomicBroadcastGrpc.AtomicBroadcastFutureStub - Class in org.hyperledger.fabric.protos.orderer
 
AtomicBroadcastGrpc.AtomicBroadcastImplBase - Class in org.hyperledger.fabric.protos.orderer
 
AtomicBroadcastGrpc.AtomicBroadcastStub - Class in org.hyperledger.fabric.protos.orderer
 
AtomicBroadcastImplBase() - Constructor for class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc.AtomicBroadcastImplBase
 
AUTHENTICATION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Request
 
AuthInfo - Class in org.hyperledger.fabric.protos.discovery
AuthInfo aggregates authentication information that the server uses to authenticate the client
AuthInfo.Builder - Class in org.hyperledger.fabric.protos.discovery
AuthInfo aggregates authentication information that the server uses to authenticate the client
AuthInfoOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 

B

BAD_CHANNEL_HEADER_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
BAD_CHANNEL_HEADER = 20;
BAD_COMMON_HEADER_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
BAD_COMMON_HEADER = 3;
BAD_CREATOR_SIGNATURE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
BAD_CREATOR_SIGNATURE = 4;
BAD_HEADER_EXTENSION_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
BAD_HEADER_EXTENSION = 19;
BAD_PAYLOAD_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
BAD_PAYLOAD = 2;
BAD_PROPOSAL_TXID_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
BAD_PROPOSAL_TXID = 8;
BAD_REQUEST_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
BAD_REQUEST = 400;
BAD_RESPONSE_PAYLOAD_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
BAD_RESPONSE_PAYLOAD = 21;
BAD_RWSET_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
BAD_RWSET = 22;
BatchSize - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BatchSize
BatchSize.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BatchSize
BatchSizeOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
BatchTimeout - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BatchTimeout
BatchTimeout.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BatchTimeout
BatchTimeoutOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
BEHAVIOR_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
BEST_EFFORT_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
BEST_EFFORT = 1;
bindService() - Method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc.DiscoveryImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.gossip.GossipGrpc.GossipImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc.AtomicBroadcastImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc.BlockAttestationsImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.orderer.ClusterGrpc.ClusterImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc.ChaincodeImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc.ChaincodeSupportImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.peer.DeliverGrpc.DeliverImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.peer.EndorserGrpc.EndorserImplBase
 
bindService() - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotImplBase
 
Block - Class in org.hyperledger.fabric.protos.common
This is finalized block structure to be shared among the orderer and peer Note that the BlockHeader chains to the previous BlockHeader, and the BlockData hash is embedded in the BlockHeader.
Block.Builder - Class in org.hyperledger.fabric.protos.common
This is finalized block structure to be shared among the orderer and peer Note that the BlockHeader chains to the previous BlockHeader, and the BlockData hash is embedded in the BlockHeader.
BLOCK_AND_PRIVATE_DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
BLOCK_ATTESTATION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
BLOCK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
BLOCK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
BLOCK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
BLOCK_MSG_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.PullMsgType
BLOCK_MSG = 1;
BLOCK_NUM_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
BLOCK_NUMBER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
BLOCK_NUMBER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
BLOCK_NUMBER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
BLOCK_NUMBER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
BLOCK_NUMBERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
BLOCK_SEQ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
BLOCK_TO_LIVE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
BLOCK_TO_LIVE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
BLOCK_UNTIL_READY_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
BLOCK_UNTIL_READY = 0;
BlockAndPrivateData - Class in org.hyperledger.fabric.protos.peer
BlockAndPrivateData contains Block and a map from tx_seq_in_block to rwset.TxPvtReadWriteSet
BlockAndPrivateData.Builder - Class in org.hyperledger.fabric.protos.peer
BlockAndPrivateData contains Block and a map from tx_seq_in_block to rwset.TxPvtReadWriteSet
BlockAndPrivateDataOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
BlockAttestation - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BlockAttestation
BlockAttestation.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BlockAttestation
BlockAttestationOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
BlockattestationProto - Class in org.hyperledger.fabric.protos.orderer
 
BlockAttestationResponse - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BlockAttestationResponse
BlockAttestationResponse.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BlockAttestationResponse
BlockAttestationResponse.TypeCase - Enum in org.hyperledger.fabric.protos.orderer
 
BlockAttestationResponseOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
blockAttestations(Envelope) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc.BlockAttestationsBlockingStub
BlockAttestations receives an Envelope of type DELIVER_SEEK_INFO , then sends back a stream of BlockAttestations.
blockAttestations(Envelope, StreamObserver<BlockAttestationResponse>) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc.BlockAttestationsImplBase
BlockAttestations receives an Envelope of type DELIVER_SEEK_INFO , then sends back a stream of BlockAttestations.
blockAttestations(Envelope, StreamObserver<BlockAttestationResponse>) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc.BlockAttestationsStub
BlockAttestations receives an Envelope of type DELIVER_SEEK_INFO , then sends back a stream of BlockAttestations.
BlockAttestationsGrpc - Class in org.hyperledger.fabric.protos.orderer
 
BlockAttestationsGrpc.BlockAttestationsBlockingStub - Class in org.hyperledger.fabric.protos.orderer
 
BlockAttestationsGrpc.BlockAttestationsFutureStub - Class in org.hyperledger.fabric.protos.orderer
 
BlockAttestationsGrpc.BlockAttestationsImplBase - Class in org.hyperledger.fabric.protos.orderer
 
BlockAttestationsGrpc.BlockAttestationsStub - Class in org.hyperledger.fabric.protos.orderer
 
BlockAttestationsImplBase() - Constructor for class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc.BlockAttestationsImplBase
 
BlockchainInfo - Class in org.hyperledger.fabric.protos.common
Contains information about the blockchain ledger such as height, current block hash, and previous block hash.
BlockchainInfo.Builder - Class in org.hyperledger.fabric.protos.common
Contains information about the blockchain ledger such as height, current block hash, and previous block hash.
BlockchainInfoOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
BlockData - Class in org.hyperledger.fabric.protos.common
Protobuf type common.BlockData
BlockData.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.BlockData
BlockDataHashingStructure - Class in org.hyperledger.fabric.protos.common
BlockDataHashingStructure is encoded into the configuration transaction as a configuration item of type Chain with a Key of "BlockDataHashingStructure" and a Value of HashingAlgorithm as marshaled protobuf bytes
BlockDataHashingStructure.Builder - Class in org.hyperledger.fabric.protos.common
BlockDataHashingStructure is encoded into the configuration transaction as a configuration item of type Chain with a Key of "BlockDataHashingStructure" and a Value of HashingAlgorithm as marshaled protobuf bytes
BlockDataHashingStructureOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
BlockDataOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
BlockHeader - Class in org.hyperledger.fabric.protos.common
BlockHeader is the element of the block which forms the block chain The block header is hashed using the configured chain hashing algorithm over the ASN.1 encoding of the BlockHeader
BlockHeader.Builder - Class in org.hyperledger.fabric.protos.common
BlockHeader is the element of the block which forms the block chain The block header is hashed using the configured chain hashing algorithm over the ASN.1 encoding of the BlockHeader
BlockHeaderOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
BlockMetadata - Class in org.hyperledger.fabric.protos.common
Protobuf type common.BlockMetadata
BlockMetadata - Class in org.hyperledger.fabric.protos.orderer.etcdraft
BlockMetadata stores data used by the Raft OSNs when coordinating with each other, to be serialized into block meta dta field and used after failres and restarts.
BlockMetadata.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.BlockMetadata
BlockMetadata.Builder - Class in org.hyperledger.fabric.protos.orderer.etcdraft
BlockMetadata stores data used by the Raft OSNs when coordinating with each other, to be serialized into block meta dta field and used after failres and restarts.
BlockMetadataIndex - Enum in org.hyperledger.fabric.protos.common
This enum enlists indexes of the block metadata array
BlockMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
BlockMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.orderer.etcdraft
 
BlockOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
BOOKMARK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
BOOKMARK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
BOOTSTRAPPING_SNAPSHOT_DIR_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
BootstrappingSnapshotInfo - Class in org.hyperledger.fabric.protos.common
Contains information for the bootstrapping snapshot.
BootstrappingSnapshotInfo.Builder - Class in org.hyperledger.fabric.protos.common
Contains information for the bootstrapping snapshot.
BOOTSTRAPPINGSNAPSHOTINFO_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
BootstrappingSnapshotInfoOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
broadcast(StreamObserver<BroadcastResponse>) - Method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc.AtomicBroadcastImplBase
broadcast receives a reply of Acknowledgement for each common.Envelope in order, indicating success or type of failure
broadcast(StreamObserver<BroadcastResponse>) - Method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc.AtomicBroadcastStub
broadcast receives a reply of Acknowledgement for each common.Envelope in order, indicating success or type of failure
BroadcastResponse - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BroadcastResponse
BroadcastResponse.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.BroadcastResponse
BroadcastResponseOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
BROKERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
build() - Method in class com.google.rpc.Status.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
build() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
build() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
build() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
build() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
build() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
build() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
build() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
build() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
build() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
build() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
build() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
buildPartial() - Method in class com.google.rpc.Status.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
buildPartial() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
BYTES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 

C

cancel(SignedSnapshotRequest) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotBlockingStub
Cancel a snapshot reqeust.
cancel(SignedSnapshotRequest) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotFutureStub
Cancel a snapshot reqeust.
cancel(SignedSnapshotRequest, StreamObserver<Empty>) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotImplBase
Cancel a snapshot reqeust.
cancel(SignedSnapshotRequest, StreamObserver<Empty>) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotStub
Cancel a snapshot reqeust.
Capabilities - Class in org.hyperledger.fabric.protos.common
Capabilities message defines the capabilities a particular binary must implement for that binary to be able to safely participate in the channel.
Capabilities.Builder - Class in org.hyperledger.fabric.protos.common
Capabilities message defines the capabilities a particular binary must implement for that binary to be able to safely participate in the channel.
CAPABILITIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Capabilities
 
CapabilitiesOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
Capability - Class in org.hyperledger.fabric.protos.common
Capability is an empty message for the time being.
Capability.Builder - Class in org.hyperledger.fabric.protos.common
Capability is an empty message for the time being.
CapabilityOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
CAR_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
CAR = 3;
CC_QUERY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Query
 
CC_QUERY_RES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.QueryResult
 
CDSData - Class in org.hyperledger.fabric.protos.peer
CDSData is data stored in the LSCC on instantiation of a CC for CDSPackage.
CDSData.Builder - Class in org.hyperledger.fabric.protos.peer
CDSData is data stored in the LSCC on instantiation of a CC for CDSPackage.
CDSDataOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
CERT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
CERTIFICATE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
CERTIFIERS_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
Chaincode - Class in org.hyperledger.fabric.protos.gossip
Chaincode represents a Chaincode that is installed on a peer
Chaincode.Builder - Class in org.hyperledger.fabric.protos.gossip
Chaincode represents a Chaincode that is installed on a peer
CHAINCODE_ACTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
CHAINCODE_DEFINITIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
CHAINCODE_DEPLOYMENT_SPEC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
CHAINCODE_EVENT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
CHAINCODE_EVENT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
CHAINCODE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
CHAINCODE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
CHAINCODE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
CHAINCODE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
CHAINCODE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
CHAINCODE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
CHAINCODE_INSTALL_PACKAGE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
CHAINCODE_INSTALL_PACKAGE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
CHAINCODE_NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
CHAINCODE_PACKAGE_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.HeaderType
Used for packaging chaincode artifacts for install
CHAINCODE_PROPOSAL_PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
CHAINCODE_SPEC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
CHAINCODE_SPEC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
CHAINCODE_VERSION_CONFLICT_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
CHAINCODE_VERSION_CONFLICT = 18;
ChaincodeAction - Class in org.hyperledger.fabric.protos.peer
ChaincodeAction contains the executed chaincode results, response, and event.
ChaincodeAction.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeAction contains the executed chaincode results, response, and event.
ChaincodeActionOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeActionPayload - Class in org.hyperledger.fabric.protos.peer
ChaincodeActionPayload is the message to be used for the TransactionAction's payload when the Header's type is set to CHAINCODE.
ChaincodeActionPayload.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeActionPayload is the message to be used for the TransactionAction's payload when the Header's type is set to CHAINCODE.
ChaincodeActionPayloadOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeCall - Class in org.hyperledger.fabric.protos.peer
ChaincodeCall defines a call to a chaincode.
ChaincodeCall.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeCall defines a call to a chaincode.
ChaincodeCallOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeData - Class in org.hyperledger.fabric.protos.peer
ChaincodeData defines the datastructure for chaincodes to be serialized by proto Type provides an additional check by directing to use a specific package after instantiation Data is Type specific (see CDSPackage and SignedCDSPackage)
ChaincodeData.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeData defines the datastructure for chaincodes to be serialized by proto Type provides an additional check by directing to use a specific package after instantiation Data is Type specific (see CDSPackage and SignedCDSPackage)
ChaincodeDataOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeDefinitionProto - Class in org.hyperledger.fabric.protos.peer.lifecycle
 
ChaincodeDeploymentSpec - Class in org.hyperledger.fabric.protos.peer
Specify the deployment of a chaincode.
ChaincodeDeploymentSpec.Builder - Class in org.hyperledger.fabric.protos.peer
Specify the deployment of a chaincode.
ChaincodeDeploymentSpecOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeEndorsedAction - Class in org.hyperledger.fabric.protos.peer
ChaincodeEndorsedAction carries information about the endorsement of a specific proposal
ChaincodeEndorsedAction.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeEndorsedAction carries information about the endorsement of a specific proposal
ChaincodeEndorsedActionOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeEndorsement - Class in org.hyperledger.fabric.protos.peer
ChaincodeEndorsement instructs the peer how transactions should be endorsed.
ChaincodeEndorsement.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeEndorsement instructs the peer how transactions should be endorsed.
ChaincodeEndorsementInfo - Class in org.hyperledger.fabric.protos.peer.lifecycle
ChaincodeEndorsementInfo is (most) everything the peer needs to know in order to execute a chaincode
ChaincodeEndorsementInfo.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
ChaincodeEndorsementInfo is (most) everything the peer needs to know in order to execute a chaincode
ChaincodeEndorsementInfoOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
ChaincodeEndorsementOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeEvent - Class in org.hyperledger.fabric.protos.peer
ChaincodeEvent is used for events and registrations that are specific to chaincode string type - "chaincode"
ChaincodeEvent.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeEvent is used for events and registrations that are specific to chaincode string type - "chaincode"
ChaincodeEventOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeEventProto - Class in org.hyperledger.fabric.protos.peer
 
chaincodeEvents(SignedChaincodeEventsRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayBlockingStub
The ChaincodeEvents service supplies a stream of responses, each containing all the events emitted by the requested chaincode for a specific block.
chaincodeEvents(SignedChaincodeEventsRequest, StreamObserver<ChaincodeEventsResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayImplBase
The ChaincodeEvents service supplies a stream of responses, each containing all the events emitted by the requested chaincode for a specific block.
chaincodeEvents(SignedChaincodeEventsRequest, StreamObserver<ChaincodeEventsResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayStub
The ChaincodeEvents service supplies a stream of responses, each containing all the events emitted by the requested chaincode for a specific block.
ChaincodeEventsRequest - Class in org.hyperledger.fabric.protos.gateway
ChaincodeEventsRequest contains details of the chaincode events that the caller wants to receive.
ChaincodeEventsRequest.Builder - Class in org.hyperledger.fabric.protos.gateway
ChaincodeEventsRequest contains details of the chaincode events that the caller wants to receive.
ChaincodeEventsRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
ChaincodeEventsResponse - Class in org.hyperledger.fabric.protos.gateway
ChaincodeEventsResponse returns chaincode events emitted from a specific block.
ChaincodeEventsResponse.Builder - Class in org.hyperledger.fabric.protos.gateway
ChaincodeEventsResponse returns chaincode events emitted from a specific block.
ChaincodeEventsResponseOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
ChaincodeGrpc - Class in org.hyperledger.fabric.protos.peer
Chaincode as a server - peer establishes a connection to the chaincode as a client Currently only supports a stream connection.
ChaincodeGrpc.ChaincodeBlockingStub - Class in org.hyperledger.fabric.protos.peer
Chaincode as a server - peer establishes a connection to the chaincode as a client Currently only supports a stream connection.
ChaincodeGrpc.ChaincodeFutureStub - Class in org.hyperledger.fabric.protos.peer
Chaincode as a server - peer establishes a connection to the chaincode as a client Currently only supports a stream connection.
ChaincodeGrpc.ChaincodeImplBase - Class in org.hyperledger.fabric.protos.peer
Chaincode as a server - peer establishes a connection to the chaincode as a client Currently only supports a stream connection.
ChaincodeGrpc.ChaincodeStub - Class in org.hyperledger.fabric.protos.peer
Chaincode as a server - peer establishes a connection to the chaincode as a client Currently only supports a stream connection.
ChaincodeHeaderExtension - Class in org.hyperledger.fabric.protos.peer
ChaincodeHeaderExtension is the Header's extentions message to be used when the Header's type is CHAINCODE.
ChaincodeHeaderExtension.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeHeaderExtension is the Header's extentions message to be used when the Header's type is CHAINCODE.
ChaincodeHeaderExtensionOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeID - Class in org.hyperledger.fabric.protos.peer
ChaincodeID contains the path as specified by the deploy transaction that created it as well as the hashCode that is generated by the system for the path.
ChaincodeID.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeID contains the path as specified by the deploy transaction that created it as well as the hashCode that is generated by the system for the path.
ChaincodeIdentifier - Class in org.hyperledger.fabric.protos.peer
ChaincodeIdentifier identifies a piece of chaincode.
ChaincodeIdentifier.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeIdentifier identifies a piece of chaincode.
ChaincodeIdentifierOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeIDOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeImplBase() - Constructor for class org.hyperledger.fabric.protos.peer.ChaincodeGrpc.ChaincodeImplBase
 
ChaincodeInfo - Class in org.hyperledger.fabric.protos.peer
ChaincodeInfo contains general information about an installed/instantiated chaincode
ChaincodeInfo.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeInfo contains general information about an installed/instantiated chaincode
ChaincodeInfoOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeInput - Class in org.hyperledger.fabric.protos.peer
Carries the chaincode function and its arguments.
ChaincodeInput.Builder - Class in org.hyperledger.fabric.protos.peer
Carries the chaincode function and its arguments.
ChaincodeInputOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeInterest - Class in org.hyperledger.fabric.protos.peer
ChaincodeInterest defines an interest about an endorsement for a specific single chaincode invocation.
ChaincodeInterest.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeInterest defines an interest about an endorsement for a specific single chaincode invocation.
ChaincodeInterestOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeInvocationSpec - Class in org.hyperledger.fabric.protos.peer
Carries the chaincode function and its arguments.
ChaincodeInvocationSpec.Builder - Class in org.hyperledger.fabric.protos.peer
Carries the chaincode function and its arguments.
ChaincodeInvocationSpecOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeMessage - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.ChaincodeMessage
ChaincodeMessage.Builder - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.ChaincodeMessage
ChaincodeMessage.Type - Enum in org.hyperledger.fabric.protos.peer
Protobuf enum protos.ChaincodeMessage.Type
ChaincodeMessageOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
ChaincodeProposalPayload - Class in org.hyperledger.fabric.protos.peer
ChaincodeProposalPayload is the Proposal's payload message to be used when the Header's type is CHAINCODE.
ChaincodeProposalPayload.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeProposalPayload is the Proposal's payload message to be used when the Header's type is CHAINCODE.
ChaincodeProposalPayloadOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeProto - Class in org.hyperledger.fabric.protos.peer
 
ChaincodeQuery - Class in org.hyperledger.fabric.protos.discovery
ChaincodeQuery requests ChaincodeQueryResults for a given list of chaincode invocations.
ChaincodeQuery.Builder - Class in org.hyperledger.fabric.protos.discovery
ChaincodeQuery requests ChaincodeQueryResults for a given list of chaincode invocations.
ChaincodeQueryOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
ChaincodeQueryResponse - Class in org.hyperledger.fabric.protos.peer
ChaincodeQueryResponse returns information about each chaincode that pertains to a query in lscc.go, such as GetChaincodes (returns all chaincodes instantiated on a channel), and GetInstalledChaincodes (returns all chaincodes installed on a peer)
ChaincodeQueryResponse.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeQueryResponse returns information about each chaincode that pertains to a query in lscc.go, such as GetChaincodes (returns all chaincodes instantiated on a channel), and GetInstalledChaincodes (returns all chaincodes installed on a peer)
ChaincodeQueryResponseOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeQueryResult - Class in org.hyperledger.fabric.protos.discovery
ChaincodeQueryResult contains EndorsementDescriptors for chaincodes
ChaincodeQueryResult.Builder - Class in org.hyperledger.fabric.protos.discovery
ChaincodeQueryResult contains EndorsementDescriptors for chaincodes
ChaincodeQueryResultOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
CHAINCODES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Properties
 
CHAINCODES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
CHAINCODES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
CHAINCODES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
CHAINCODES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
ChaincodeShimProto - Class in org.hyperledger.fabric.protos.peer
 
ChaincodeSource - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.ChaincodeSource
ChaincodeSource.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.ChaincodeSource
ChaincodeSource.Local - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.ChaincodeSource.Local
ChaincodeSource.Local.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.ChaincodeSource.Local
ChaincodeSource.LocalOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
ChaincodeSource.TypeCase - Enum in org.hyperledger.fabric.protos.peer.lifecycle
 
ChaincodeSource.Unavailable - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.ChaincodeSource.Unavailable
ChaincodeSource.Unavailable.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.ChaincodeSource.Unavailable
ChaincodeSource.UnavailableOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
ChaincodeSourceOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
ChaincodeSpec - Class in org.hyperledger.fabric.protos.peer
Carries the chaincode specification.
ChaincodeSpec.Builder - Class in org.hyperledger.fabric.protos.peer
Carries the chaincode specification.
ChaincodeSpec.Type - Enum in org.hyperledger.fabric.protos.peer
Protobuf enum protos.ChaincodeSpec.Type
ChaincodeSpecOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChaincodeSupportGrpc - Class in org.hyperledger.fabric.protos.peer
Interface that provides support to chaincode execution.
ChaincodeSupportGrpc.ChaincodeSupportBlockingStub - Class in org.hyperledger.fabric.protos.peer
Interface that provides support to chaincode execution.
ChaincodeSupportGrpc.ChaincodeSupportFutureStub - Class in org.hyperledger.fabric.protos.peer
Interface that provides support to chaincode execution.
ChaincodeSupportGrpc.ChaincodeSupportImplBase - Class in org.hyperledger.fabric.protos.peer
Interface that provides support to chaincode execution.
ChaincodeSupportGrpc.ChaincodeSupportStub - Class in org.hyperledger.fabric.protos.peer
Interface that provides support to chaincode execution.
ChaincodeSupportImplBase() - Constructor for class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc.ChaincodeSupportImplBase
 
ChaincodeValidation - Class in org.hyperledger.fabric.protos.peer
ChaincodeValidation instructs the peer how transactions for this chaincode should be validated.
ChaincodeValidation.Builder - Class in org.hyperledger.fabric.protos.peer
ChaincodeValidation instructs the peer how transactions for this chaincode should be validated.
ChaincodeValidationInfo - Class in org.hyperledger.fabric.protos.peer.lifecycle
ValidationInfo is (most) everything the peer needs to know in order to validate a transaction
ChaincodeValidationInfo.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
ValidationInfo is (most) everything the peer needs to know in order to validate a transaction
ChaincodeValidationInfoOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
ChaincodeValidationOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
CHAN_AND_ORG_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
CHAN_AND_ORG = 4;
CHAN_ONLY_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
CHAN_ONLY = 3;
CHAN_OR_ORG_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
CHAN_OR_ORG = 5;
CHANNEL_CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ConfigTree
 
CHANNEL_CONFIG_POLICY_REFERENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
CHANNEL_CONFIG_POLICY_REFERENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
CHANNEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Query
 
CHANNEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
CHANNEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
CHANNEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
CHANNEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
CHANNEL_GROUP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Config
 
CHANNEL_HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Header
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ChannelHeader
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
CHANNEL_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
CHANNEL_MAC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.StateInfo
 
CHANNEL_MAC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
ChannelHeader - Class in org.hyperledger.fabric.protos.common
Header is a generic replay prevention and identity message to include in a signed payload
ChannelHeader.Builder - Class in org.hyperledger.fabric.protos.common
Header is a generic replay prevention and identity message to include in a signed payload
ChannelHeaderOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ChannelInfo - Class in org.hyperledger.fabric.protos.peer
ChannelInfo contains general information about channels
ChannelInfo.Builder - Class in org.hyperledger.fabric.protos.peer
ChannelInfo contains general information about channels
ChannelInfoOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChannelQueryResponse - Class in org.hyperledger.fabric.protos.peer
ChannelQueryResponse returns information about each channel that pertains to a query in lscc.go, such as GetChannels (returns all channels for a given peer)
ChannelQueryResponse.Builder - Class in org.hyperledger.fabric.protos.peer
ChannelQueryResponse returns information about each channel that pertains to a query in lscc.go, such as GetChannels (returns all channels for a given peer)
ChannelQueryResponseOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ChannelRestrictions - Class in org.hyperledger.fabric.protos.orderer
ChannelRestrictions is the mssage which conveys restrictions on channel creation for an orderer
ChannelRestrictions.Builder - Class in org.hyperledger.fabric.protos.orderer
ChannelRestrictions is the mssage which conveys restrictions on channel creation for an orderer
ChannelRestrictionsOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
CHANNELS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
CheckCommitReadinessArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
CheckCommitReadinessArgs is the message used as arguments to `_lifecycle.CheckCommitReadiness`.
CheckCommitReadinessArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
CheckCommitReadinessArgs is the message used as arguments to `_lifecycle.CheckCommitReadiness`.
CheckCommitReadinessArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
CheckCommitReadinessResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
CheckCommitReadinessResult is the message returned by `_lifecycle.CheckCommitReadiness`.
CheckCommitReadinessResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
CheckCommitReadinessResult is the message returned by `_lifecycle.CheckCommitReadiness`.
CheckCommitReadinessResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
CLASS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
clear() - Method in class com.google.rpc.Status.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
clear() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
clear() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
clear() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
clear() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
clear() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
clearAbsoluteMaxBytes() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
The byte count of the serialized messages in a batch cannot exceed this value.
clearAck() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
clearAcls() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
clearAction() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
The list of actions to apply to the ledger
clearActions() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
clearActiveNodes() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
Indicates active nodes in cluster that are reacheable by Raft leader
clearAddress() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The address of the endorsing peer or ordering node that returned an error.
clearAddresses() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
clearAdminOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the admins
clearAdmins() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity denoting the administrator of this MSP
clearAfterTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Only returns events after this transaction ID.
clearAlive() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
clearAliveMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Membership
clearAnchorPeers() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
clearAnonymityType() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
clearApprovals() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
clearApprovals() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
clearArgs() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
repeated bytes args = 1 [json_name = "args"];
clearArgument() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
When 'vscc' a marshaled VSCCArgs
clearAuthentication() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
authentication contains information that the service uses to check the client's eligibility for the queries.
clearBehavior() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The behavior when a missing block is encountered
clearBlock() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
clearBlock() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
.common.Block block = 1 [json_name = "block"];
clearBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
clearBlockAndPrivateData() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
clearBlockAttestation() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
clearBlockNum() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
uint64 block_num = 1 [json_name = "blockNum"];
clearBlockNumber() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Block number in which the chaincode events were emitted.
clearBlockNumber() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
Block number that contains the transaction.
clearBlockNumber() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
uint64 block_number = 1 [json_name = "blockNumber"];
clearBlockNumber() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The block number to generate a snapshot
clearBlockNumbers() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
clearBlockSeq() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
uint64 block_seq = 4 [json_name = "blockSeq"];
clearBlockToLive() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The number of blocks after which the collection data expires.
clearBlockToLive() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The number of blocks after which the collection data expires.
clearBookmark() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
clearBookmark() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
clearBootstrappingSnapshotDir() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
clearBootstrappingSnapshotInfo() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
clearBrokers() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
clearBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
bytes Bytes = 2 [json_name = "Bytes"];
clearCapabilities() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
clearCcQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ChaincodeQuery queries for chaincodes by their name and version.
clearCcQueryRes() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
clearCert() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes cert = 2 [json_name = "cert"];
clearCertificate() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
Certificate represents the second certificate in a certification chain.
clearCertifiersIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
CertifiersIdentifier is the hash of certificates chain of trust related to this organizational unit
clearChaincode() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
string chaincode = 1 [json_name = "chaincode"];
clearChaincodeActions() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
clearChaincodeDefinitions() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
clearChaincodeDeploymentSpec() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
This is the bytes of the ChaincodeDeploymentSpec
clearChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
event emitted by chaincode.
clearChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
clearChaincodeId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Name of the chaincode for which events are requested.
clearChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the ChaincodeID of executing this invocation.
clearChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string chaincode_id = 1 [json_name = "chaincodeId"];
clearChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
The ID of the chaincode to target.
clearChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
clearChaincodeInstallPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
bytes chaincode_install_package = 1 [json_name = "chaincodeInstallPackage"];
clearChaincodeInstallPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
This should be a marshaled lifecycle.ChaincodePackage
clearChaincodeName() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
string chaincode_name = 1 [json_name = "chaincodeName"];
clearChaincodeProposalPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
This field contains the bytes of the ChaincodeProposalPayload message from the original invocation (essentially the arguments) after the application of the visibility function.
clearChaincodes() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
clearChaincodes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
clearChaincodes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
clearChaincodes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
clearChaincodes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
clearChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
clearChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
clearChannel() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
string channel = 1 [json_name = "channel"];
clearChannel() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
The channel of the message.
clearChannel() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
string channel = 1 [json_name = "channel"];
clearChannel() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
string channel = 1 [json_name = "channel"];
clearChannel() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
string channel = 1 [json_name = "channel"];
clearChannelConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config channel_config = 1 [json_name = "channelConfig"];
clearChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
clearChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
clearChannelGroup() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
clearChannelHeader() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
bytes channel_header = 1 [json_name = "channelHeader"];
clearChannelId() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Identifier of the channel this message is bound for
clearChannelId() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Which channel this config update is for
clearChannelId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Identifier of the channel this request is bound for.
clearChannelId() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the channel this request is bound for.
clearChannelId() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
Identifier of the channel this request is bound for.
clearChannelId() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the channel this request is bound for.
clearChannelId() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the channel this request is bound for.
clearChannelId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
channel id
clearChannelId() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
string channel_id = 1 [json_name = "channelId"];
clearChannelId() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
string channel_id = 1 [json_name = "channelId"];
clearChannelId() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The channel ID
clearChannelId() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The channel ID
clearChannelMAC() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
clearChannelMAC() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
clearChannels() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
clearClass_() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
clearClientIdentity() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
This is the identity of the client that is used to verify the signature on the SignedRequest's payload.
clearClientOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the clients
clearClientTlsCert() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
bytes client_tls_cert = 3 [json_name = "clientTlsCert"];
clearClientTlsCertHash() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
This is the hash of the client's TLS cert.
clearCode() - Method in class com.google.rpc.Status.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
clearCodePackage() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
bytes code_package = 3 [json_name = "codePackage"];
clearCollection() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string collection = 3 [json_name = "collection"];
clearCollection() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string collection = 2 [json_name = "collection"];
clearCollection() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string collection = 2 [json_name = "collection"];
clearCollection() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string collection = 2 [json_name = "collection"];
clearCollection() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string collection = 3 [json_name = "collection"];
clearCollection() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string collection = 2 [json_name = "collection"];
clearCollection() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string collection = 2 [json_name = "collection"];
clearCollection() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string collection = 3 [json_name = "collection"];
clearCollection() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string collection = 3 [json_name = "collection"];
clearCollectionConfigs() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
clearCollectionConfigs() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
clearCollectionHashedRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
clearCollectionName() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string collection_name = 1 [json_name = "collectionName"];
clearCollectionName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
clearCollectionName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
clearCollectionNames() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
clearCollectionPvtRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
clearCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
clearCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
clearCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
clearCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
clearCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
clearCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
clearConfig() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
clearConfig() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
A marshaled Config structure
clearConfig() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
Config is MSP dependent configuration info
clearConfig() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
clearConfigQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
clearConfigResult() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
clearConfigSeq() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
uint64 config_seq = 2 [json_name = "configSeq"];
clearConfigUpdate() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
A marshaled ConfigUpdate structure
clearConn() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
ConnEstablish, used for establishing a connection
clearConnect() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
clearConsensusRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
consensus_request is a consensus specific message.
clearConsenterIds() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
clearConsenterMetadata() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
bytes consenter_metadata = 2 [json_name = "consenterMetadata"];
clearConsenters() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
clearContent() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
clearContent() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
string content = 1 [json_name = "content"];
clearContent() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
clearContent() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
clearCreator() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
Creator of the message, a marshaled msp.SerializedIdentity
clearCred() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
cred represents the serialized idemix credential of the default signer
clearCredentialRevocationInformation() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
credential_revocation_information contains a serialized CredentialRevocationInformation
clearCryptoConfig() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
clearCurrentBlockHash() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
bytes currentBlockHash = 2 [json_name = "currentBlockHash"];
clearData() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockData data = 2 [json_name = "data"];
clearData() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
repeated bytes data = 1 [json_name = "data"];
clearData() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Data, the encoding of which is defined by the type in the header
clearData() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
clearData() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
bytes data = 2 [json_name = "data"];
clearData() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Data data specific to the package
clearData() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
clearDataDig() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
clearDataHash() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The hash of the BlockData, by MerkleTree
clearDataModel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
clearDataModel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
clearDataMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Contains a ledger block
clearDataReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
clearDatatype() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
string datatype = 1 [json_name = "datatype"];
clearDataUpdate() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
clearDead() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
clearDecorations() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
clearDetails() - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
clearDigest() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
clearDigests() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
Maybe change this to bitmap later on
clearDigests() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
repeated bytes digests = 2 [json_name = "digests"];
clearDigests() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
clearDisregardNamespacePolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we wish to ignore the namespace endorsement policy
clearElectionTick() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 election_tick = 2 [json_name = "electionTick"];
clearElements() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
clearElements() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
clearEmpty() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Empty message, used for pinging
clearEnable() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
If true then an msp identity that does not contain any of the specified OU will be considered invalid.
clearEndKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string end_key = 2 [json_name = "endKey"];
clearEndKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string endKey = 2 [json_name = "endKey"];
clearEndorsedAt() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
uint64 endorsed_at = 1 [json_name = "endorsedAt"];
clearEndorsement() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The endorsement of the proposal, basically the endorser's signature over the payload
clearEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
clearEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
clearEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
clearEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
clearEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
clearEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
clearEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
clearEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
clearEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
clearEndorsementPolicyRef() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
A named reference to an endorsement policy,
clearEndorsements() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
clearEndorser() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
Identity of the endorser (e.g.
clearEndorsersByGroups() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
clearEndorsingOrganizations() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
clearEndorsingOrganizations() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
clearEndpoint() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
clearEndpoint() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
string endpoint = 1 [json_name = "endpoint"];
clearEndSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
uint64 end_seq_num = 2 [json_name = "endSeqNum"];
clearEnrollmentId() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
enrollment_id contains the enrollment id of this signer
clearEntries() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
clearEntries() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
clearEntries() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
clearEnvelope() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
The transaction envelope.
clearEpoch() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
The epoch in which this header was generated, where epoch is defined based on block height Epoch in which the response has been generated.
clearEpoch() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
epoch represents the current epoch (time interval) used for revocation
clearError() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
Error indicates failure or refusal to process the query
clearError() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
string error = 1 [json_name = "error"];
clearErrorResponse() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
How to respond to errors reported to the deliver service
clearEscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Escc for the chaincode instance
clearEscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the ESCC for this chaincode.
clearEventName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string event_name = 3 [json_name = "eventName"];
clearEvents() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
clearEvents() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the event generated by the chaincode.
clearExtension() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Extension that may be attached based on the header type
clearExtension() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
Optional extensions to the proposal.
clearExtension() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
Extension should be unmarshaled to a type-specific message.
clearFabricNodeOus() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
clearFetchedRecordsCount() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
int32 fetched_records_count = 1 [json_name = "fetchedRecordsCount"];
clearField(Descriptors.FieldDescriptor) - Method in class com.google.rpc.Status.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
clearFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
clearFilter() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
clearFilteredBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
clearFilteredTransactions() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
clearGroups() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
clearHash() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
hash of ChaincodeDeploymentSpec.code_package
clearHash() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
The hash of the chaincode bytes
clearHashedReads() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
clearHashedRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.HashedRWSet for KV and Document data models)
clearHashedWrites() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
clearHasMore() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
bool has_more = 2 [json_name = "hasMore"];
clearHeader() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockHeader header = 1 [json_name = "header"];
clearHeader() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Header is included to provide identity and prevent replay
clearHeader() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockHeader header = 1 [json_name = "header"];
clearHeader() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
The header of the proposal.
clearHeader() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
The header of the proposal action, which is the proposal header
clearHeartbeatTick() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 heartbeat_tick = 3 [json_name = "heartbeatTick"];
clearHeight() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
uint64 height = 1 [json_name = "height"];
clearHello() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for push&pull
clearHost() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
string host = 1 [json_name = "host"];
clearHost() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
string host = 1 [json_name = "host"];
clearHost() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
DNS host name of the anchor peer
clearId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Id of the chaincode that's the unique fingerprint for the CC This is not currently used anywhere but serves as a good eyecatcher
clearId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the chaincode unique id.
clearId() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
string id = 3 [json_name = "id"];
clearId() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
string id = 1 [json_name = "id"];
clearId() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
string id = 1 [json_name = "id"];
clearIdBytes() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
the Identity, serialized according to the rules of its MPS
clearIdentities() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
clearIdentity() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is the msp.SerializedIdentity of the peer, represented in bytes.
clearIdentity() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Client requestor identity.
clearIdentity() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Client requestor identity.
clearIdentity() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
bytes identity = 4 [json_name = "identity"];
clearIdentity() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes identity = 2 [json_name = "identity"];
clearIdentityIdentifierHashFunction() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
clearIncNum() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
uint64 inc_num = 1 [json_name = "incNum"];
clearIndex() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
uint64 index = 1 [json_name = "index"];
clearInfo() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Info string which may contain additional information about the status returned
clearInfo() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Info string which may contain additional information about the returned status.
clearInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
clearInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
bool init_required = 2 [json_name = "initRequired"];
clearInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
clearInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
clearInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
bool init_required = 7 [json_name = "initRequired"];
clearInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
bool init_required = 7 [json_name = "initRequired"];
clearInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
bool init_required = 8 [json_name = "initRequired"];
clearInProgress() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
bool in_progress = 1 [json_name = "inProgress"];
clearInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the chaincode function upon instantiation and its arguments.
clearInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
Input contains the arguments for this invocation.
clearInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeInput input = 3 [json_name = "input"];
clearInstalledChaincodes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
clearInstantiationPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
InstantiationPolicy for the chaincode
clearInstantiationPolicy() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
This is the instantiation policy which is identical in structure to endorsement policy.
clearInt64() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
int64 Int64 = 1 [json_name = "Int64"];
clearInterest() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The chaincode interest derived from simulating the proposal.
clearInterests() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
clearIntermediateCerts() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
clearInternalEndpoint() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
clearIpk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
ipk represents the (serialized) issuer public key
clearIsDeclaration() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
bool is_declaration = 3 [json_name = "isDeclaration"];
clearIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
bool is_delete = 4 [json_name = "isDelete"];
clearIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
bool is_delete = 2 [json_name = "isDelete"];
clearIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bool is_delete = 2 [json_name = "isDelete"];
clearIsInit() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
is_init is used for the application to signal that an invocation is to be routed to the legacy 'Init' function for compatibility with chaincodes which handled Init in the old way.
clearIsolatedData() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
clearIsPurge() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bool is_purge = 4 [json_name = "isPurge"];
clearItrExhausted() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
bool itr_exhausted = 3 [json_name = "itrExhausted"];
clearKey() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string key = 2 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string key = 1 [json_name = "key"];
clearKey() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string key = 1 [json_name = "key"];
clearKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
clearKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
clearKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
clearKeyIdentifier() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
clearKeyMaterial() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
KeyMaterial (optional) for the key to be imported; this is properly encoded key bytes, prefixed by the type of the key
clearKeyPolicies() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
clearKnown() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
repeated bytes known = 2 [json_name = "known"];
clearKvReads() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
clearLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string label = 2 [json_name = "label"];
clearLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string label = 2 [json_name = "label"];
clearLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string label = 2 [json_name = "label"];
clearLastBlockInSnapshot() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
uint64 lastBlockInSnapshot = 1 [json_name = "lastBlockInSnapshot"];
clearLastConfig() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
clearLastOffsetPersisted() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastOffsetPersisted is the encoded value for the Metadata message which is encoded in the ORDERER block metadata index for the case of the Kafka-based orderer.
clearLastOriginalOffsetProcessed() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastOriginalOffsetProcessed is used to keep track of the newest offset processed if a message is re-validated and re-ordered.
clearLastResubmittedConfigOffset() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastResubmittedConfigOffset is used to capture the newest offset of CONFIG kafka message, which is revalidated and resubmitted.
clearLastUpdate() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
The last CONFIG_UPDATE message which generated this current configuration
clearLastValidationSeq() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
last_validation_seq denotes the last configuration sequence at which the sender validated this message.
clearLayouts() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
clearLeadershipMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to indicate intent of peer to become leader
clearLedgerHeight() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
uint64 ledger_height = 1 [json_name = "ledgerHeight"];
clearLeftChannel() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
bool left_channel = 2 [json_name = "leftChannel"];
clearLocalPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
clearLocalPeers() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
clearMaxCount() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
The max count of channels to allow to be created, a value of 0 indicates no limit
clearMaxDegree() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
uint32 max_degree = 1 [json_name = "maxDegree"];
clearMaximumPeerCount() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The maximum number of peers that private data will be sent to upon endorsement.
clearMaximumPeerCount() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The maximum number of peers that private data will be sent to upon endorsement.
clearMaxInflightBlocks() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 max_inflight_blocks = 4 [json_name = "maxInflightBlocks"];
clearMaxLevel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
uint32 max_level = 2 [json_name = "maxLevel"];
clearMaxLevelHashes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
clearMaxMessageCount() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
Simply specified as number of messages for now, in the future we may want to allow this to be specified by size in bytes
clearMemberOnlyRead() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
clearMemberOnlyRead() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
clearMemberOnlyWrite() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
clearMemberOnlyWrite() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
clearMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
clearMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
clearMembers() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
clearMembership() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.Member membership = 1 [json_name = "membership"];
clearMembershipInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
clearMemReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
clearMemRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
clearMessage() - Method in class com.google.rpc.Status.Builder
A developer-facing error message, which should be in English.
clearMessage() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The error message returned by this node.
clearMessage() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A message associated with the response code.
clearMetadata() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
repeated bytes metadata = 1 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
bytes metadata = 3 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
bytes metadata = 2 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
bytes metadata = 2 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes metadata = 3 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
bytes metadata = 3 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
Opaque metadata, dependent on the consensus type.
clearMetadata() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
bytes metadata = 3 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
bytes metadata = 4 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
clearMetadata() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
bytes metadata = 4 [json_name = "metadata"];
clearMetadatahash() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
hash of ChaincodeID.name + ChaincodeID.version
clearMetadataWrites() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
clearMetadataWrites() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
clearMetakey() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
string metakey = 1 [json_name = "metakey"];
clearModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
string mod_policy = 5 [json_name = "modPolicy"];
clearModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
string mod_policy = 3 [json_name = "modPolicy"];
clearModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
string mod_policy = 3 [json_name = "modPolicy"];
clearMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
clearMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
clearMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
clearMsgType() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
clearMspId() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The MSP Identifier of this node.
clearMspid() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
The identifier of the associated membership service provider
clearMspIdentifier() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPIdentifier represents the identifier of the MSP this principal refers to
clearMspIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
MSPIdentifier represents the identifier of the MSP this organization unit refers to
clearMsps() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
clearN() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
int32 n = 1 [json_name = "n"];
clearName() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
SHA256 is currently the only supported and tested algorithm.
clearName() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
the name of the collection inside the denoted chaincode
clearName() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
clearName() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
Name holds the identifier of the MSP
clearName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Name of the chaincode
clearName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
Specifies what code to run for endorsements, defaults 'escc'
clearName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
all other requests will use the name (really a hashcode) generated by the deploy transaction
clearName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
Specifies which code to run to validate transactions, defaults to 'vscc'
clearName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string name = 2 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string name = 2 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string name = 2 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string name = 1 [json_name = "name"];
clearName() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
the name of the collection inside the denoted chaincode
clearNamespace() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string namespace = 2 [json_name = "namespace"];
clearNamespace() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string namespace = 2 [json_name = "namespace"];
clearNamespace() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string namespace = 1 [json_name = "namespace"];
clearNamespace() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
clearNamespace() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
clearNewest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
clearNextCommit() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
clearNextConsenterId() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Carries the Raft ID value that will be assigned to the next OSN that will join this cluster.
clearNonce() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
Arbitrary number that may only be used once.
clearNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
uint64 nonce = 1 [json_name = "nonce"];
clearNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
uint64 nonce = 1 [json_name = "nonce"];
clearNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
uint64 nonce = 1 [json_name = "nonce"];
clearNonce() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
uint64 nonce = 1 [json_name = "nonce"];
clearNonce() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
used mainly for testing, but will might be used in the future for ensuring message delivery by acking
clearNoPrivateReads() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we do not need to read from private data
clearNoPublicWrites() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we do not need to write to the chaincode namespace
clearNOutOf() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
clearNsPvtRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
clearNsRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
clearNumber() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The position in the blockchain
clearNumber() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
uint64 number = 1 [json_name = "number"];
clearNumber() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
The position in the blockchain
clearNymX() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
nym_x is the X-component of the pseudonym elliptic curve point.
clearNymY() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
nym_y is the Y-component of the pseudonym elliptic curve point.
clearOldest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
clearOneof(Descriptors.OneofDescriptor) - Method in class com.google.rpc.Status.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
clearOptions() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
.etcdraft.Options options = 2 [json_name = "options"];
clearOrdererOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the orderers
clearOrderers() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
clearOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
clearOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
clearOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
organizational_unit_identifier defines the organizational unit the default signer is in
clearOrganizationalUnitIdentifiers() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
clearOriginalOffset() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
int64 original_offset = 4 [json_name = "originalOffset"];
clearOu() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
ou contains the organizational unit of the idemix identity
clearOwnerEndorsements() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
clearPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
string package_id = 1 [json_name = "packageId"];
clearPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
string package_id = 1 [json_name = "packageId"];
clearPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
clearPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
string package_id = 1 [json_name = "packageId"];
clearPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
clearPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string package_id = 1 [json_name = "packageId"];
clearPageSize() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
int32 pageSize = 1 [json_name = "pageSize"];
clearPath() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
deploy transaction will use the path
clearPath() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the path as specified by the install/instantiate transaction
clearPayload() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
clearPayload() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
clearPayload() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
A marshaled Payload
clearPayload() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
bytes payload = 1 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
.gossip.Payload payload = 1 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
bytes payload = 1 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
the payload is a marshaled kvrwset.KVRWSet
clearPayload() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
Encodes marhslaed bytes of rwset.TxPvtReadWriteSet defined in rwset.proto
clearPayload() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
bytes payload = 1 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
bytes payload = 2 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
bytes payload = 1 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
bytes payload = 1 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
clearPayload() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
clearPayload() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
content is the fabric transaction that is forwarded to the cluster member.
clearPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
bytes payload = 4 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
bytes payload = 3 [json_name = "payload"];
clearPayload() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
clearPayload() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
clearPayload() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
The payload of the proposal as defined by the type in the proposal header.
clearPayload() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The payload of response.
clearPayload() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A payload that can be used to include metadata with this response.
clearPayload() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
The payload of the action as defined by the type in the header For chaincode, it's the bytes of ChaincodeActionPayload
clearPayloads() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
clearPeerIdentity() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to learn of a peer's certificate
clearPeerOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the peers
clearPeerQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
clearPeers() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
clearPeersByOrg() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
clearPkiId() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes pki_id = 1 [json_name = "pkiId"];
clearPkiId() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
bytes pki_id = 1 [json_name = "pkiId"];
clearPkiId() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
bytes pki_id = 3 [json_name = "pkiId"];
clearPkiId() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes pki_id = 1 [json_name = "pkiId"];
clearPkiId() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
bytes pki_id = 3 [json_name = "pkiId"];
clearPolicies() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
clearPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
.common.Policy policy = 2 [json_name = "policy"];
clearPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Policy endorsement policy for the chaincode instance
clearPolicyRef() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
The policy name to use for this API
clearPort() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
uint32 port = 2 [json_name = "port"];
clearPort() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
uint32 port = 2 [json_name = "port"];
clearPort() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
The port number
clearPreferredMaxBytes() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
The byte count of the serialized messages in a batch should not exceed this value.
clearPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
clearPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
The signed set of endorsed transaction responses to submit.
clearPreviousBlockHash() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
bytes previousBlockHash = 3 [json_name = "previousBlockHash"];
clearPreviousHash() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The hash of the previous block header
clearPrincipal() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
Principal completes the policy principal definition.
clearPrincipalClassification() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
Classification describes the way that one should process Principal.
clearPrincipals() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
clearPrivateData() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Encapsulates private data used to distribute private rwset after the endorsement
clearPrivateData() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
repeated bytes private_data = 3 [json_name = "privateData"];
clearPrivateDataMap() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
clearPrivateReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to request private data
clearPrivateRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to respond to private data requests
clearPrivateRwset() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
bytes private_rwset = 4 [json_name = "privateRwset"];
clearPrivateSigner() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PrivateSigner denotes a reference to the private key of the peer's signing identity
clearPrivateSimHeight() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
uint64 private_sim_height = 5 [json_name = "privateSimHeight"];
clearProbe() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bool probe = 4 [json_name = "probe"];
clearProof() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
proof contains the cryptographic evidence that this identity is valid
clearProperties() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.Properties properties = 5 [json_name = "properties"];
clearProposal() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The signed proposal.
clearProposal() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
clearProposalBytes() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
The bytes of Proposal
clearProposalHash() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
Hash of the proposal that triggered this response.
clearProposalResponsePayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
This is the bytes of the ProposalResponsePayload message signed by the endorsers.
clearProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The signed proposal ready for endorsement.
clearProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
The signed proposal ready for evaluation.
clearPublicSigner() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PublicSigner carries the public information of the signing identity.
clearPvtRwset() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
clearPvtRwsetHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
Hash of entire private read-write set for a specific collection.
clearQuantitiesByGroup() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
clearQueries() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
clearQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
clearQuery() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string query = 1 [json_name = "query"];
clearRaftIndex() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Index of etcd/raft entry for current block.
clearRangeQueriesInfo() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
clearRawReads() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
clearReads() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
clearReadSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
clearReadsInfo() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
clearReadsMerkleHashes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
clearReferences() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
clearReferences() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
clearRegular() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
clearRequest() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
Serialized ChaincodeEventsRequest message.
clearRequest() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
Serialized CommitStatusRequest message.
clearRequest() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
The bytes of SnapshotRequest or SnapshotQuery
clearRequiredPeerCount() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The minimum number of peers private data will be sent to upon endorsement.
clearRequiredPeerCount() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The minimum number of peers private data will be sent to upon endorsement.
clearResourcesConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
clearResponse() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the result of executing this invocation.
clearResponse() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
A response message indicating whether the endorsement of the action was successful
clearResult() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
clearResult() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
The result of the transaction commit, as defined in peer/transaction.proto.
clearResult() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
clearResultBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
bytes resultBytes = 1 [json_name = "resultBytes"];
clearResults() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
clearResults() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the read set and the write set produced by the chaincode executing this invocation.
clearResults() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
clearRevocationList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity revocation list
clearRevocationPk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
revocation_pk is the public key used for revocation of credentials
clearRole() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
clearRole() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
role defines whether the default signer is admin, peer, member or client
clearRole() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
role contains the role of this identity (e.g., ADMIN or MEMBER)
clearRootCerts() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
clearRule() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
clearRule() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
clearRules() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
clearRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
clearRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
clearSecretEnvelope() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
clearSelfInformation() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
clearSeqInBlock() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
uint64 seq_in_block = 5 [json_name = "seqInBlock"];
clearSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
uint64 seq_num = 1 [json_name = "seqNum"];
clearSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
uint64 seq_num = 2 [json_name = "seqNum"];
clearSequence() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
uint64 sequence = 1 [json_name = "sequence"];
clearSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
clearSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
clearSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
clearSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
int64 sequence = 2 [json_name = "sequence"];
clearSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
int64 sequence = 1 [json_name = "sequence"];
clearSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
int64 sequence = 1 [json_name = "sequence"];
clearSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
int64 sequence = 2 [json_name = "sequence"];
clearServerTlsCert() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
bytes server_tls_cert = 4 [json_name = "serverTlsCert"];
clearSignature() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
Signature over the concatenation signatureHeader bytes and config bytes
clearSignature() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
A signature by the creator specified in the Payload header
clearSignature() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
The signature over the concatenation of the Metadata value bytes, signatureHeader, and block header
clearSignature() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
bytes signature = 2 [json_name = "signature"];
clearSignature() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
Signature for request message.
clearSignature() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
Signature for request message.
clearSignature() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
bytes signature = 2 [json_name = "signature"];
clearSignature() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
bytes signature = 2 [json_name = "signature"];
clearSignature() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
Signature of the payload included in ProposalResponse concatenated with the endorser's certificate; ie, sign(ProposalResponse.payload + endorser)
clearSignature() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
Signaure over proposalBytes; this signature is to be verified against the creator identity contained in the header of the Proposal message marshaled as proposalBytes
clearSignature() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
Signaure over request bytes; this signature is to be verified against the client identity
clearSignatureHashFamily() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
clearSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
A marshaled SignatureHeader
clearSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
bytes signature_header = 2 [json_name = "signatureHeader"];
clearSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
An encoded SignatureHeader
clearSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The signature header that contains creator identity and nonce
clearSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The signature header that contains creator identity and nonce
clearSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
clearSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
Initially, only a signature policy is supported.
clearSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
clearSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
Initially, only a signature policy is supported.
clearSignatures() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
clearSignatures() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
clearSignedBy() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
int32 signed_by = 1 [json_name = "signedBy"];
clearSigner() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
signer may contain crypto material to configure a default signer
clearSigningIdentity() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
clearSk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
sk is the secret key of the default signer, corresponding to credential Cred
clearSnapshotIntervalSize() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
Take snapshot when cumulative data exceeds certain size in bytes.
clearSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
clearSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
clearSpecified() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
clearStart() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to start the deliver from
clearStartKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string start_key = 1 [json_name = "startKey"];
clearStartKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string startKey = 1 [json_name = "startKey"];
clearStartPosition() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Position within the ledger at which to start reading events.
clearStartSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
uint64 start_seq_num = 1 [json_name = "startSeqNum"];
clearState() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
clearStateInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
clearStateInfo() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for relaying information about state
clearStateInfoPullReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for asking for StateInfoSnapshots
clearStateRequest() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to ask from a remote peer a set of blocks
clearStateResponse() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to send a set of blocks to a remote peer
clearStateSnapshot() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for sending sets of StateInfo messages
clearStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
clearStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
clearStatus() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.common.Status status = 1 [json_name = "status"];
clearStatus() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Status code, which may be used to programatically respond to success/failure
clearStatus() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
clearStatus() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Status code, which may be used to programatically respond to success/failure.
clearStatus() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
clearStatus() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A status code that should follow the HTTP status codes.
clearStop() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to stop the deliver
clearString() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
string String = 3 [json_name = "String"];
clearSubmitRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
submit_request is a relay of a transaction.
clearSubmitRes() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
clearSubPolicy() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
string sub_policy = 1 [json_name = "subPolicy"];
clearTag() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
determines to which peers it is allowed to forward the message
clearTargetOrganizations() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
clearTickInterval() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
time duration format, e.g.
clearTimeout() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
clearTimeout() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
int32 timeout = 4 [json_name = "timeout"];
clearTimestamp() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Timestamp is the local time when the message was created by the sender
clearTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
clearTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
clearTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
clearTimestamp() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
clearTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
clearTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Timestamp is the time that the message was created as defined by the sender
clearTimeToCut() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
clearTlsCertHash() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
If mutual TLS is employed, this represents the hash of the client's TLS certificate
clearTlsCertHash() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes tls_cert_hash = 3 [json_name = "tlsCertHash"];
clearTlsIntermediateCerts() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
clearTlsRootCerts() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS root certificates trusted by this MSP.
clearTransactionActions() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
clearTransactionEnvelope() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An Envelope which includes a processed transaction
clearTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the transaction to check.
clearTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The unique identifier for the transaction.
clearTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the transaction to evaluate.
clearTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
Identifier of the prepared transaction.
clearTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
Identifier of the proposed transaction.
clearTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the transaction to submit.
clearTransientMap() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
clearTxId() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
An unique identifier that is used end-to-end.
clearTxId() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string tx_id = 3 [json_name = "txId"];
clearTxId() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string tx_id = 1 [json_name = "txId"];
clearTxId() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
string tx_id = 1 [json_name = "txId"];
clearTxId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string tx_id = 2 [json_name = "txId"];
clearTxid() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
string txid = 4 [json_name = "txid"];
clearTxid() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
string txid = 1 [json_name = "txid"];
clearTxNum() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
uint64 tx_num = 2 [json_name = "txNum"];
clearTxSeqInBlock() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
uint64 tx_seq_in_block = 1 [json_name = "txSeqInBlock"];
clearTxValidationCode() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
clearType() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
clearType() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Header types 0-10000 are reserved and defined by HeaderType
clearType() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
For outside implementors, consider the first 1000 types reserved, otherwise one of PolicyType
clearType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
clearType() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
Type holds the type of the MSP; the default one would be of type FABRIC implementing an X.509 based provider
clearType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
clearType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The consensus type: "solo", "kafka" or "etcdraft".
clearType() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
clearType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
clearType() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
clearType() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
clearType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
clearType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
clearType() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
clearType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.common.HeaderType type = 2 [json_name = "type"];
clearType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
clearType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
clearUnavailable() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
clearValidationCode() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An indication of whether the transaction was validated or invalidated by committing peer
clearValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
clearValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
bytes validation_parameter = 2 [json_name = "validationParameter"];
clearValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
clearValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
clearValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
bytes validation_parameter = 5 [json_name = "validationParameter"];
clearValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
bytes validation_parameter = 5 [json_name = "validationParameter"];
clearValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
clearValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
clearValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
string validation_plugin = 1 [json_name = "validationPlugin"];
clearValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
clearValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
clearValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
clearValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
clearValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
clearValue() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
bytes value = 2 [json_name = "value"];
clearValue() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
bytes value = 1 [json_name = "value"];
clearValue() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
bytes value = 2 [json_name = "value"];
clearValue() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
bytes value = 2 [json_name = "value"];
clearValue() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
bytes value = 3 [json_name = "value"];
clearValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
bytes value = 2 [json_name = "value"];
clearValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
bytes value = 3 [json_name = "value"];
clearValue() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
bytes value = 2 [json_name = "value"];
clearValue() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
bytes value = 2 [json_name = "value"];
clearValueHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bytes value_hash = 3 [json_name = "valueHash"];
clearValues() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
clearVersion() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Version indicates message protocol version
clearVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
uint64 version = 1 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
uint64 version = 1 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
uint64 version = 1 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
int32 version = 1 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string version = 2 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
.kvrwset.Version version = 2 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
.kvrwset.Version version = 2 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Version of the chaincode
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
user friendly version name for the chaincode
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
A user friendly human readable name corresponding to the ID
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string version = 2 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string version = 3 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string version = 1 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string version = 3 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string version = 3 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string version = 3 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string version = 2 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string version = 2 [json_name = "version"];
clearVersion() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Version indicates message protocol version
clearVscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Vscc for the chaincode instance
clearVscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the VSCC for this chaincode.
clearWidth() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
width specifies the width of the Merkle tree to use when computing the BlockDataHash in order to replicate flat hashing, set this width to MAX_UINT32
clearWrites() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
clearWriteSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
WriteSet lists the portion of the config which was written, this should included updated Versions
CLIENT_IDENTITY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
CLIENT_OU_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
CLIENT_TLS_CERT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
CLIENT_TLS_CERT_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
CLIENT_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
Represents an MSP Client
clone() - Method in class com.google.rpc.Status.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
clone() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
clone() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
clone() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
clone() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
clone() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
ClusterGrpc - Class in org.hyperledger.fabric.protos.orderer
Cluster defines communication between cluster members.
ClusterGrpc.ClusterBlockingStub - Class in org.hyperledger.fabric.protos.orderer
Cluster defines communication between cluster members.
ClusterGrpc.ClusterFutureStub - Class in org.hyperledger.fabric.protos.orderer
Cluster defines communication between cluster members.
ClusterGrpc.ClusterImplBase - Class in org.hyperledger.fabric.protos.orderer
Cluster defines communication between cluster members.
ClusterGrpc.ClusterStub - Class in org.hyperledger.fabric.protos.orderer
Cluster defines communication between cluster members.
ClusterImplBase() - Constructor for class org.hyperledger.fabric.protos.orderer.ClusterGrpc.ClusterImplBase
 
ClusterMetadata - Class in org.hyperledger.fabric.protos.orderer.etcdraft
ClusterMetadata encapsulates metadata that is exchanged among cluster nodes
ClusterMetadata.Builder - Class in org.hyperledger.fabric.protos.orderer.etcdraft
ClusterMetadata encapsulates metadata that is exchanged among cluster nodes
ClusterMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.orderer.etcdraft
 
ClusterProto - Class in org.hyperledger.fabric.protos.orderer
 
CODE_FIELD_NUMBER - Static variable in class com.google.rpc.Status
 
CODE_PACKAGE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
COLLECTION_CONFIGS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
COLLECTION_CONFIGS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.DelState
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetState
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.PutState
 
COLLECTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
COLLECTION_HASHED_RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
COLLECTION_NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
COLLECTION_NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
COLLECTION_NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
COLLECTION_NAMES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
COLLECTION_PVT_RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
CollectionConfig - Class in org.hyperledger.fabric.protos.common
Deprecated.
CollectionConfig - Class in org.hyperledger.fabric.protos.peer
CollectionConfig defines the configuration of a collection object; it currently contains a single, static type.
CollectionConfig.Builder - Class in org.hyperledger.fabric.protos.common
Deprecated.
CollectionConfig defines the configuration of a collection object; it currently contains a single, static type.
CollectionConfig.Builder - Class in org.hyperledger.fabric.protos.peer
CollectionConfig defines the configuration of a collection object; it currently contains a single, static type.
CollectionConfig.PayloadCase - Enum in org.hyperledger.fabric.protos.common
Deprecated.
 
CollectionConfig.PayloadCase - Enum in org.hyperledger.fabric.protos.peer
 
CollectionConfigOrBuilder - Interface in org.hyperledger.fabric.protos.common
Deprecated.
CollectionConfigOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
CollectionConfigPackage - Class in org.hyperledger.fabric.protos.common
Deprecated.
CollectionConfigPackage - Class in org.hyperledger.fabric.protos.peer
CollectionConfigPackage represents an array of CollectionConfig messages; the extra struct is required because repeated oneof is forbidden by the protobuf syntax
CollectionConfigPackage.Builder - Class in org.hyperledger.fabric.protos.common
Deprecated.
CollectionConfigPackage represents an array of CollectionConfig messages; the extra struct is required because repeated oneof is forbidden by the protobuf syntax
CollectionConfigPackage.Builder - Class in org.hyperledger.fabric.protos.peer
CollectionConfigPackage represents an array of CollectionConfig messages; the extra struct is required because repeated oneof is forbidden by the protobuf syntax
CollectionConfigPackageOrBuilder - Interface in org.hyperledger.fabric.protos.common
Deprecated.
CollectionConfigPackageOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
CollectionHashedReadWriteSet - Class in org.hyperledger.fabric.protos.ledger.rwset
CollectionHashedReadWriteSet encapsulate the hashed representation for the private read-write set for a collection
CollectionHashedReadWriteSet.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset
CollectionHashedReadWriteSet encapsulate the hashed representation for the private read-write set for a collection
CollectionHashedReadWriteSetOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset
 
CollectionPolicyConfig - Class in org.hyperledger.fabric.protos.common
Deprecated.
CollectionPolicyConfig - Class in org.hyperledger.fabric.protos.peer
Collection policy configuration.
CollectionPolicyConfig.Builder - Class in org.hyperledger.fabric.protos.common
Deprecated.
Collection policy configuration.
CollectionPolicyConfig.Builder - Class in org.hyperledger.fabric.protos.peer
Collection policy configuration.
CollectionPolicyConfig.PayloadCase - Enum in org.hyperledger.fabric.protos.common
Deprecated.
 
CollectionPolicyConfig.PayloadCase - Enum in org.hyperledger.fabric.protos.peer
 
CollectionPolicyConfigOrBuilder - Interface in org.hyperledger.fabric.protos.common
Deprecated.
CollectionPolicyConfigOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
CollectionProto - Class in org.hyperledger.fabric.protos.common
 
CollectionProto - Class in org.hyperledger.fabric.protos.peer
 
CollectionPvtReadWriteSet - Class in org.hyperledger.fabric.protos.ledger.rwset
CollectionPvtReadWriteSet encapsulates the private read-write set for a collection
CollectionPvtReadWriteSet.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset
CollectionPvtReadWriteSet encapsulates the private read-write set for a collection
CollectionPvtReadWriteSetOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset
 
COLLECTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
COLLECTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
COLLECTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
COLLECTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
COLLECTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
COLLECTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
com.google.rpc - package com.google.rpc
 
COMBINED_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
an identity to be anonymous or nominal.
CombinedPrincipal - Class in org.hyperledger.fabric.protos.common
CombinedPrincipal governs the organization of the Principal field of a policy principal when principal_classification has indicated that a combined form of principals is required
CombinedPrincipal.Builder - Class in org.hyperledger.fabric.protos.common
CombinedPrincipal governs the organization of the Principal field of a policy principal when principal_classification has indicated that a combined form of principals is required
CombinedPrincipalOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
COMMIT_HASH_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
Block metadata array position to store the hash of TRANSACTIONS_FILTER, State Updates, and the COMMIT_HASH of the previous block
CommitChaincodeDefinitionArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
CommitChaincodeDefinitionArgs is the message used as arguments to `_lifecycle.CommitChaincodeDefinition`.
CommitChaincodeDefinitionArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
CommitChaincodeDefinitionArgs is the message used as arguments to `_lifecycle.CommitChaincodeDefinition`.
CommitChaincodeDefinitionArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
CommitChaincodeDefinitionResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
CommitChaincodeDefinitionResult is the message returned by `_lifecycle.CommitChaincodeDefinition`.
CommitChaincodeDefinitionResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
CommitChaincodeDefinitionResult is the message returned by `_lifecycle.CommitChaincodeDefinition`.
CommitChaincodeDefinitionResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
commitStatus(SignedCommitStatusRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayBlockingStub
The CommitStatus service will indicate whether a prepared transaction previously submitted to the Submit service has been committed.
commitStatus(SignedCommitStatusRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayFutureStub
The CommitStatus service will indicate whether a prepared transaction previously submitted to the Submit service has been committed.
commitStatus(SignedCommitStatusRequest, StreamObserver<CommitStatusResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayImplBase
The CommitStatus service will indicate whether a prepared transaction previously submitted to the Submit service has been committed.
commitStatus(SignedCommitStatusRequest, StreamObserver<CommitStatusResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayStub
The CommitStatus service will indicate whether a prepared transaction previously submitted to the Submit service has been committed.
CommitStatusRequest - Class in org.hyperledger.fabric.protos.gateway
CommitStatusRequest contains the details required to check whether a transaction has been successfully committed.
CommitStatusRequest.Builder - Class in org.hyperledger.fabric.protos.gateway
CommitStatusRequest contains the details required to check whether a transaction has been successfully committed.
CommitStatusRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
CommitStatusResponse - Class in org.hyperledger.fabric.protos.gateway
CommitStatusResponse returns the result of committing a transaction.
CommitStatusResponse.Builder - Class in org.hyperledger.fabric.protos.gateway
CommitStatusResponse returns the result of committing a transaction.
CommitStatusResponseOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
CommonProto - Class in org.hyperledger.fabric.protos.common
 
COMPLETED_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
COMPLETED = 6;
Config - Class in org.hyperledger.fabric.protos.common
Config represents the config for a particular channel
Config.Builder - Class in org.hyperledger.fabric.protos.common
Config represents the config for a particular channel
CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.MSPConfig
 
CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
CONFIG_QUERY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Query
 
CONFIG_RESULT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.QueryResult
 
CONFIG_SEQ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
CONFIG_UPDATE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
CONFIG_UPDATE_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.HeaderType
Used for transactions which update the channel config
CONFIG_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.HeaderType
Used for messages which express the channel config
CONFIG_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
CONFIG = 2;
ConfigEnvelope - Class in org.hyperledger.fabric.protos.common
ConfigEnvelope is designed to contain _all_ configuration for a chain with no dependency on previous configuration transactions.
ConfigEnvelope.Builder - Class in org.hyperledger.fabric.protos.common
ConfigEnvelope is designed to contain _all_ configuration for a chain with no dependency on previous configuration transactions.
ConfigEnvelopeOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ConfigGroup - Class in org.hyperledger.fabric.protos.common
ConfigGroup is the hierarchical data structure for holding config
ConfigGroup.Builder - Class in org.hyperledger.fabric.protos.common
ConfigGroup is the hierarchical data structure for holding config
ConfigGroupOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ConfigMetadata - Class in org.hyperledger.fabric.protos.orderer.etcdraft
ConfigMetadata is serialized and set as the value of ConsensusType.Metadata in a channel configuration when the ConsensusType.Type is set "etcdraft".
ConfigMetadata.Builder - Class in org.hyperledger.fabric.protos.orderer.etcdraft
ConfigMetadata is serialized and set as the value of ConsensusType.Metadata in a channel configuration when the ConsensusType.Type is set "etcdraft".
ConfigMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.orderer.etcdraft
 
ConfigOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ConfigPolicy - Class in org.hyperledger.fabric.protos.common
Protobuf type common.ConfigPolicy
ConfigPolicy.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.ConfigPolicy
ConfigPolicyOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ConfigQuery - Class in org.hyperledger.fabric.protos.discovery
ConfigQuery requests a ConfigResult
ConfigQuery.Builder - Class in org.hyperledger.fabric.protos.discovery
ConfigQuery requests a ConfigResult
ConfigQueryOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
ConfigResult - Class in org.hyperledger.fabric.protos.discovery
Protobuf type discovery.ConfigResult
ConfigResult.Builder - Class in org.hyperledger.fabric.protos.discovery
Protobuf type discovery.ConfigResult
ConfigResultOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
ConfigSignature - Class in org.hyperledger.fabric.protos.common
Protobuf type common.ConfigSignature
ConfigSignature.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.ConfigSignature
ConfigSignatureOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ConfigTree - Class in org.hyperledger.fabric.protos.peer
ConfigTree encapsulates channel and resources configuration of a channel.
ConfigTree.Builder - Class in org.hyperledger.fabric.protos.peer
ConfigTree encapsulates channel and resources configuration of a channel.
ConfigTreeOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ConfigTxProto - Class in org.hyperledger.fabric.protos.common
 
ConfigUpdate - Class in org.hyperledger.fabric.protos.common
ConfigUpdate is used to submit a subset of config and to have the orderer apply to Config it is always submitted inside a ConfigUpdateEnvelope which allows the addition of signatures resulting in a new total configuration.
ConfigUpdate.Builder - Class in org.hyperledger.fabric.protos.common
ConfigUpdate is used to submit a subset of config and to have the orderer apply to Config it is always submitted inside a ConfigUpdateEnvelope which allows the addition of signatures resulting in a new total configuration.
ConfigUpdateEnvelope - Class in org.hyperledger.fabric.protos.common
Protobuf type common.ConfigUpdateEnvelope
ConfigUpdateEnvelope.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.ConfigUpdateEnvelope
ConfigUpdateEnvelopeOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ConfigUpdateOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ConfigurationProto - Class in org.hyperledger.fabric.protos.common
 
ConfigurationProto - Class in org.hyperledger.fabric.protos.orderer
 
ConfigurationProto - Class in org.hyperledger.fabric.protos.orderer.etcdraft
 
ConfigurationProto - Class in org.hyperledger.fabric.protos.peer
 
ConfigValue - Class in org.hyperledger.fabric.protos.common
ConfigValue represents an individual piece of config data
ConfigValue.Builder - Class in org.hyperledger.fabric.protos.common
ConfigValue represents an individual piece of config data
ConfigValueOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
CONN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
connect(StreamObserver<ChaincodeMessage>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc.ChaincodeImplBase
 
connect(StreamObserver<ChaincodeMessage>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc.ChaincodeStub
 
CONNECT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
ConnEstablish - Class in org.hyperledger.fabric.protos.gossip
ConnEstablish is the message used for the gossip handshake Whenever a peer connects to another peer, it handshakes with it by sending this message that proves its identity
ConnEstablish.Builder - Class in org.hyperledger.fabric.protos.gossip
ConnEstablish is the message used for the gossip handshake Whenever a peer connects to another peer, it handshakes with it by sending this message that proves its identity
ConnEstablishOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
CONSENSUS_REQUEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.StepRequest
 
ConsensusRequest - Class in org.hyperledger.fabric.protos.orderer
ConsensusRequest is a consensus specific message sent to a cluster member.
ConsensusRequest.Builder - Class in org.hyperledger.fabric.protos.orderer
ConsensusRequest is a consensus specific message sent to a cluster member.
ConsensusRequestOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
ConsensusType - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.ConsensusType
ConsensusType.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.ConsensusType
ConsensusType.State - Enum in org.hyperledger.fabric.protos.orderer
State defines the orderer mode of operation, typically for consensus-type migration.
ConsensusTypeOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
Consenter - Class in org.hyperledger.fabric.protos.orderer.etcdraft
Consenter represents a consenting node (i.e.
Consenter.Builder - Class in org.hyperledger.fabric.protos.orderer.etcdraft
Consenter represents a consenting node (i.e.
CONSENTER_IDS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
CONSENTER_METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
ConsenterOrBuilder - Interface in org.hyperledger.fabric.protos.orderer.etcdraft
 
CONSENTERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
Consortium - Class in org.hyperledger.fabric.protos.common
Consortium represents the consortium context in which the channel was created
Consortium.Builder - Class in org.hyperledger.fabric.protos.common
Consortium represents the consortium context in which the channel was created
ConsortiumOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
containsAcls(String) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
containsAcls(String) - Method in class org.hyperledger.fabric.protos.peer.ACLs
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
containsAcls(String) - Method in interface org.hyperledger.fabric.protos.peer.ACLsOrBuilder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
containsApprovals(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
map<string, bool> approvals = 1 [json_name = "approvals"];
containsApprovals(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
map<string, bool> approvals = 1 [json_name = "approvals"];
containsApprovals(String) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResultOrBuilder
map<string, bool> approvals = 1 [json_name = "approvals"];
containsApprovals(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
map<string, bool> approvals = 8 [json_name = "approvals"];
containsApprovals(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
map<string, bool> approvals = 8 [json_name = "approvals"];
containsApprovals(String) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
map<string, bool> approvals = 8 [json_name = "approvals"];
containsCapabilities(String) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
containsCapabilities(String) - Method in class org.hyperledger.fabric.protos.common.Capabilities
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
containsCapabilities(String) - Method in interface org.hyperledger.fabric.protos.common.CapabilitiesOrBuilder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
containsCollectionConfigs(String) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
containsCollectionConfigs(String) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
containsCollectionConfigs(String) - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
containsDecorations(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
map<string, bytes> decorations = 2 [json_name = "decorations"];
containsDecorations(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
map<string, bytes> decorations = 2 [json_name = "decorations"];
containsDecorations(String) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
map<string, bytes> decorations = 2 [json_name = "decorations"];
containsEndorsersByGroups(String) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies the endorsers, separated to groups.
containsEndorsersByGroups(String) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies the endorsers, separated to groups.
containsEndorsersByGroups(String) - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies the endorsers, separated to groups.
containsGroups(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
containsGroups(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
containsGroups(String) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
containsIsolatedData(String) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
containsIsolatedData(String) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
containsIsolatedData(String) - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
containsMsps(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
msps is a map from MSP_ID to FabricMSPConfig
containsMsps(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
msps is a map from MSP_ID to FabricMSPConfig
containsMsps(String) - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
msps is a map from MSP_ID to FabricMSPConfig
containsOrderers(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
orderers is a map from MSP_ID to endpoint lists of orderers
containsOrderers(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
orderers is a map from MSP_ID to endpoint lists of orderers
containsOrderers(String) - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
orderers is a map from MSP_ID to endpoint lists of orderers
containsPeersByOrg(String) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
containsPeersByOrg(String) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
containsPeersByOrg(String) - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipResultOrBuilder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
containsPolicies(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
containsPolicies(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
containsPolicies(String) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
containsPrivateDataMap(long) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
containsPrivateDataMap(long) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
containsPrivateDataMap(long) - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
containsQuantitiesByGroup(String) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Specifies how many non repeated signatures of each group are needed for endorsement
containsQuantitiesByGroup(String) - Method in class org.hyperledger.fabric.protos.discovery.Layout
Specifies how many non repeated signatures of each group are needed for endorsement
containsQuantitiesByGroup(String) - Method in interface org.hyperledger.fabric.protos.discovery.LayoutOrBuilder
Specifies how many non repeated signatures of each group are needed for endorsement
containsReferences(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
containsReferences(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
containsReferences(String) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
containsReferences(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
containsReferences(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
containsReferences(String) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
containsTransientMap(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
TransientMap contains data (e.g.
containsTransientMap(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
TransientMap contains data (e.g.
containsTransientMap(String) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeProposalPayloadOrBuilder
TransientMap contains data (e.g.
containsValues(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
containsValues(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
containsValues(String) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
CONTENT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
CONTENT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Error
 
CREATOR_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignatureHeader
 
CRED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
CREDENTIAL_REVOCATION_INFORMATION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
CRYPTO_CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
CURRENTBLOCKHASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockchainInfo
 

D

DATA_DIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Block
 
DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockData
 
DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Payload
 
DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Payload
 
DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
DATA_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockHeader
 
DATA_MODEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
DATA_MODEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
DATA_MSG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
DATA_REQ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
DATA_UPDATE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
DataDigest - Class in org.hyperledger.fabric.protos.gossip
DataDigest is the message sent from the receiver peer to the initator peer and contains the data items it has
DataDigest.Builder - Class in org.hyperledger.fabric.protos.gossip
DataDigest is the message sent from the receiver peer to the initator peer and contains the data items it has
DataDigestOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
DataMessage - Class in org.hyperledger.fabric.protos.gossip
DataMessage is the message that contains a block
DataMessage.Builder - Class in org.hyperledger.fabric.protos.gossip
DataMessage is the message that contains a block
DataMessageOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
DataRequest - Class in org.hyperledger.fabric.protos.gossip
DataRequest is a message used for a peer to request certain data blocks from a remote peer
DataRequest.Builder - Class in org.hyperledger.fabric.protos.gossip
DataRequest is a message used for a peer to request certain data blocks from a remote peer
DataRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
DATATYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
DataUpdate - Class in org.hyperledger.fabric.protos.gossip
DataUpdate is the final message in the pull phase sent from the receiver to the initiator
DataUpdate.Builder - Class in org.hyperledger.fabric.protos.gossip
DataUpdate is the final message in the pull phase sent from the receiver to the initiator
DataUpdateOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
DbProto - Class in org.hyperledger.fabric.protos.peer.lifecycle
 
DEAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
DECORATIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
DEL_STATE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
DEL_STATE = 10;
deliver(StreamObserver<DeliverResponse>) - Method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc.AtomicBroadcastImplBase
deliver first requires an Envelope of type DELIVER_SEEK_INFO with Payload data as a mashaled SeekInfo message, then a stream of block replies is received.
deliver(StreamObserver<DeliverResponse>) - Method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc.AtomicBroadcastStub
deliver first requires an Envelope of type DELIVER_SEEK_INFO with Payload data as a mashaled SeekInfo message, then a stream of block replies is received.
deliver(StreamObserver<DeliverResponse>) - Method in class org.hyperledger.fabric.protos.peer.DeliverGrpc.DeliverImplBase
Deliver first requires an Envelope of type ab.DELIVER_SEEK_INFO with Payload data as a marshaled orderer.SeekInfo message, then a stream of block replies is received
deliver(StreamObserver<DeliverResponse>) - Method in class org.hyperledger.fabric.protos.peer.DeliverGrpc.DeliverStub
Deliver first requires an Envelope of type ab.DELIVER_SEEK_INFO with Payload data as a marshaled orderer.SeekInfo message, then a stream of block replies is received
DELIVER_SEEK_INFO_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.HeaderType
Used as the type for Envelope messages submitted to instruct the Deliver API to seek
deliverFiltered(StreamObserver<DeliverResponse>) - Method in class org.hyperledger.fabric.protos.peer.DeliverGrpc.DeliverImplBase
DeliverFiltered first requires an Envelope of type ab.DELIVER_SEEK_INFO with Payload data as a marshaled orderer.SeekInfo message, then a stream of **filtered** block replies is received
deliverFiltered(StreamObserver<DeliverResponse>) - Method in class org.hyperledger.fabric.protos.peer.DeliverGrpc.DeliverStub
DeliverFiltered first requires an Envelope of type ab.DELIVER_SEEK_INFO with Payload data as a marshaled orderer.SeekInfo message, then a stream of **filtered** block replies is received
DeliverGrpc - Class in org.hyperledger.fabric.protos.peer
 
DeliverGrpc.DeliverBlockingStub - Class in org.hyperledger.fabric.protos.peer
 
DeliverGrpc.DeliverFutureStub - Class in org.hyperledger.fabric.protos.peer
 
DeliverGrpc.DeliverImplBase - Class in org.hyperledger.fabric.protos.peer
 
DeliverGrpc.DeliverStub - Class in org.hyperledger.fabric.protos.peer
 
DeliverImplBase() - Constructor for class org.hyperledger.fabric.protos.peer.DeliverGrpc.DeliverImplBase
 
DeliverResponse - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.DeliverResponse
DeliverResponse - Class in org.hyperledger.fabric.protos.peer
DeliverResponse
DeliverResponse.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.DeliverResponse
DeliverResponse.Builder - Class in org.hyperledger.fabric.protos.peer
DeliverResponse
DeliverResponse.TypeCase - Enum in org.hyperledger.fabric.protos.orderer
 
DeliverResponse.TypeCase - Enum in org.hyperledger.fabric.protos.peer
 
DeliverResponseOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
DeliverResponseOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
deliverWithPrivateData(StreamObserver<DeliverResponse>) - Method in class org.hyperledger.fabric.protos.peer.DeliverGrpc.DeliverImplBase
DeliverWithPrivateData first requires an Envelope of type ab.DELIVER_SEEK_INFO with Payload data as a marshaled orderer.SeekInfo message, then a stream of block and private data replies is received
deliverWithPrivateData(StreamObserver<DeliverResponse>) - Method in class org.hyperledger.fabric.protos.peer.DeliverGrpc.DeliverStub
DeliverWithPrivateData first requires an Envelope of type ab.DELIVER_SEEK_INFO with Payload data as a marshaled orderer.SeekInfo message, then a stream of block and private data replies is received
DelState - Class in org.hyperledger.fabric.protos.peer
DelState is the payload of a ChaincodeMessage.
DelState.Builder - Class in org.hyperledger.fabric.protos.peer
DelState is the payload of a ChaincodeMessage.
DelStateOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
DETAILS_FIELD_NUMBER - Static variable in class com.google.rpc.Status
 
DIGEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
DIGESTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataDigest
 
DIGESTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataRequest
 
DIGESTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
discover(SignedRequest) - Method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc.DiscoveryBlockingStub
Discover receives a signed request, and returns a response.
discover(SignedRequest) - Method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc.DiscoveryFutureStub
Discover receives a signed request, and returns a response.
discover(SignedRequest, StreamObserver<Response>) - Method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc.DiscoveryImplBase
Discover receives a signed request, and returns a response.
discover(SignedRequest, StreamObserver<Response>) - Method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc.DiscoveryStub
Discover receives a signed request, and returns a response.
DiscoveryGrpc - Class in org.hyperledger.fabric.protos.discovery
Discovery defines a service that serves information about the fabric network like which peers, orderers, chaincodes, etc.
DiscoveryGrpc.DiscoveryBlockingStub - Class in org.hyperledger.fabric.protos.discovery
Discovery defines a service that serves information about the fabric network like which peers, orderers, chaincodes, etc.
DiscoveryGrpc.DiscoveryFutureStub - Class in org.hyperledger.fabric.protos.discovery
Discovery defines a service that serves information about the fabric network like which peers, orderers, chaincodes, etc.
DiscoveryGrpc.DiscoveryImplBase - Class in org.hyperledger.fabric.protos.discovery
Discovery defines a service that serves information about the fabric network like which peers, orderers, chaincodes, etc.
DiscoveryGrpc.DiscoveryStub - Class in org.hyperledger.fabric.protos.discovery
Discovery defines a service that serves information about the fabric network like which peers, orderers, chaincodes, etc.
DiscoveryImplBase() - Constructor for class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc.DiscoveryImplBase
 
DISREGARD_NAMESPACE_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
DUPLICATE_TXID_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
DUPLICATE_TXID = 9;

E

ELECTION_TICK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
ELEMENTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
ELEMENTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
Empty - Class in org.hyperledger.fabric.protos.gossip
Empty is used for pinging and in tests
Empty.Builder - Class in org.hyperledger.fabric.protos.gossip
Empty is used for pinging and in tests
EMPTY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
EMPTY_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
EMPTY = 1;
EmptyOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
ENABLE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
END_KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
END_SEQ_NUM_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
ENDKEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
endorse(EndorseRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayBlockingStub
The Endorse service passes a proposed transaction to the gateway in order to obtain sufficient endorsement.
endorse(EndorseRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayFutureStub
The Endorse service passes a proposed transaction to the gateway in order to obtain sufficient endorsement.
endorse(EndorseRequest, StreamObserver<EndorseResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayImplBase
The Endorse service passes a proposed transaction to the gateway in order to obtain sufficient endorsement.
endorse(EndorseRequest, StreamObserver<EndorseResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayStub
The Endorse service passes a proposed transaction to the gateway in order to obtain sufficient endorsement.
ENDORSED_AT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
Endorsement - Class in org.hyperledger.fabric.protos.peer
An endorsement is a signature of an endorser over a proposal response.
Endorsement.Builder - Class in org.hyperledger.fabric.protos.peer
An endorsement is a signature of an endorser over a proposal response.
ENDORSEMENT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
ENDORSEMENT_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
ENDORSEMENT_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
ENDORSEMENT_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
ENDORSEMENT_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
ENDORSEMENT_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
ENDORSEMENT_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
ENDORSEMENT_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
ENDORSEMENT_POLICY_FAILURE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
ENDORSEMENT_POLICY_FAILURE = 10;
ENDORSEMENT_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
ENDORSEMENT_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
ENDORSEMENT_POLICY_REF_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
EndorsementDescriptor - Class in org.hyperledger.fabric.protos.discovery
EndorsementDescriptor contains information about which peers can be used to request endorsement from, such that the endorsement policy would be fulfilled.
EndorsementDescriptor.Builder - Class in org.hyperledger.fabric.protos.discovery
EndorsementDescriptor contains information about which peers can be used to request endorsement from, such that the endorsement policy would be fulfilled.
EndorsementDescriptorOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
EndorsementOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ENDORSEMENTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
ENDORSER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Endorsement
 
ENDORSER_TRANSACTION_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.HeaderType
Used by the SDK to submit endorser based transactions
EndorseRequest - Class in org.hyperledger.fabric.protos.gateway
EndorseRequest contains the details required to obtain sufficient endorsements for a transaction to be committed to the ledger.
EndorseRequest.Builder - Class in org.hyperledger.fabric.protos.gateway
EndorseRequest contains the details required to obtain sufficient endorsements for a transaction to be committed to the ledger.
EndorseRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
EndorseResponse - Class in org.hyperledger.fabric.protos.gateway
EndorseResponse returns the result of endorsing a transaction.
EndorseResponse.Builder - Class in org.hyperledger.fabric.protos.gateway
EndorseResponse returns the result of endorsing a transaction.
EndorseResponseOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
EndorserGrpc - Class in org.hyperledger.fabric.protos.peer
 
EndorserGrpc.EndorserBlockingStub - Class in org.hyperledger.fabric.protos.peer
 
EndorserGrpc.EndorserFutureStub - Class in org.hyperledger.fabric.protos.peer
 
EndorserGrpc.EndorserImplBase - Class in org.hyperledger.fabric.protos.peer
 
EndorserGrpc.EndorserStub - Class in org.hyperledger.fabric.protos.peer
 
EndorserImplBase() - Constructor for class org.hyperledger.fabric.protos.peer.EndorserGrpc.EndorserImplBase
 
ENDORSERS_BY_GROUPS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
ENDORSING_ORGANIZATIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
ENDORSING_ORGANIZATIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
Endpoint - Class in org.hyperledger.fabric.protos.discovery
Endpoint is a combination of a host and a port
Endpoint.Builder - Class in org.hyperledger.fabric.protos.discovery
Endpoint is a combination of a host and a port
ENDPOINT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Endpoints
 
ENDPOINT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Member
 
EndpointOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
Endpoints - Class in org.hyperledger.fabric.protos.discovery
Endpoints is a list of Endpoint(s)
Endpoints.Builder - Class in org.hyperledger.fabric.protos.discovery
Endpoints is a list of Endpoint(s)
EndpointsOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
ENROLLMENT_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
ENTRIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
ENTRIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
ENTRIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
Envelope - Class in org.hyperledger.fabric.protos.common
Envelope wraps a Payload with a signature so that the message may be authenticated
Envelope - Class in org.hyperledger.fabric.protos.gossip
Envelope contains a marshalled GossipMessage and a signature over it.
Envelope.Builder - Class in org.hyperledger.fabric.protos.common
Envelope wraps a Payload with a signature so that the message may be authenticated
Envelope.Builder - Class in org.hyperledger.fabric.protos.gossip
Envelope contains a marshalled GossipMessage and a signature over it.
ENVELOPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
EnvelopeOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
EnvelopeOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
EPOCH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ChannelHeader
 
EPOCH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
equals(Object) - Method in class com.google.rpc.Status
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Block
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.BlockData
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Capability
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Config
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Consortium
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Envelope
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Header
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Metadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Payload
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.Policy
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
equals(Object) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Error
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Query
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Request
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.Response
 
equals(Object) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.Member
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
equals(Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
equals(Object) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.DelState
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.GetState
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.PutState
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.Response
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
equals(Object) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
equals(Object) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
Error - Class in org.hyperledger.fabric.protos.discovery
Error denotes that something went wrong and contains the error message
Error.Builder - Class in org.hyperledger.fabric.protos.discovery
Error denotes that something went wrong and contains the error message
ERROR_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.QueryResult
 
ERROR_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
ERROR_RESPONSE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
ERROR_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
ERROR = 7;
ErrorDetail - Class in org.hyperledger.fabric.protos.gateway
If any of the functions in the Gateway service returns an error, then it will be in the format of a google.rpc.Status message.
ErrorDetail.Builder - Class in org.hyperledger.fabric.protos.gateway
If any of the functions in the Gateway service returns an error, then it will be in the format of a google.rpc.Status message.
ErrorDetailOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
ErrorOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
ESCC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
ESCC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
evaluate(EvaluateRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayBlockingStub
The Evaluate service passes a proposed transaction to the gateway in order to invoke the transaction function and return the result to the client.
evaluate(EvaluateRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayFutureStub
The Evaluate service passes a proposed transaction to the gateway in order to invoke the transaction function and return the result to the client.
evaluate(EvaluateRequest, StreamObserver<EvaluateResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayImplBase
The Evaluate service passes a proposed transaction to the gateway in order to invoke the transaction function and return the result to the client.
evaluate(EvaluateRequest, StreamObserver<EvaluateResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayStub
The Evaluate service passes a proposed transaction to the gateway in order to invoke the transaction function and return the result to the client.
EvaluateRequest - Class in org.hyperledger.fabric.protos.gateway
EvaluateRequest contains the details required to evaluate a transaction (query the ledger).
EvaluateRequest.Builder - Class in org.hyperledger.fabric.protos.gateway
EvaluateRequest contains the details required to evaluate a transaction (query the ledger).
EvaluateRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
EvaluateResponse - Class in org.hyperledger.fabric.protos.gateway
EvaluateResponse returns the result of evaluating a transaction.
EvaluateResponse.Builder - Class in org.hyperledger.fabric.protos.gateway
EvaluateResponse returns the result of evaluating a transaction.
EvaluateResponseOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
EVENT_NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
EVENTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
EVENTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
EventsProto - Class in org.hyperledger.fabric.protos.peer
 
EXPIRED_CHAINCODE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
EXPIRED_CHAINCODE = 17;
EXTENSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ChannelHeader
 
EXTENSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Proposal
 
EXTENSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 

F

FABRIC_NODE_OUS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
FabricCryptoConfig - Class in org.hyperledger.fabric.protos.msp
FabricCryptoConfig contains configuration parameters for the cryptographic algorithms used by the MSP this configuration refers to
FabricCryptoConfig.Builder - Class in org.hyperledger.fabric.protos.msp
FabricCryptoConfig contains configuration parameters for the cryptographic algorithms used by the MSP this configuration refers to
FabricCryptoConfigOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
FabricMSPConfig - Class in org.hyperledger.fabric.protos.msp
FabricMSPConfig collects all the configuration information for a Fabric MSP.
FabricMSPConfig.Builder - Class in org.hyperledger.fabric.protos.msp
FabricMSPConfig collects all the configuration information for a Fabric MSP.
FabricMSPConfigOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
FabricNodeOUs - Class in org.hyperledger.fabric.protos.msp
FabricNodeOUs contains configuration to tell apart clients from peers from orderers based on OUs.
FabricNodeOUs.Builder - Class in org.hyperledger.fabric.protos.msp
FabricNodeOUs contains configuration to tell apart clients from peers from orderers based on OUs.
FabricNodeOUsOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
FabricOUIdentifier - Class in org.hyperledger.fabric.protos.msp
FabricOUIdentifier represents an organizational unit and its related chain of trust identifier.
FabricOUIdentifier.Builder - Class in org.hyperledger.fabric.protos.msp
FabricOUIdentifier represents an organizational unit and its related chain of trust identifier.
FabricOUIdentifierOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
FAIL_IF_NOT_READY_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
FAIL_IF_NOT_READY = 1;
FETCHED_RECORDS_COUNT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
FIELDS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
FILTER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
FILTERED_BLOCK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
FILTERED_TRANSACTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
FilteredBlock - Class in org.hyperledger.fabric.protos.peer
FilteredBlock is a minimal set of information about a block
FilteredBlock.Builder - Class in org.hyperledger.fabric.protos.peer
FilteredBlock is a minimal set of information about a block
FilteredBlockOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
FilteredChaincodeAction - Class in org.hyperledger.fabric.protos.peer
FilteredChaincodeAction is a minimal set of information about an action within a transaction
FilteredChaincodeAction.Builder - Class in org.hyperledger.fabric.protos.peer
FilteredChaincodeAction is a minimal set of information about an action within a transaction
FilteredChaincodeActionOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
FilteredTransaction - Class in org.hyperledger.fabric.protos.peer
FilteredTransaction is a minimal set of information about a transaction within a block
FilteredTransaction.Builder - Class in org.hyperledger.fabric.protos.peer
FilteredTransaction is a minimal set of information about a transaction within a block
FilteredTransaction.DataCase - Enum in org.hyperledger.fabric.protos.peer
 
FilteredTransactionActions - Class in org.hyperledger.fabric.protos.peer
FilteredTransactionActions is a wrapper for array of TransactionAction message from regular block
FilteredTransactionActions.Builder - Class in org.hyperledger.fabric.protos.peer
FilteredTransactionActions is a wrapper for array of TransactionAction message from regular block
FilteredTransactionActionsOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
FilteredTransactionOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
FORBIDDEN_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
FORBIDDEN = 403;
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.ApplicationPolicy.TypeCase
Deprecated.
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.CollectionConfig.PayloadCase
Deprecated.
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.CollectionPolicyConfig.PayloadCase
Deprecated.
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.HeaderType
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.SignaturePolicy.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.common.Status
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.discovery.Query.QueryCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.discovery.QueryResult.ResultCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.ContentCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.gossip.Secret.ContentCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.ReadsInfoCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.DeliverResponse.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessage.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekPosition.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.StepRequest.PayloadCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.orderer.StepResponse.PayloadCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.ApplicationPolicy.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.CollectionConfig.PayloadCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.PayloadCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.DeliverResponse.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.FilteredTransaction.DataCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.lifecycle.StateData.TypeCase
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
 
forNumber(int) - Static method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
 

G

GatewayGrpc - Class in org.hyperledger.fabric.protos.gateway
The Gateway API for evaluating and submitting transactions via the gateway.
GatewayGrpc.GatewayBlockingStub - Class in org.hyperledger.fabric.protos.gateway
The Gateway API for evaluating and submitting transactions via the gateway.
GatewayGrpc.GatewayFutureStub - Class in org.hyperledger.fabric.protos.gateway
The Gateway API for evaluating and submitting transactions via the gateway.
GatewayGrpc.GatewayImplBase - Class in org.hyperledger.fabric.protos.gateway
The Gateway API for evaluating and submitting transactions via the gateway.
GatewayGrpc.GatewayStub - Class in org.hyperledger.fabric.protos.gateway
The Gateway API for evaluating and submitting transactions via the gateway.
GatewayImplBase() - Constructor for class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayImplBase
 
GatewayProto - Class in org.hyperledger.fabric.protos.gateway
 
generate(SignedSnapshotRequest) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotBlockingStub
Generate a snapshot reqeust.
generate(SignedSnapshotRequest) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotFutureStub
Generate a snapshot reqeust.
generate(SignedSnapshotRequest, StreamObserver<Empty>) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotImplBase
Generate a snapshot reqeust.
generate(SignedSnapshotRequest, StreamObserver<Empty>) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotStub
Generate a snapshot reqeust.
GET_HISTORY_FOR_KEY_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
GET_HISTORY_FOR_KEY = 19;
GET_PRIVATE_DATA_HASH_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
GET_PRIVATE_DATA_HASH = 22;
GET_QUERY_RESULT_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
GET_QUERY_RESULT = 15;
GET_STATE_BY_RANGE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
GET_STATE_BY_RANGE = 14;
GET_STATE_METADATA_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
GET_STATE_METADATA = 20;
GET_STATE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
GET_STATE = 8;
getAbsoluteMaxBytes() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
The byte count of the serialized messages in a batch cannot exceed this value.
getAbsoluteMaxBytes() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
The byte count of the serialized messages in a batch cannot exceed this value.
getAbsoluteMaxBytes() - Method in interface org.hyperledger.fabric.protos.orderer.BatchSizeOrBuilder
The byte count of the serialized messages in a batch cannot exceed this value.
getAck() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
getAck() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
getAck() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
getAckBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
getAckOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
getAckOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
getAckOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
getAcls() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
Deprecated.
getAcls() - Method in class org.hyperledger.fabric.protos.peer.ACLs
Deprecated.
getAcls() - Method in interface org.hyperledger.fabric.protos.peer.ACLsOrBuilder
Deprecated.
getAclsCount() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
getAclsCount() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
getAclsCount() - Method in interface org.hyperledger.fabric.protos.peer.ACLsOrBuilder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsMap() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsMap() - Method in class org.hyperledger.fabric.protos.peer.ACLs
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsMap() - Method in interface org.hyperledger.fabric.protos.peer.ACLsOrBuilder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsOrDefault(String, APIResource) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsOrDefault(String, APIResource) - Method in class org.hyperledger.fabric.protos.peer.ACLs
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsOrDefault(String, APIResource) - Method in interface org.hyperledger.fabric.protos.peer.ACLsOrBuilder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.ACLs
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAclsOrThrow(String) - Method in interface org.hyperledger.fabric.protos.peer.ACLsOrBuilder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
getAction() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
The list of actions to apply to the ledger
getAction() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
The list of actions to apply to the ledger
getAction() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionPayloadOrBuilder
The list of actions to apply to the ledger
getActionBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
The list of actions to apply to the ledger
getActionOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
The list of actions to apply to the ledger
getActionOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
The list of actions to apply to the ledger
getActionOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionPayloadOrBuilder
The list of actions to apply to the ledger
getActions(int) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
getActions(int) - Method in class org.hyperledger.fabric.protos.peer.Transaction
The payload is an array of TransactionAction.
getActions(int) - Method in interface org.hyperledger.fabric.protos.peer.TransactionOrBuilder
The payload is an array of TransactionAction.
getActionsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
getActionsBuilderList() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
getActionsCount() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
getActionsCount() - Method in class org.hyperledger.fabric.protos.peer.Transaction
The payload is an array of TransactionAction.
getActionsCount() - Method in interface org.hyperledger.fabric.protos.peer.TransactionOrBuilder
The payload is an array of TransactionAction.
getActionsList() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
getActionsList() - Method in class org.hyperledger.fabric.protos.peer.Transaction
The payload is an array of TransactionAction.
getActionsList() - Method in interface org.hyperledger.fabric.protos.peer.TransactionOrBuilder
The payload is an array of TransactionAction.
getActionsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
getActionsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.Transaction
The payload is an array of TransactionAction.
getActionsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.TransactionOrBuilder
The payload is an array of TransactionAction.
getActionsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
getActionsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.Transaction
The payload is an array of TransactionAction.
getActionsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.TransactionOrBuilder
The payload is an array of TransactionAction.
getActiveNodes(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
Indicates active nodes in cluster that are reacheable by Raft leader
getActiveNodes(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
Indicates active nodes in cluster that are reacheable by Raft leader
getActiveNodes(int) - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadataOrBuilder
Indicates active nodes in cluster that are reacheable by Raft leader
getActiveNodesCount() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
Indicates active nodes in cluster that are reacheable by Raft leader
getActiveNodesCount() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
Indicates active nodes in cluster that are reacheable by Raft leader
getActiveNodesCount() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadataOrBuilder
Indicates active nodes in cluster that are reacheable by Raft leader
getActiveNodesList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
Indicates active nodes in cluster that are reacheable by Raft leader
getActiveNodesList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
Indicates active nodes in cluster that are reacheable by Raft leader
getActiveNodesList() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadataOrBuilder
Indicates active nodes in cluster that are reacheable by Raft leader
getAddress() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The address of the endorsing peer or ordering node that returned an error.
getAddress() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
The address of the endorsing peer or ordering node that returned an error.
getAddress() - Method in interface org.hyperledger.fabric.protos.gateway.ErrorDetailOrBuilder
The address of the endorsing peer or ordering node that returned an error.
getAddressBytes() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The address of the endorsing peer or ordering node that returned an error.
getAddressBytes() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
The address of the endorsing peer or ordering node that returned an error.
getAddressBytes() - Method in interface org.hyperledger.fabric.protos.gateway.ErrorDetailOrBuilder
The address of the endorsing peer or ordering node that returned an error.
getAddresses(int) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
getAddresses(int) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
repeated string addresses = 1 [json_name = "addresses"];
getAddresses(int) - Method in interface org.hyperledger.fabric.protos.common.OrdererAddressesOrBuilder
repeated string addresses = 1 [json_name = "addresses"];
getAddressesBytes(int) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
getAddressesBytes(int) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
repeated string addresses = 1 [json_name = "addresses"];
getAddressesBytes(int) - Method in interface org.hyperledger.fabric.protos.common.OrdererAddressesOrBuilder
repeated string addresses = 1 [json_name = "addresses"];
getAddressesCount() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
getAddressesCount() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
repeated string addresses = 1 [json_name = "addresses"];
getAddressesCount() - Method in interface org.hyperledger.fabric.protos.common.OrdererAddressesOrBuilder
repeated string addresses = 1 [json_name = "addresses"];
getAddressesList() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
getAddressesList() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
repeated string addresses = 1 [json_name = "addresses"];
getAddressesList() - Method in interface org.hyperledger.fabric.protos.common.OrdererAddressesOrBuilder
repeated string addresses = 1 [json_name = "addresses"];
getAdminOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the admins
getAdminOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the admins
getAdminOuIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the admins
getAdminOuIdentifierBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the admins
getAdminOuIdentifierOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the admins
getAdminOuIdentifierOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the admins
getAdminOuIdentifierOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the admins
getAdmins(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity denoting the administrator of this MSP
getAdmins(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
Identity denoting the administrator of this MSP
getAdmins(int) - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
Identity denoting the administrator of this MSP
getAdminsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity denoting the administrator of this MSP
getAdminsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
Identity denoting the administrator of this MSP
getAdminsCount() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
Identity denoting the administrator of this MSP
getAdminsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity denoting the administrator of this MSP
getAdminsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
Identity denoting the administrator of this MSP
getAdminsList() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
Identity denoting the administrator of this MSP
getAfterTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Only returns events after this transaction ID.
getAfterTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Only returns events after this transaction ID.
getAfterTransactionId() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Only returns events after this transaction ID.
getAfterTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Only returns events after this transaction ID.
getAfterTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Only returns events after this transaction ID.
getAfterTransactionIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Only returns events after this transaction ID.
getAlive(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAlive(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAlive(int) - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveCount() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveCount() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveCount() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveList() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Membership
getAliveMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Membership
getAliveMsg() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Membership
getAliveMsgBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Membership
getAliveMsgOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Membership
getAliveMsgOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Membership
getAliveMsgOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Membership
getAliveOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAliveOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
getAnchorPeers(int) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeers(int) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeers(int) - Method in interface org.hyperledger.fabric.protos.peer.AnchorPeersOrBuilder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersBuilderList() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersCount() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersCount() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersCount() - Method in interface org.hyperledger.fabric.protos.peer.AnchorPeersOrBuilder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersList() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersList() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersList() - Method in interface org.hyperledger.fabric.protos.peer.AnchorPeersOrBuilder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.AnchorPeersOrBuilder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnchorPeersOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.AnchorPeersOrBuilder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
getAnonymityType() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
getAnonymityType() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
getAnonymityType() - Method in interface org.hyperledger.fabric.protos.common.MSPIdentityAnonymityOrBuilder
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
getAnonymityTypeValue() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
getAnonymityTypeValue() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
getAnonymityTypeValue() - Method in interface org.hyperledger.fabric.protos.common.MSPIdentityAnonymityOrBuilder
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
getApprovals() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
Deprecated.
getApprovals() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
Deprecated.
getApprovals() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResultOrBuilder
Deprecated.
getApprovals() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
Deprecated.
getApprovals() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
Deprecated.
getApprovals() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
Deprecated.
getApprovalsCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
getApprovalsCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
getApprovalsCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResultOrBuilder
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
getApprovalsCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
getApprovalsCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsMap() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsMap() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsMap() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResultOrBuilder
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsMap() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsMap() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsMap() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsOrDefault(String, boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsOrDefault(String, boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsOrDefault(String, boolean) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResultOrBuilder
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsOrDefault(String, boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsOrDefault(String, boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsOrDefault(String, boolean) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsOrThrow(String) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResultOrBuilder
map<string, bool> approvals = 1 [json_name = "approvals"];
getApprovalsOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
map<string, bool> approvals = 8 [json_name = "approvals"];
getApprovalsOrThrow(String) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
map<string, bool> approvals = 8 [json_name = "approvals"];
getArgs(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
repeated bytes args = 1 [json_name = "args"];
getArgs(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
repeated bytes args = 1 [json_name = "args"];
getArgs(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
repeated bytes args = 1 [json_name = "args"];
getArgsCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
repeated bytes args = 1 [json_name = "args"];
getArgsCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
repeated bytes args = 1 [json_name = "args"];
getArgsCount() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
repeated bytes args = 1 [json_name = "args"];
getArgsList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
repeated bytes args = 1 [json_name = "args"];
getArgsList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
repeated bytes args = 1 [json_name = "args"];
getArgsList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
repeated bytes args = 1 [json_name = "args"];
getArgument() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
When 'vscc' a marshaled VSCCArgs
getArgument() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
When 'vscc' a marshaled VSCCArgs
getArgument() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeValidationOrBuilder
When 'vscc' a marshaled VSCCArgs
getAuthentication() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
authentication contains information that the service uses to check the client's eligibility for the queries.
getAuthentication() - Method in class org.hyperledger.fabric.protos.discovery.Request
authentication contains information that the service uses to check the client's eligibility for the queries.
getAuthentication() - Method in interface org.hyperledger.fabric.protos.discovery.RequestOrBuilder
authentication contains information that the service uses to check the client's eligibility for the queries.
getAuthenticationBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
authentication contains information that the service uses to check the client's eligibility for the queries.
getAuthenticationOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
authentication contains information that the service uses to check the client's eligibility for the queries.
getAuthenticationOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Request
authentication contains information that the service uses to check the client's eligibility for the queries.
getAuthenticationOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.RequestOrBuilder
authentication contains information that the service uses to check the client's eligibility for the queries.
getBehavior() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The behavior when a missing block is encountered
getBehavior() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
The behavior when a missing block is encountered
getBehavior() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
The behavior when a missing block is encountered
getBehaviorValue() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The behavior when a missing block is encountered
getBehaviorValue() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
The behavior when a missing block is encountered
getBehaviorValue() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
The behavior when a missing block is encountered
getBlock() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
getBlock() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
.common.Block block = 2 [json_name = "block"];
getBlock() - Method in interface org.hyperledger.fabric.protos.orderer.DeliverResponseOrBuilder
.common.Block block = 2 [json_name = "block"];
getBlock() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
.common.Block block = 1 [json_name = "block"];
getBlock() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
.common.Block block = 1 [json_name = "block"];
getBlock() - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
.common.Block block = 1 [json_name = "block"];
getBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
getBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.common.Block block = 2 [json_name = "block"];
getBlock() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.common.Block block = 2 [json_name = "block"];
getBlockAndPrivateData() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
getBlockAndPrivateData() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
getBlockAndPrivateData() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
getBlockAndPrivateDataBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
getBlockAndPrivateDataOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
getBlockAndPrivateDataOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
getBlockAndPrivateDataOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
getBlockAttestation() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
getBlockAttestation() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
getBlockAttestation() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationResponseOrBuilder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
getBlockAttestationBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
getBlockAttestationOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
getBlockAttestationOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
getBlockAttestationOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationResponseOrBuilder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
getBlockAttestationsMethod() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc
 
getBlockBuilder() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
getBlockBuilder() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
.common.Block block = 1 [json_name = "block"];
getBlockBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
getBlockNum() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
uint64 block_num = 1 [json_name = "blockNum"];
getBlockNum() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
uint64 block_num = 1 [json_name = "blockNum"];
getBlockNum() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.VersionOrBuilder
uint64 block_num = 1 [json_name = "blockNum"];
getBlockNumber() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Block number in which the chaincode events were emitted.
getBlockNumber() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
Block number in which the chaincode events were emitted.
getBlockNumber() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponseOrBuilder
Block number in which the chaincode events were emitted.
getBlockNumber() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
Block number that contains the transaction.
getBlockNumber() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
Block number that contains the transaction.
getBlockNumber() - Method in interface org.hyperledger.fabric.protos.gateway.CommitStatusResponseOrBuilder
Block number that contains the transaction.
getBlockNumber() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
uint64 block_number = 1 [json_name = "blockNumber"];
getBlockNumber() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
uint64 block_number = 1 [json_name = "blockNumber"];
getBlockNumber() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCutOrBuilder
uint64 block_number = 1 [json_name = "blockNumber"];
getBlockNumber() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The block number to generate a snapshot
getBlockNumber() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
The block number to generate a snapshot
getBlockNumber() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotRequestOrBuilder
The block number to generate a snapshot
getBlockNumbers(int) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockNumbers(int) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockNumbers(int) - Method in interface org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponseOrBuilder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockNumbersCount() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockNumbersCount() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockNumbersCount() - Method in interface org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponseOrBuilder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockNumbersList() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockNumbersList() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockNumbersList() - Method in interface org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponseOrBuilder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
getBlockOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
getBlockOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
.common.Block block = 2 [json_name = "block"];
getBlockOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.DeliverResponseOrBuilder
.common.Block block = 2 [json_name = "block"];
getBlockOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
.common.Block block = 1 [json_name = "block"];
getBlockOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
.common.Block block = 1 [json_name = "block"];
getBlockOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
.common.Block block = 1 [json_name = "block"];
getBlockOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
getBlockOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.common.Block block = 2 [json_name = "block"];
getBlockOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.common.Block block = 2 [json_name = "block"];
getBlockSeq() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
uint64 block_seq = 4 [json_name = "blockSeq"];
getBlockSeq() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
uint64 block_seq = 4 [json_name = "blockSeq"];
getBlockSeq() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataDigestOrBuilder
uint64 block_seq = 4 [json_name = "blockSeq"];
getBlockToLive() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The number of blocks after which the collection data expires.
getBlockToLive() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
The number of blocks after which the collection data expires.
getBlockToLive() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
The number of blocks after which the collection data expires.
getBlockToLive() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The number of blocks after which the collection data expires.
getBlockToLive() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
The number of blocks after which the collection data expires.
getBlockToLive() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
The number of blocks after which the collection data expires.
getBookmark() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
getBookmark() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
string bookmark = 2 [json_name = "bookmark"];
getBookmark() - Method in interface org.hyperledger.fabric.protos.peer.QueryMetadataOrBuilder
string bookmark = 2 [json_name = "bookmark"];
getBookmark() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
getBookmark() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
string bookmark = 2 [json_name = "bookmark"];
getBookmark() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseMetadataOrBuilder
string bookmark = 2 [json_name = "bookmark"];
getBookmarkBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
getBookmarkBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
string bookmark = 2 [json_name = "bookmark"];
getBookmarkBytes() - Method in interface org.hyperledger.fabric.protos.peer.QueryMetadataOrBuilder
string bookmark = 2 [json_name = "bookmark"];
getBookmarkBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
getBookmarkBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
string bookmark = 2 [json_name = "bookmark"];
getBookmarkBytes() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseMetadataOrBuilder
string bookmark = 2 [json_name = "bookmark"];
getBootstrappingSnapshotDir() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
getBootstrappingSnapshotDir() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
getBootstrappingSnapshotDir() - Method in interface org.hyperledger.fabric.protos.peer.JoinBySnapshotStatusOrBuilder
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
getBootstrappingSnapshotDirBytes() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
getBootstrappingSnapshotDirBytes() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
getBootstrappingSnapshotDirBytes() - Method in interface org.hyperledger.fabric.protos.peer.JoinBySnapshotStatusOrBuilder
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
getBootstrappingSnapshotInfo() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
getBootstrappingSnapshotInfo() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
getBootstrappingSnapshotInfo() - Method in interface org.hyperledger.fabric.protos.common.BlockchainInfoOrBuilder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
getBootstrappingSnapshotInfoBuilder() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
getBootstrappingSnapshotInfoOrBuilder() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
getBootstrappingSnapshotInfoOrBuilder() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
getBootstrappingSnapshotInfoOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.BlockchainInfoOrBuilder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
getBroadcastMethod() - Static method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc
 
getBrokers(int) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokers(int) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokers(int) - Method in interface org.hyperledger.fabric.protos.orderer.KafkaBrokersOrBuilder
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersBytes(int) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersBytes(int) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersBytes(int) - Method in interface org.hyperledger.fabric.protos.orderer.KafkaBrokersOrBuilder
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersCount() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersCount() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersCount() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaBrokersOrBuilder
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersList() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersList() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
Each broker here should be identified using the (IP|host):port notation, e.g.
getBrokersList() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaBrokersOrBuilder
Each broker here should be identified using the (IP|host):port notation, e.g.
getBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
bytes Bytes = 2 [json_name = "Bytes"];
getBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
bytes Bytes = 2 [json_name = "Bytes"];
getBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateDataOrBuilder
bytes Bytes = 2 [json_name = "Bytes"];
getCancelMethod() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc
 
getCapabilities() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
Deprecated.
getCapabilities() - Method in class org.hyperledger.fabric.protos.common.Capabilities
Deprecated.
getCapabilities() - Method in interface org.hyperledger.fabric.protos.common.CapabilitiesOrBuilder
Deprecated.
getCapabilitiesCount() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
getCapabilitiesCount() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
getCapabilitiesCount() - Method in interface org.hyperledger.fabric.protos.common.CapabilitiesOrBuilder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesMap() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesMap() - Method in class org.hyperledger.fabric.protos.common.Capabilities
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesMap() - Method in interface org.hyperledger.fabric.protos.common.CapabilitiesOrBuilder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesOrDefault(String, Capability) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesOrDefault(String, Capability) - Method in class org.hyperledger.fabric.protos.common.Capabilities
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesOrDefault(String, Capability) - Method in interface org.hyperledger.fabric.protos.common.CapabilitiesOrBuilder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.Capabilities
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCapabilitiesOrThrow(String) - Method in interface org.hyperledger.fabric.protos.common.CapabilitiesOrBuilder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
getCcQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ChaincodeQuery queries for chaincodes by their name and version.
getCcQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query
ChaincodeQuery queries for chaincodes by their name and version.
getCcQuery() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
ChaincodeQuery queries for chaincodes by their name and version.
getCcQueryBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ChaincodeQuery queries for chaincodes by their name and version.
getCcQueryOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ChaincodeQuery queries for chaincodes by their name and version.
getCcQueryOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query
ChaincodeQuery queries for chaincodes by their name and version.
getCcQueryOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
ChaincodeQuery queries for chaincodes by their name and version.
getCcQueryRes() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
getCcQueryRes() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
getCcQueryRes() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
getCcQueryResBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
getCcQueryResOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
getCcQueryResOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
getCcQueryResOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
getCert() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes cert = 2 [json_name = "cert"];
getCert() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
bytes cert = 2 [json_name = "cert"];
getCert() - Method in interface org.hyperledger.fabric.protos.gossip.PeerIdentityOrBuilder
bytes cert = 2 [json_name = "cert"];
getCertificate() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
Certificate represents the second certificate in a certification chain.
getCertificate() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
Certificate represents the second certificate in a certification chain.
getCertificate() - Method in interface org.hyperledger.fabric.protos.msp.FabricOUIdentifierOrBuilder
Certificate represents the second certificate in a certification chain.
getCertifiersIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
CertifiersIdentifier is the hash of certificates chain of trust related to this organizational unit
getCertifiersIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
CertifiersIdentifier is the hash of certificates chain of trust related to this organizational unit
getCertifiersIdentifier() - Method in interface org.hyperledger.fabric.protos.common.OrganizationUnitOrBuilder
CertifiersIdentifier is the hash of certificates chain of trust related to this organizational unit
getChaincode() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
string chaincode = 1 [json_name = "chaincode"];
getChaincode() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
string chaincode = 1 [json_name = "chaincode"];
getChaincode() - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
string chaincode = 1 [json_name = "chaincode"];
getChaincodeActions(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActions(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActions(int) - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionActionsOrBuilder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsBuilderList() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsCount() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsCount() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsCount() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionActionsOrBuilder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsList() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsList() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsList() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionActionsOrBuilder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionActionsOrBuilder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeActionsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionActionsOrBuilder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
getChaincodeBytes() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
string chaincode = 1 [json_name = "chaincode"];
getChaincodeBytes() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
string chaincode = 1 [json_name = "chaincode"];
getChaincodeBytes() - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
string chaincode = 1 [json_name = "chaincode"];
getChaincodeDefinitions(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitions(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitions(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResultOrBuilder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResultOrBuilder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResultOrBuilder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResultOrBuilder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDefinitionsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResultOrBuilder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
getChaincodeDeploymentSpec() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
This is the bytes of the ChaincodeDeploymentSpec
getChaincodeDeploymentSpec() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
This is the bytes of the ChaincodeDeploymentSpec
getChaincodeDeploymentSpec() - Method in interface org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpecOrBuilder
This is the bytes of the ChaincodeDeploymentSpec
getChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
event emitted by chaincode.
getChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
event emitted by chaincode.
getChaincodeEvent() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
event emitted by chaincode.
getChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
getChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
getChaincodeEvent() - Method in interface org.hyperledger.fabric.protos.peer.FilteredChaincodeActionOrBuilder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
getChaincodeEventBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
event emitted by chaincode.
getChaincodeEventBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
getChaincodeEventOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
event emitted by chaincode.
getChaincodeEventOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
event emitted by chaincode.
getChaincodeEventOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
event emitted by chaincode.
getChaincodeEventOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
getChaincodeEventOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
getChaincodeEventOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.FilteredChaincodeActionOrBuilder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
getChaincodeEventsMethod() - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
 
getChaincodeId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Name of the chaincode for which events are requested.
getChaincodeId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Name of the chaincode for which events are requested.
getChaincodeId() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Name of the chaincode for which events are requested.
getChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the ChaincodeID of executing this invocation.
getChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
This field contains the ChaincodeID of executing this invocation.
getChaincodeId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionOrBuilder
This field contains the ChaincodeID of executing this invocation.
getChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string chaincode_id = 1 [json_name = "chaincodeId"];
getChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
string chaincode_id = 1 [json_name = "chaincodeId"];
getChaincodeId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEventOrBuilder
string chaincode_id = 1 [json_name = "chaincodeId"];
getChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
The ID of the chaincode to target.
getChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
The ID of the chaincode to target.
getChaincodeId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtensionOrBuilder
The ID of the chaincode to target.
getChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
getChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
getChaincodeId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
getChaincodeIdBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the ChaincodeID of executing this invocation.
getChaincodeIdBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
The ID of the chaincode to target.
getChaincodeIdBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
getChaincodeIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Name of the chaincode for which events are requested.
getChaincodeIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Name of the chaincode for which events are requested.
getChaincodeIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Name of the chaincode for which events are requested.
getChaincodeIdBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string chaincode_id = 1 [json_name = "chaincodeId"];
getChaincodeIdBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
string chaincode_id = 1 [json_name = "chaincodeId"];
getChaincodeIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEventOrBuilder
string chaincode_id = 1 [json_name = "chaincodeId"];
getChaincodeIdOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the ChaincodeID of executing this invocation.
getChaincodeIdOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
This field contains the ChaincodeID of executing this invocation.
getChaincodeIdOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionOrBuilder
This field contains the ChaincodeID of executing this invocation.
getChaincodeIdOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
The ID of the chaincode to target.
getChaincodeIdOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
The ID of the chaincode to target.
getChaincodeIdOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtensionOrBuilder
The ID of the chaincode to target.
getChaincodeIdOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
getChaincodeIdOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
getChaincodeIdOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
getChaincodeInstallPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
bytes chaincode_install_package = 1 [json_name = "chaincodeInstallPackage"];
getChaincodeInstallPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
bytes chaincode_install_package = 1 [json_name = "chaincodeInstallPackage"];
getChaincodeInstallPackage() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResultOrBuilder
bytes chaincode_install_package = 1 [json_name = "chaincodeInstallPackage"];
getChaincodeInstallPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
This should be a marshaled lifecycle.ChaincodePackage
getChaincodeInstallPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
This should be a marshaled lifecycle.ChaincodePackage
getChaincodeInstallPackage() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgsOrBuilder
This should be a marshaled lifecycle.ChaincodePackage
getChaincodeName() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
string chaincode_name = 1 [json_name = "chaincodeName"];
getChaincodeName() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
string chaincode_name = 1 [json_name = "chaincodeName"];
getChaincodeName() - Method in interface org.hyperledger.fabric.protos.peer.LifecycleEventOrBuilder
string chaincode_name = 1 [json_name = "chaincodeName"];
getChaincodeNameBytes() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
string chaincode_name = 1 [json_name = "chaincodeName"];
getChaincodeNameBytes() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
string chaincode_name = 1 [json_name = "chaincodeName"];
getChaincodeNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.LifecycleEventOrBuilder
string chaincode_name = 1 [json_name = "chaincodeName"];
getChaincodeProposalPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
This field contains the bytes of the ChaincodeProposalPayload message from the original invocation (essentially the arguments) after the application of the visibility function.
getChaincodeProposalPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
This field contains the bytes of the ChaincodeProposalPayload message from the original invocation (essentially the arguments) after the application of the visibility function.
getChaincodeProposalPayload() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionPayloadOrBuilder
This field contains the bytes of the ChaincodeProposalPayload message from the original invocation (essentially the arguments) after the application of the visibility function.
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.gossip.Properties
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodes(int) - Method in interface org.hyperledger.fabric.protos.gossip.PropertiesOrBuilder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInterestOrBuilder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeQueryResponseOrBuilder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodes(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.gossip.Properties
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesCount() - Method in interface org.hyperledger.fabric.protos.gossip.PropertiesOrBuilder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInterestOrBuilder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeQueryResponseOrBuilder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.gossip.Properties
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesList() - Method in interface org.hyperledger.fabric.protos.gossip.PropertiesOrBuilder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInterestOrBuilder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeQueryResponseOrBuilder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.Properties
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gossip.PropertiesOrBuilder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInterestOrBuilder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeQueryResponseOrBuilder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.Properties
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gossip.PropertiesOrBuilder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInterestOrBuilder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeQueryResponseOrBuilder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ReferencesOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
getChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpec() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpecOrBuilder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpec() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpecOrBuilder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpecBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpecBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpecOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpecOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpecOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpecOrBuilder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpecOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpecOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChaincodeSpecOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpecOrBuilder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
getChannel() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
string channel = 1 [json_name = "channel"];
getChannel() - Method in class org.hyperledger.fabric.protos.discovery.Query
string channel = 1 [json_name = "channel"];
getChannel() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
string channel = 1 [json_name = "channel"];
getChannel() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
The channel of the message.
getChannel() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
The channel of the message.
getChannel() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
The channel of the message.
getChannel() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
string channel = 1 [json_name = "channel"];
getChannel() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
string channel = 1 [json_name = "channel"];
getChannel() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusRequestOrBuilder
string channel = 1 [json_name = "channel"];
getChannel() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
string channel = 1 [json_name = "channel"];
getChannel() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
string channel = 1 [json_name = "channel"];
getChannel() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitRequestOrBuilder
string channel = 1 [json_name = "channel"];
getChannel() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
string channel = 1 [json_name = "channel"];
getChannel() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
string channel = 1 [json_name = "channel"];
getChannel() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitResponseOrBuilder
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in class org.hyperledger.fabric.protos.discovery.Query
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusRequestOrBuilder
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitRequestOrBuilder
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
string channel = 1 [json_name = "channel"];
getChannelBytes() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitResponseOrBuilder
string channel = 1 [json_name = "channel"];
getChannelConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config channel_config = 1 [json_name = "channelConfig"];
getChannelConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
.common.Config channel_config = 1 [json_name = "channelConfig"];
getChannelConfig() - Method in interface org.hyperledger.fabric.protos.peer.ConfigTreeOrBuilder
.common.Config channel_config = 1 [json_name = "channelConfig"];
getChannelConfigBuilder() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config channel_config = 1 [json_name = "channelConfig"];
getChannelConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config channel_config = 1 [json_name = "channelConfig"];
getChannelConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
.common.Config channel_config = 1 [json_name = "channelConfig"];
getChannelConfigOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ConfigTreeOrBuilder
.common.Config channel_config = 1 [json_name = "channelConfig"];
getChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReference() - Method in interface org.hyperledger.fabric.protos.common.ApplicationPolicyOrBuilder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReference() - Method in interface org.hyperledger.fabric.protos.peer.ApplicationPolicyOrBuilder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReferenceBytes() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReferenceBytes() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReferenceBytes() - Method in interface org.hyperledger.fabric.protos.common.ApplicationPolicyOrBuilder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReferenceBytes() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReferenceBytes() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelConfigPolicyReferenceBytes() - Method in interface org.hyperledger.fabric.protos.peer.ApplicationPolicyOrBuilder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
getChannelGroup() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
getChannelGroup() - Method in class org.hyperledger.fabric.protos.common.Config
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
getChannelGroup() - Method in interface org.hyperledger.fabric.protos.common.ConfigOrBuilder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
getChannelGroupBuilder() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
getChannelGroupOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
getChannelGroupOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Config
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
getChannelGroupOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.ConfigOrBuilder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
getChannelHeader() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
bytes channel_header = 1 [json_name = "channelHeader"];
getChannelHeader() - Method in class org.hyperledger.fabric.protos.common.Header
bytes channel_header = 1 [json_name = "channelHeader"];
getChannelHeader() - Method in interface org.hyperledger.fabric.protos.common.HeaderOrBuilder
bytes channel_header = 1 [json_name = "channelHeader"];
getChannelId() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Identifier of the channel this message is bound for
getChannelId() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
Identifier of the channel this message is bound for
getChannelId() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
Identifier of the channel this message is bound for
getChannelId() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Which channel this config update is for
getChannelId() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
Which channel this config update is for
getChannelId() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
Which channel this config update is for
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Identifier of the channel this request is bound for.
getChannelId() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
Identifier of the channel this request is bound for.
getChannelId() - Method in interface org.hyperledger.fabric.protos.gateway.CommitStatusRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
Identifier of the channel this request is bound for.
getChannelId() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
Identifier of the channel this request is bound for.
getChannelId() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
Identifier of the channel this request is bound for.
getChannelId() - Method in interface org.hyperledger.fabric.protos.gateway.SubmitRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
channel id
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
channel id
getChannelId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
channel id
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
string channel_id = 1 [json_name = "channelId"];
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
string channel_id = 1 [json_name = "channelId"];
getChannelId() - Method in interface org.hyperledger.fabric.protos.peer.ChannelInfoOrBuilder
string channel_id = 1 [json_name = "channelId"];
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
string channel_id = 1 [json_name = "channelId"];
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
string channel_id = 1 [json_name = "channelId"];
getChannelId() - Method in interface org.hyperledger.fabric.protos.peer.FilteredBlockOrBuilder
string channel_id = 1 [json_name = "channelId"];
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The channel ID
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
The channel ID
getChannelId() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotQueryOrBuilder
The channel ID
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The channel ID
getChannelId() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
The channel ID
getChannelId() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotRequestOrBuilder
The channel ID
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Identifier of the channel this message is bound for
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
Identifier of the channel this message is bound for
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
Identifier of the channel this message is bound for
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Which channel this config update is for
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
Which channel this config update is for
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
Which channel this config update is for
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.CommitStatusRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.SubmitRequestOrBuilder
Identifier of the channel this request is bound for.
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
channel id
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
channel id
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
channel id
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
string channel_id = 1 [json_name = "channelId"];
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
string channel_id = 1 [json_name = "channelId"];
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChannelInfoOrBuilder
string channel_id = 1 [json_name = "channelId"];
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
string channel_id = 1 [json_name = "channelId"];
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
string channel_id = 1 [json_name = "channelId"];
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.FilteredBlockOrBuilder
string channel_id = 1 [json_name = "channelId"];
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The channel ID
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
The channel ID
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotQueryOrBuilder
The channel ID
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The channel ID
getChannelIdBytes() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
The channel ID
getChannelIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotRequestOrBuilder
The channel ID
getChannelMAC() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
getChannelMAC() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
getChannelMAC() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoOrBuilder
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
getChannelMAC() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
getChannelMAC() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
getChannelMAC() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoPullRequestOrBuilder
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
getChannels(int) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannels(int) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannels(int) - Method in interface org.hyperledger.fabric.protos.peer.ChannelQueryResponseOrBuilder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsCount() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsCount() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsCount() - Method in interface org.hyperledger.fabric.protos.peer.ChannelQueryResponseOrBuilder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsList() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsList() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsList() - Method in interface org.hyperledger.fabric.protos.peer.ChannelQueryResponseOrBuilder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.ChannelQueryResponseOrBuilder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getChannelsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.ChannelQueryResponseOrBuilder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
getClass_() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
getClass_() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
getClass_() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageRegularOrBuilder
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
getClass_Value() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
getClass_Value() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
getClass_Value() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageRegularOrBuilder
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
getClientIdentity() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
This is the identity of the client that is used to verify the signature on the SignedRequest's payload.
getClientIdentity() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
This is the identity of the client that is used to verify the signature on the SignedRequest's payload.
getClientIdentity() - Method in interface org.hyperledger.fabric.protos.discovery.AuthInfoOrBuilder
This is the identity of the client that is used to verify the signature on the SignedRequest's payload.
getClientOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the clients
getClientOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the clients
getClientOuIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the clients
getClientOuIdentifierBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the clients
getClientOuIdentifierOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the clients
getClientOuIdentifierOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the clients
getClientOuIdentifierOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the clients
getClientTlsCert() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
bytes client_tls_cert = 3 [json_name = "clientTlsCert"];
getClientTlsCert() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
bytes client_tls_cert = 3 [json_name = "clientTlsCert"];
getClientTlsCert() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConsenterOrBuilder
bytes client_tls_cert = 3 [json_name = "clientTlsCert"];
getClientTlsCertHash() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
This is the hash of the client's TLS cert.
getClientTlsCertHash() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
This is the hash of the client's TLS cert.
getClientTlsCertHash() - Method in interface org.hyperledger.fabric.protos.discovery.AuthInfoOrBuilder
This is the hash of the client's TLS cert.
getCode() - Method in class com.google.rpc.Status.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class com.google.rpc.Status
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in interface com.google.rpc.StatusOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCodePackage() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
bytes code_package = 3 [json_name = "codePackage"];
getCodePackage() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
bytes code_package = 3 [json_name = "codePackage"];
getCodePackage() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpecOrBuilder
bytes code_package = 3 [json_name = "codePackage"];
getCollection() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string collection = 3 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
string collection = 3 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataDigestOrBuilder
string collection = 3 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.DelState
string collection = 2 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.peer.DelStateOrBuilder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
string collection = 2 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.peer.GetQueryResultOrBuilder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.GetState
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string collection = 3 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
string collection = 3 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.peer.GetStateByRangeOrBuilder
string collection = 3 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
string collection = 2 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.peer.GetStateMetadataOrBuilder
string collection = 2 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.peer.GetStateOrBuilder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
string collection = 2 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.peer.PurgePrivateStateOrBuilder
string collection = 2 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string collection = 3 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.PutState
string collection = 3 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string collection = 3 [json_name = "collection"];
getCollection() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
string collection = 3 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.peer.PutStateMetadataOrBuilder
string collection = 3 [json_name = "collection"];
getCollection() - Method in interface org.hyperledger.fabric.protos.peer.PutStateOrBuilder
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataDigestOrBuilder
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.DelState
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.peer.DelStateOrBuilder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetQueryResultOrBuilder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.GetState
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetStateByRangeOrBuilder
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetStateMetadataOrBuilder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetStateOrBuilder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.peer.PurgePrivateStateOrBuilder
string collection = 2 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.PutState
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.peer.PutStateMetadataOrBuilder
string collection = 3 [json_name = "collection"];
getCollectionBytes() - Method in interface org.hyperledger.fabric.protos.peer.PutStateOrBuilder
string collection = 3 [json_name = "collection"];
getCollectionConfigs() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
getCollectionConfigs() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
getCollectionConfigs() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
getCollectionConfigs() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
Deprecated.
getCollectionConfigs() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
Deprecated.
getCollectionConfigs() - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
Deprecated.
getCollectionConfigsBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
getCollectionConfigsCount() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
getCollectionConfigsCount() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
getCollectionConfigsCount() - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsMap() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsMap() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsMap() - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
getCollectionConfigsOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
getCollectionConfigsOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
getCollectionConfigsOrDefault(String, CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsOrDefault(String, CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsOrDefault(String, CollectionConfigPackage) - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsOrThrow(String) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsOrThrow(String) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionConfigsOrThrow(String) - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
getCollectionHashedRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwset(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSetOrBuilder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSetOrBuilder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSetOrBuilder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSetOrBuilder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionHashedRwsetOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSetOrBuilder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
getCollectionName() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string collection_name = 1 [json_name = "collectionName"];
getCollectionName() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
string collection_name = 1 [json_name = "collectionName"];
getCollectionName() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
string collection_name = 1 [json_name = "collectionName"];
getCollectionName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
getCollectionName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
string collection_name = 1 [json_name = "collectionName"];
getCollectionName() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSetOrBuilder
string collection_name = 1 [json_name = "collectionName"];
getCollectionName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
getCollectionName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
string collection_name = 1 [json_name = "collectionName"];
getCollectionName() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSetOrBuilder
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSetOrBuilder
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
string collection_name = 1 [json_name = "collectionName"];
getCollectionNameBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSetOrBuilder
string collection_name = 1 [json_name = "collectionName"];
getCollectionNames(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNames(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNames(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesBytes(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesBytes(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesBytes(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesCount() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionNamesList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
repeated string collection_names = 2 [json_name = "collectionNames"];
getCollectionPvtRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwset(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSetOrBuilder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSetOrBuilder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSetOrBuilder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSetOrBuilder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollectionPvtRwsetOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSetOrBuilder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollectionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollectionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollectionsOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollectionsOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCollectionsOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
getCommitStatusMethod() - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
 
getConfig(int) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfig(int) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfig(int) - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigPackageOrBuilder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfig() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
A marshaled Config structure
getConfig() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
A marshaled Config structure
getConfig() - Method in interface org.hyperledger.fabric.protos.common.ConfigEnvelopeOrBuilder
A marshaled Config structure
getConfig() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
Config is MSP dependent configuration info
getConfig() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
Config is MSP dependent configuration info
getConfig() - Method in interface org.hyperledger.fabric.protos.msp.MSPConfigOrBuilder
Config is MSP dependent configuration info
getConfig(int) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfig(int) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfig(int) - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigPackageOrBuilder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigBuilder(int) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
A marshaled Config structure
getConfigBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigBuilderList() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigBuilderList() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigCount() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigCount() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigCount() - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigPackageOrBuilder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigCount() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigCount() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigCount() - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigPackageOrBuilder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigList() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigList() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigList() - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigPackageOrBuilder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigList() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigList() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigList() - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigPackageOrBuilder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigPackageOrBuilder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
A marshaled Config structure
getConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
A marshaled Config structure
getConfigOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.ConfigEnvelopeOrBuilder
A marshaled Config structure
getConfigOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigPackageOrBuilder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilderList() - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigPackageOrBuilder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigPackageOrBuilder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
getConfigQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
getConfigQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
getConfigQuery() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
getConfigQueryBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
getConfigQueryOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
getConfigQueryOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
getConfigQueryOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
getConfigResult() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
getConfigResult() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
getConfigResult() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
getConfigResultBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
getConfigResultOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
getConfigResultOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
getConfigResultOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
getConfigSeq() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
uint64 config_seq = 2 [json_name = "configSeq"];
getConfigSeq() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
uint64 config_seq = 2 [json_name = "configSeq"];
getConfigSeq() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageRegularOrBuilder
uint64 config_seq = 2 [json_name = "configSeq"];
getConfigUpdate() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
A marshaled ConfigUpdate structure
getConfigUpdate() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
A marshaled ConfigUpdate structure
getConfigUpdate() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateEnvelopeOrBuilder
A marshaled ConfigUpdate structure
getConn() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
ConnEstablish, used for establishing a connection
getConn() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
ConnEstablish, used for establishing a connection
getConn() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
ConnEstablish, used for establishing a connection
getConnBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
ConnEstablish, used for establishing a connection
getConnect() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
getConnect() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
getConnect() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
getConnectBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
getConnectMethod() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc
 
getConnectOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
getConnectOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
getConnectOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
getConnOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
ConnEstablish, used for establishing a connection
getConnOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
ConnEstablish, used for establishing a connection
getConnOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
ConnEstablish, used for establishing a connection
getConsensusRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
consensus_request is a consensus specific message.
getConsensusRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
consensus_request is a consensus specific message.
getConsensusRequest() - Method in interface org.hyperledger.fabric.protos.orderer.StepRequestOrBuilder
consensus_request is a consensus specific message.
getConsensusRequestBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
consensus_request is a consensus specific message.
getConsensusRequestOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
consensus_request is a consensus specific message.
getConsensusRequestOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
consensus_request is a consensus specific message.
getConsensusRequestOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.StepRequestOrBuilder
consensus_request is a consensus specific message.
getConsenterIds(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterIds(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterIds(int) - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadataOrBuilder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterIdsCount() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterIdsCount() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterIdsCount() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadataOrBuilder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterIdsList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterIdsList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterIdsList() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadataOrBuilder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
getConsenterMetadata() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
bytes consenter_metadata = 2 [json_name = "consenterMetadata"];
getConsenterMetadata() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
bytes consenter_metadata = 2 [json_name = "consenterMetadata"];
getConsenterMetadata() - Method in interface org.hyperledger.fabric.protos.common.OrdererBlockMetadataOrBuilder
bytes consenter_metadata = 2 [json_name = "consenterMetadata"];
getConsenters(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsenters(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsenters(int) - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadataOrBuilder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersBuilder(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersBuilderList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersCount() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersCount() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersCount() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadataOrBuilder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersList() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadataOrBuilder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersOrBuilder(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersOrBuilder(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadataOrBuilder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersOrBuilderList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersOrBuilderList() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getConsentersOrBuilderList() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadataOrBuilder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
getContent(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContent(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContent(int) - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryResultOrBuilder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContent() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
string content = 1 [json_name = "content"];
getContent() - Method in class org.hyperledger.fabric.protos.discovery.Error
string content = 1 [json_name = "content"];
getContent() - Method in interface org.hyperledger.fabric.protos.discovery.ErrorOrBuilder
string content = 1 [json_name = "content"];
getContentBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentBytes() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
string content = 1 [json_name = "content"];
getContentBytes() - Method in class org.hyperledger.fabric.protos.discovery.Error
string content = 1 [json_name = "content"];
getContentBytes() - Method in interface org.hyperledger.fabric.protos.discovery.ErrorOrBuilder
string content = 1 [json_name = "content"];
getContentCase() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
getContentCase() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
getContentCase() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
 
getContentCase() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
getContentCase() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
getContentCase() - Method in interface org.hyperledger.fabric.protos.gossip.SecretOrBuilder
 
getContentCount() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentCount() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentCount() - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryResultOrBuilder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentList() - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryResultOrBuilder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryResultOrBuilder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getContentOrBuilderList() - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryResultOrBuilder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
getCreator() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
Creator of the message, a marshaled msp.SerializedIdentity
getCreator() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
Creator of the message, a marshaled msp.SerializedIdentity
getCreator() - Method in interface org.hyperledger.fabric.protos.common.SignatureHeaderOrBuilder
Creator of the message, a marshaled msp.SerializedIdentity
getCred() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
cred represents the serialized idemix credential of the default signer
getCred() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
cred represents the serialized idemix credential of the default signer
getCred() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfigOrBuilder
cred represents the serialized idemix credential of the default signer
getCredentialRevocationInformation() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
credential_revocation_information contains a serialized CredentialRevocationInformation
getCredentialRevocationInformation() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
credential_revocation_information contains a serialized CredentialRevocationInformation
getCredentialRevocationInformation() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfigOrBuilder
credential_revocation_information contains a serialized CredentialRevocationInformation
getCryptoConfig() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
getCryptoConfig() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
getCryptoConfig() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
getCryptoConfigBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
getCryptoConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
getCryptoConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
getCryptoConfigOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
getCurrentBlockHash() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
bytes currentBlockHash = 2 [json_name = "currentBlockHash"];
getCurrentBlockHash() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
bytes currentBlockHash = 2 [json_name = "currentBlockHash"];
getCurrentBlockHash() - Method in interface org.hyperledger.fabric.protos.common.BlockchainInfoOrBuilder
bytes currentBlockHash = 2 [json_name = "currentBlockHash"];
getData() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockData data = 2 [json_name = "data"];
getData() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockData data = 2 [json_name = "data"];
getData(int) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
repeated bytes data = 1 [json_name = "data"];
getData(int) - Method in class org.hyperledger.fabric.protos.common.BlockData
repeated bytes data = 1 [json_name = "data"];
getData(int) - Method in interface org.hyperledger.fabric.protos.common.BlockDataOrBuilder
repeated bytes data = 1 [json_name = "data"];
getData() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockData data = 2 [json_name = "data"];
getData() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Data, the encoding of which is defined by the type in the header
getData() - Method in class org.hyperledger.fabric.protos.common.Payload
Data, the encoding of which is defined by the type in the header
getData() - Method in interface org.hyperledger.fabric.protos.common.PayloadOrBuilder
Data, the encoding of which is defined by the type in the header
getData(int) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getData(int) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
repeated .gossip.Envelope data = 2 [json_name = "data"];
getData(int) - Method in interface org.hyperledger.fabric.protos.gossip.DataUpdateOrBuilder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getData() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
bytes data = 2 [json_name = "data"];
getData() - Method in class org.hyperledger.fabric.protos.gossip.Payload
bytes data = 2 [json_name = "data"];
getData() - Method in interface org.hyperledger.fabric.protos.gossip.PayloadOrBuilder
bytes data = 2 [json_name = "data"];
getData() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Data data specific to the package
getData() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Data data specific to the package
getData() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Data data specific to the package
getDataBuilder() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockData data = 2 [json_name = "data"];
getDataBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataCase() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
getDataCase() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
getDataCase() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
 
getDataCount() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
repeated bytes data = 1 [json_name = "data"];
getDataCount() - Method in class org.hyperledger.fabric.protos.common.BlockData
repeated bytes data = 1 [json_name = "data"];
getDataCount() - Method in interface org.hyperledger.fabric.protos.common.BlockDataOrBuilder
repeated bytes data = 1 [json_name = "data"];
getDataCount() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataCount() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataCount() - Method in interface org.hyperledger.fabric.protos.gossip.DataUpdateOrBuilder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataDig() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
getDataDig() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
getDataDig() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
getDataDigBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
getDataDigOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
getDataDigOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
getDataDigOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
getDataHash() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The hash of the BlockData, by MerkleTree
getDataHash() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
The hash of the BlockData, by MerkleTree
getDataHash() - Method in interface org.hyperledger.fabric.protos.common.BlockHeaderOrBuilder
The hash of the BlockData, by MerkleTree
getDataList() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
repeated bytes data = 1 [json_name = "data"];
getDataList() - Method in class org.hyperledger.fabric.protos.common.BlockData
repeated bytes data = 1 [json_name = "data"];
getDataList() - Method in interface org.hyperledger.fabric.protos.common.BlockDataOrBuilder
repeated bytes data = 1 [json_name = "data"];
getDataList() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataList() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataList() - Method in interface org.hyperledger.fabric.protos.gossip.DataUpdateOrBuilder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataModel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModel() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSetOrBuilder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModel() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSetOrBuilder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModelValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModelValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModelValue() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSetOrBuilder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModelValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModelValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataModelValue() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSetOrBuilder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
getDataMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Contains a ledger block
getDataMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Contains a ledger block
getDataMsg() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Contains a ledger block
getDataMsgBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Contains a ledger block
getDataMsgOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Contains a ledger block
getDataMsgOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Contains a ledger block
getDataMsgOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Contains a ledger block
getDataOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockData data = 2 [json_name = "data"];
getDataOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockData data = 2 [json_name = "data"];
getDataOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockData data = 2 [json_name = "data"];
getDataOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gossip.DataUpdateOrBuilder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gossip.DataUpdateOrBuilder
repeated .gossip.Envelope data = 2 [json_name = "data"];
getDataReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
getDataReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
getDataReq() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
getDataReqBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
getDataReqOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
getDataReqOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
getDataReqOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
getDatatype() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
string datatype = 1 [json_name = "datatype"];
getDatatype() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
string datatype = 1 [json_name = "datatype"];
getDatatype() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateMetadataOrBuilder
string datatype = 1 [json_name = "datatype"];
getDatatypeBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
string datatype = 1 [json_name = "datatype"];
getDatatypeBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
string datatype = 1 [json_name = "datatype"];
getDatatypeBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateMetadataOrBuilder
string datatype = 1 [json_name = "datatype"];
getDataUpdate() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
getDataUpdate() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
getDataUpdate() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
getDataUpdateBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
getDataUpdateOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
getDataUpdateOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
getDataUpdateOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
getDead(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDead(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDead(int) - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadCount() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadCount() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadCount() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadList() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDeadOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipResponseOrBuilder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
getDecorations() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
Deprecated.
getDecorations() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
Deprecated.
getDecorations() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
Deprecated.
getDecorationsCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
getDecorationsCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
getDecorationsCount() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsMap() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsMap() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsMap() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsOrDefault(String, ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsOrDefault(String, ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsOrDefault(String, ByteString) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDecorationsOrThrow(String) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
map<string, bytes> decorations = 2 [json_name = "decorations"];
getDefaultInstance() - Static method in class com.google.rpc.Status
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Block
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Capability
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Config
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Header
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Payload
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.Policy
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.Response
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
getDefaultInstance() - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
getDefaultInstanceForType() - Method in class com.google.rpc.Status.Builder
 
getDefaultInstanceForType() - Method in class com.google.rpc.Status
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Block
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockData
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Capability
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Config
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Consortium
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Envelope
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Header
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Metadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Payload
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.Policy
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Error
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Request
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.Response
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Member
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.DelState
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetState
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.PutState
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.Response
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
getDefaultInstanceForType() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
getDeliverFilteredMethod() - Static method in class org.hyperledger.fabric.protos.peer.DeliverGrpc
 
getDeliverMethod() - Static method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc
 
getDeliverMethod() - Static method in class org.hyperledger.fabric.protos.peer.DeliverGrpc
 
getDeliverWithPrivateDataMethod() - Static method in class org.hyperledger.fabric.protos.peer.DeliverGrpc
 
getDescriptor() - Static method in class com.google.rpc.Status.Builder
 
getDescriptor() - Static method in class com.google.rpc.Status
 
getDescriptor() - Static method in class com.google.rpc.StatusProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Block.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Block
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Capability
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CollectionProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.CommonProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Config.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Config
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigTxProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigurationProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Header.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Header
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.common.HeaderType
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.LedgerProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipalProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Payload
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.PoliciesProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.Policy
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.common.Status
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.ProtocolProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.GatewayProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.MessageProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KVQueryResultProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.RWSetProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.IdentitiesProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.MSPConfigProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.AbProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BlockattestationProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ClusterProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ConfigurationProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigurationProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.MetadataProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEventProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeShimProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.CollectionProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ConfigurationProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.EventsProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeDefinitionProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.DbProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.LifecycleProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.PeerProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.PolicyProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ProposalProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponseProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ResourcesProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.Response
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SignedCcDepSpecProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.TransactionProto
 
getDescriptor() - Static method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.transientstore.TransientstoreProto
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
getDescriptor() - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
getDescriptorForType() - Method in class com.google.rpc.Status.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.common.HeaderType
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.common.Status
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
getDescriptorForType() - Method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
getDescriptorForType() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
getDetails(int) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
getDetails(int) - Method in class com.google.rpc.Status
A list of messages that carry the error details.
getDetails(int) - Method in interface com.google.rpc.StatusOrBuilder
A list of messages that carry the error details.
getDetailsBuilder(int) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
getDetailsBuilderList() - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
getDetailsCount() - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
getDetailsCount() - Method in class com.google.rpc.Status
A list of messages that carry the error details.
getDetailsCount() - Method in interface com.google.rpc.StatusOrBuilder
A list of messages that carry the error details.
getDetailsList() - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
getDetailsList() - Method in class com.google.rpc.Status
A list of messages that carry the error details.
getDetailsList() - Method in interface com.google.rpc.StatusOrBuilder
A list of messages that carry the error details.
getDetailsOrBuilder(int) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
getDetailsOrBuilder(int) - Method in class com.google.rpc.Status
A list of messages that carry the error details.
getDetailsOrBuilder(int) - Method in interface com.google.rpc.StatusOrBuilder
A list of messages that carry the error details.
getDetailsOrBuilderList() - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
getDetailsOrBuilderList() - Method in class com.google.rpc.Status
A list of messages that carry the error details.
getDetailsOrBuilderList() - Method in interface com.google.rpc.StatusOrBuilder
A list of messages that carry the error details.
getDigest() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
getDigest() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
getDigest() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataElementOrBuilder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
getDigestBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
getDigestOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
getDigestOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
getDigestOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataElementOrBuilder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
getDigests(int) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
Maybe change this to bitmap later on
getDigests(int) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
Maybe change this to bitmap later on
getDigests(int) - Method in interface org.hyperledger.fabric.protos.gossip.DataDigestOrBuilder
Maybe change this to bitmap later on
getDigests(int) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
repeated bytes digests = 2 [json_name = "digests"];
getDigests(int) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
repeated bytes digests = 2 [json_name = "digests"];
getDigests(int) - Method in interface org.hyperledger.fabric.protos.gossip.DataRequestOrBuilder
repeated bytes digests = 2 [json_name = "digests"];
getDigests(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigests(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigests(int) - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataRequestOrBuilder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsCount() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
Maybe change this to bitmap later on
getDigestsCount() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
Maybe change this to bitmap later on
getDigestsCount() - Method in interface org.hyperledger.fabric.protos.gossip.DataDigestOrBuilder
Maybe change this to bitmap later on
getDigestsCount() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
repeated bytes digests = 2 [json_name = "digests"];
getDigestsCount() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
repeated bytes digests = 2 [json_name = "digests"];
getDigestsCount() - Method in interface org.hyperledger.fabric.protos.gossip.DataRequestOrBuilder
repeated bytes digests = 2 [json_name = "digests"];
getDigestsCount() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsCount() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsCount() - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataRequestOrBuilder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsList() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
Maybe change this to bitmap later on
getDigestsList() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
Maybe change this to bitmap later on
getDigestsList() - Method in interface org.hyperledger.fabric.protos.gossip.DataDigestOrBuilder
Maybe change this to bitmap later on
getDigestsList() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
repeated bytes digests = 2 [json_name = "digests"];
getDigestsList() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
repeated bytes digests = 2 [json_name = "digests"];
getDigestsList() - Method in interface org.hyperledger.fabric.protos.gossip.DataRequestOrBuilder
repeated bytes digests = 2 [json_name = "digests"];
getDigestsList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsList() - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataRequestOrBuilder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataRequestOrBuilder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDigestsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataRequestOrBuilder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
getDiscoverMethod() - Static method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc
 
getDisregardNamespacePolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we wish to ignore the namespace endorsement policy
getDisregardNamespacePolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
Indicates we wish to ignore the namespace endorsement policy
getDisregardNamespacePolicy() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
Indicates we wish to ignore the namespace endorsement policy
getElectionTick() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 election_tick = 2 [json_name = "electionTick"];
getElectionTick() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
uint32 election_tick = 2 [json_name = "electionTick"];
getElectionTick() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.OptionsOrBuilder
uint32 election_tick = 2 [json_name = "electionTick"];
getElements(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElements(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElements(int) - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataResponseOrBuilder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElements(int) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElements(int) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElements(int) - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoSnapshotOrBuilder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsCount() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsCount() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsCount() - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataResponseOrBuilder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsCount() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsCount() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsCount() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoSnapshotOrBuilder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsList() - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataResponseOrBuilder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsList() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsList() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsList() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoSnapshotOrBuilder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataResponseOrBuilder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoSnapshotOrBuilder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gossip.RemotePvtDataResponseOrBuilder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
getElementsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getElementsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoSnapshotOrBuilder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
getEmpty() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Empty message, used for pinging
getEmpty() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Empty message, used for pinging
getEmpty() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Empty message, used for pinging
getEmptyBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Empty message, used for pinging
getEmptyOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Empty message, used for pinging
getEmptyOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Empty message, used for pinging
getEmptyOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Empty message, used for pinging
getEnable() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
If true then an msp identity that does not contain any of the specified OU will be considered invalid.
getEnable() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
If true then an msp identity that does not contain any of the specified OU will be considered invalid.
getEnable() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
If true then an msp identity that does not contain any of the specified OU will be considered invalid.
getEndKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string end_key = 2 [json_name = "endKey"];
getEndKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
string end_key = 2 [json_name = "endKey"];
getEndKey() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
string end_key = 2 [json_name = "endKey"];
getEndKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string endKey = 2 [json_name = "endKey"];
getEndKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
string endKey = 2 [json_name = "endKey"];
getEndKey() - Method in interface org.hyperledger.fabric.protos.peer.GetStateByRangeOrBuilder
string endKey = 2 [json_name = "endKey"];
getEndKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string end_key = 2 [json_name = "endKey"];
getEndKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
string end_key = 2 [json_name = "endKey"];
getEndKeyBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
string end_key = 2 [json_name = "endKey"];
getEndKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string endKey = 2 [json_name = "endKey"];
getEndKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
string endKey = 2 [json_name = "endKey"];
getEndKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetStateByRangeOrBuilder
string endKey = 2 [json_name = "endKey"];
getEndorsedAt() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
uint64 endorsed_at = 1 [json_name = "endorsedAt"];
getEndorsedAt() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
uint64 endorsed_at = 1 [json_name = "endorsedAt"];
getEndorsedAt() - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
uint64 endorsed_at = 1 [json_name = "endorsedAt"];
getEndorsement() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The endorsement of the proposal, basically the endorser's signature over the payload
getEndorsement() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
The endorsement of the proposal, basically the endorser's signature over the payload
getEndorsement() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
The endorsement of the proposal, basically the endorser's signature over the payload
getEndorsementBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The endorsement of the proposal, basically the endorser's signature over the payload
getEndorsementOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The endorsement of the proposal, basically the endorser's signature over the payload
getEndorsementOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
The endorsement of the proposal, basically the endorser's signature over the payload
getEndorsementOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
The endorsement of the proposal, basically the endorser's signature over the payload
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfoOrBuilder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfoOrBuilder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
getEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicy() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicy() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyBuilder() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyBuilder() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
getEndorsementPolicyRef() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
A named reference to an endorsement policy,
getEndorsementPolicyRef() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
A named reference to an endorsement policy,
getEndorsementPolicyRef() - Method in interface org.hyperledger.fabric.protos.peer.VSCCArgsOrBuilder
A named reference to an endorsement policy,
getEndorsementPolicyRefBytes() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
A named reference to an endorsement policy,
getEndorsementPolicyRefBytes() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
A named reference to an endorsement policy,
getEndorsementPolicyRefBytes() - Method in interface org.hyperledger.fabric.protos.peer.VSCCArgsOrBuilder
A named reference to an endorsement policy,
getEndorsements(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsements(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsements(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEndorsedActionOrBuilder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsCount() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEndorsedActionOrBuilder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEndorsedActionOrBuilder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEndorsedActionOrBuilder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorsementsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEndorsedActionOrBuilder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
getEndorseMethod() - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
 
getEndorser() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
Identity of the endorser (e.g.
getEndorser() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
Identity of the endorser (e.g.
getEndorser() - Method in interface org.hyperledger.fabric.protos.peer.EndorsementOrBuilder
Identity of the endorser (e.g.
getEndorsersByGroups() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Deprecated.
getEndorsersByGroups() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Deprecated.
getEndorsersByGroups() - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Deprecated.
getEndorsersByGroupsCount() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
getEndorsersByGroupsCount() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
getEndorsersByGroupsCount() - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies the endorsers, separated to groups.
getEndorsersByGroupsMap() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies the endorsers, separated to groups.
getEndorsersByGroupsMap() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies the endorsers, separated to groups.
getEndorsersByGroupsMap() - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies the endorsers, separated to groups.
getEndorsersByGroupsOrDefault(String, Peers) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies the endorsers, separated to groups.
getEndorsersByGroupsOrDefault(String, Peers) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies the endorsers, separated to groups.
getEndorsersByGroupsOrDefault(String, Peers) - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies the endorsers, separated to groups.
getEndorsersByGroupsOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies the endorsers, separated to groups.
getEndorsersByGroupsOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies the endorsers, separated to groups.
getEndorsersByGroupsOrThrow(String) - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies the endorsers, separated to groups.
getEndorsingOrganizations(int) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizations(int) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizations(int) - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizations(int) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
getEndorsingOrganizations(int) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
The list of endorsing organizations.
getEndorsingOrganizations(int) - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
The list of endorsing organizations.
getEndorsingOrganizationsBytes(int) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsBytes(int) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsBytes(int) - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsBytes(int) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
getEndorsingOrganizationsBytes(int) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
The list of endorsing organizations.
getEndorsingOrganizationsBytes(int) - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
The list of endorsing organizations.
getEndorsingOrganizationsCount() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsCount() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsCount() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsCount() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
getEndorsingOrganizationsCount() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
The list of endorsing organizations.
getEndorsingOrganizationsCount() - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
The list of endorsing organizations.
getEndorsingOrganizationsList() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsList() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsList() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
If targeting the peers of specific organizations (e.g.
getEndorsingOrganizationsList() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
getEndorsingOrganizationsList() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
The list of endorsing organizations.
getEndorsingOrganizationsList() - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
The list of endorsing organizations.
getEndpoint(int) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpoint(int) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpoint(int) - Method in interface org.hyperledger.fabric.protos.discovery.EndpointsOrBuilder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpoint() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
string endpoint = 1 [json_name = "endpoint"];
getEndpoint() - Method in class org.hyperledger.fabric.protos.gossip.Member
string endpoint = 1 [json_name = "endpoint"];
getEndpoint() - Method in interface org.hyperledger.fabric.protos.gossip.MemberOrBuilder
string endpoint = 1 [json_name = "endpoint"];
getEndpointBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointBytes() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
string endpoint = 1 [json_name = "endpoint"];
getEndpointBytes() - Method in class org.hyperledger.fabric.protos.gossip.Member
string endpoint = 1 [json_name = "endpoint"];
getEndpointBytes() - Method in interface org.hyperledger.fabric.protos.gossip.MemberOrBuilder
string endpoint = 1 [json_name = "endpoint"];
getEndpointCount() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointCount() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointCount() - Method in interface org.hyperledger.fabric.protos.discovery.EndpointsOrBuilder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointList() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointList() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointList() - Method in interface org.hyperledger.fabric.protos.discovery.EndpointsOrBuilder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.discovery.EndpointsOrBuilder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndpointOrBuilderList() - Method in interface org.hyperledger.fabric.protos.discovery.EndpointsOrBuilder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
getEndSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
uint64 end_seq_num = 2 [json_name = "endSeqNum"];
getEndSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
uint64 end_seq_num = 2 [json_name = "endSeqNum"];
getEndSeqNum() - Method in interface org.hyperledger.fabric.protos.gossip.RemoteStateRequestOrBuilder
uint64 end_seq_num = 2 [json_name = "endSeqNum"];
getEnrollmentId() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
enrollment_id contains the enrollment id of this signer
getEnrollmentId() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
enrollment_id contains the enrollment id of this signer
getEnrollmentId() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfigOrBuilder
enrollment_id contains the enrollment id of this signer
getEnrollmentIdBytes() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
enrollment_id contains the enrollment id of this signer
getEnrollmentIdBytes() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
enrollment_id contains the enrollment id of this signer
getEnrollmentIdBytes() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfigOrBuilder
enrollment_id contains the enrollment id of this signer
getEntries(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntries(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntries(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntries(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntries(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHashOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntries(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntries(int) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntries(int) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntries(int) - Method in interface org.hyperledger.fabric.protos.peer.StateMetadataResultOrBuilder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesBuilderList() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHashOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesCount() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesCount() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesCount() - Method in interface org.hyperledger.fabric.protos.peer.StateMetadataResultOrBuilder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHashOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesList() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesList() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesList() - Method in interface org.hyperledger.fabric.protos.peer.StateMetadataResultOrBuilder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHashOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.StateMetadataResultOrBuilder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHashOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteOrBuilder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
getEntriesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEntriesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.StateMetadataResultOrBuilder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
getEnvelope() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
The transaction envelope.
getEnvelope() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
The transaction envelope.
getEnvelope() - Method in interface org.hyperledger.fabric.protos.gateway.PreparedTransactionOrBuilder
The transaction envelope.
getEnvelopeBuilder() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
The transaction envelope.
getEnvelopeOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
The transaction envelope.
getEnvelopeOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
The transaction envelope.
getEnvelopeOrBuilder() - Method in interface org.hyperledger.fabric.protos.gateway.PreparedTransactionOrBuilder
The transaction envelope.
getEpoch() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
The epoch in which this header was generated, where epoch is defined based on block height Epoch in which the response has been generated.
getEpoch() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
The epoch in which this header was generated, where epoch is defined based on block height Epoch in which the response has been generated.
getEpoch() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
The epoch in which this header was generated, where epoch is defined based on block height Epoch in which the response has been generated.
getEpoch() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
epoch represents the current epoch (time interval) used for revocation
getEpoch() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
epoch represents the current epoch (time interval) used for revocation
getEpoch() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPConfigOrBuilder
epoch represents the current epoch (time interval) used for revocation
getError() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
Error indicates failure or refusal to process the query
getError() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
Error indicates failure or refusal to process the query
getError() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
Error indicates failure or refusal to process the query
getError() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
string error = 1 [json_name = "error"];
getError() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
string error = 1 [json_name = "error"];
getError() - Method in interface org.hyperledger.fabric.protos.gossip.AcknowledgementOrBuilder
string error = 1 [json_name = "error"];
getErrorBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
Error indicates failure or refusal to process the query
getErrorBytes() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
string error = 1 [json_name = "error"];
getErrorBytes() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
string error = 1 [json_name = "error"];
getErrorBytes() - Method in interface org.hyperledger.fabric.protos.gossip.AcknowledgementOrBuilder
string error = 1 [json_name = "error"];
getErrorOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
Error indicates failure or refusal to process the query
getErrorOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
Error indicates failure or refusal to process the query
getErrorOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
Error indicates failure or refusal to process the query
getErrorResponse() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
How to respond to errors reported to the deliver service
getErrorResponse() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
How to respond to errors reported to the deliver service
getErrorResponse() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
How to respond to errors reported to the deliver service
getErrorResponseValue() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
How to respond to errors reported to the deliver service
getErrorResponseValue() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
How to respond to errors reported to the deliver service
getErrorResponseValue() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
How to respond to errors reported to the deliver service
getEscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Escc for the chaincode instance
getEscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Escc for the chaincode instance
getEscc() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Escc for the chaincode instance
getEscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the ESCC for this chaincode.
getEscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the name of the ESCC for this chaincode.
getEscc() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the name of the ESCC for this chaincode.
getEsccBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Escc for the chaincode instance
getEsccBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Escc for the chaincode instance
getEsccBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Escc for the chaincode instance
getEsccBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the ESCC for this chaincode.
getEsccBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the name of the ESCC for this chaincode.
getEsccBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the name of the ESCC for this chaincode.
getEvaluateMethod() - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
 
getEventName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string event_name = 3 [json_name = "eventName"];
getEventName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
string event_name = 3 [json_name = "eventName"];
getEventName() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEventOrBuilder
string event_name = 3 [json_name = "eventName"];
getEventNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string event_name = 3 [json_name = "eventName"];
getEventNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
string event_name = 3 [json_name = "eventName"];
getEventNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEventOrBuilder
string event_name = 3 [json_name = "eventName"];
getEvents(int) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
getEvents(int) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
Chaincode events emitted by the requested chaincode.
getEvents(int) - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponseOrBuilder
Chaincode events emitted by the requested chaincode.
getEvents() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the event generated by the chaincode.
getEvents() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
This field contains the event generated by the chaincode.
getEvents() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionOrBuilder
This field contains the event generated by the chaincode.
getEventsBuilder(int) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
getEventsBuilderList() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
getEventsCount() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
getEventsCount() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
Chaincode events emitted by the requested chaincode.
getEventsCount() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponseOrBuilder
Chaincode events emitted by the requested chaincode.
getEventsList() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
getEventsList() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
Chaincode events emitted by the requested chaincode.
getEventsList() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponseOrBuilder
Chaincode events emitted by the requested chaincode.
getEventsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
getEventsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
Chaincode events emitted by the requested chaincode.
getEventsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponseOrBuilder
Chaincode events emitted by the requested chaincode.
getEventsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
getEventsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
Chaincode events emitted by the requested chaincode.
getEventsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponseOrBuilder
Chaincode events emitted by the requested chaincode.
getExtension() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Extension that may be attached based on the header type
getExtension() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
Extension that may be attached based on the header type
getExtension() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
Extension that may be attached based on the header type
getExtension() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
Optional extensions to the proposal.
getExtension() - Method in class org.hyperledger.fabric.protos.peer.Proposal
Optional extensions to the proposal.
getExtension() - Method in interface org.hyperledger.fabric.protos.peer.ProposalOrBuilder
Optional extensions to the proposal.
getExtension() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
Extension should be unmarshaled to a type-specific message.
getExtension() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
Extension should be unmarshaled to a type-specific message.
getExtension() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponsePayloadOrBuilder
Extension should be unmarshaled to a type-specific message.
getFabricNodeOus() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
getFabricNodeOus() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
getFabricNodeOus() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
getFabricNodeOusBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
getFabricNodeOusOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
getFabricNodeOusOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
getFabricNodeOusOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
getFetchedRecordsCount() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
int32 fetched_records_count = 1 [json_name = "fetchedRecordsCount"];
getFetchedRecordsCount() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
int32 fetched_records_count = 1 [json_name = "fetchedRecordsCount"];
getFetchedRecordsCount() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseMetadataOrBuilder
int32 fetched_records_count = 1 [json_name = "fetchedRecordsCount"];
getFields(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
getFields(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
repeated string fields = 2 [json_name = "fields"];
getFields(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateMetadataOrBuilder
repeated string fields = 2 [json_name = "fields"];
getFieldsBytes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
getFieldsBytes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
repeated string fields = 2 [json_name = "fields"];
getFieldsBytes(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateMetadataOrBuilder
repeated string fields = 2 [json_name = "fields"];
getFieldsCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
getFieldsCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
repeated string fields = 2 [json_name = "fields"];
getFieldsCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateMetadataOrBuilder
repeated string fields = 2 [json_name = "fields"];
getFieldsList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
getFieldsList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
repeated string fields = 2 [json_name = "fields"];
getFieldsList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateMetadataOrBuilder
repeated string fields = 2 [json_name = "fields"];
getFilter() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
getFilter() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
getFilter() - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipQueryOrBuilder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
getFilterBuilder() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
getFilteredBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
getFilteredBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
getFilteredBlock() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
getFilteredBlockBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
getFilteredBlockOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
getFilteredBlockOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
getFilteredBlockOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
getFilteredTransactions(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactions(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactions(int) - Method in interface org.hyperledger.fabric.protos.peer.FilteredBlockOrBuilder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsBuilderList() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsCount() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsCount() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsCount() - Method in interface org.hyperledger.fabric.protos.peer.FilteredBlockOrBuilder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsList() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsList() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsList() - Method in interface org.hyperledger.fabric.protos.peer.FilteredBlockOrBuilder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.FilteredBlockOrBuilder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilteredTransactionsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.FilteredBlockOrBuilder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
getFilterOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
getFilterOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
getFilterOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipQueryOrBuilder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
getGenerateMethod() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc
 
getGossipStreamMethod() - Static method in class org.hyperledger.fabric.protos.gossip.GossipGrpc
 
getGroups() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
Deprecated.
getGroups() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
Deprecated.
getGroups() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
Deprecated.
getGroupsCount() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
getGroupsCount() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getGroupsCount() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsMap() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsMap() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsMap() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsOrDefault(String, ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsOrDefault(String, ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsOrDefault(String, ConfigGroup) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getGroupsOrThrow(String) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
getHash() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
hash of ChaincodeDeploymentSpec.code_package
getHash() - Method in class org.hyperledger.fabric.protos.peer.CDSData
hash of ChaincodeDeploymentSpec.code_package
getHash() - Method in interface org.hyperledger.fabric.protos.peer.CDSDataOrBuilder
hash of ChaincodeDeploymentSpec.code_package
getHash() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
The hash of the chaincode bytes
getHash() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
The hash of the chaincode bytes
getHash() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIdentifierOrBuilder
The hash of the chaincode bytes
getHashedReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReads(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedReadsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
getHashedRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.HashedRWSet for KV and Document data models)
getHashedRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
Data model specific serialized proto message (e.g., kvrwset.HashedRWSet for KV and Document data models)
getHashedRwset() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSetOrBuilder
Data model specific serialized proto message (e.g., kvrwset.HashedRWSet for KV and Document data models)
getHashedWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWrites(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHashedWritesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
getHasMore() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
bool has_more = 2 [json_name = "hasMore"];
getHasMore() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
bool has_more = 2 [json_name = "hasMore"];
getHasMore() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
bool has_more = 2 [json_name = "hasMore"];
getHeader() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockHeader header = 1 [json_name = "header"];
getHeader() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockHeader header = 1 [json_name = "header"];
getHeader() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockHeader header = 1 [json_name = "header"];
getHeader() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Header is included to provide identity and prevent replay
getHeader() - Method in class org.hyperledger.fabric.protos.common.Payload
Header is included to provide identity and prevent replay
getHeader() - Method in interface org.hyperledger.fabric.protos.common.PayloadOrBuilder
Header is included to provide identity and prevent replay
getHeader() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockHeader header = 1 [json_name = "header"];
getHeader() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
.common.BlockHeader header = 1 [json_name = "header"];
getHeader() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationOrBuilder
.common.BlockHeader header = 1 [json_name = "header"];
getHeader() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
The header of the proposal.
getHeader() - Method in class org.hyperledger.fabric.protos.peer.Proposal
The header of the proposal.
getHeader() - Method in interface org.hyperledger.fabric.protos.peer.ProposalOrBuilder
The header of the proposal.
getHeader() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
The header of the proposal action, which is the proposal header
getHeader() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
The header of the proposal action, which is the proposal header
getHeader() - Method in interface org.hyperledger.fabric.protos.peer.TransactionActionOrBuilder
The header of the proposal action, which is the proposal header
getHeaderBuilder() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockHeader header = 1 [json_name = "header"];
getHeaderBuilder() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Header is included to provide identity and prevent replay
getHeaderBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockHeader header = 1 [json_name = "header"];
getHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockHeader header = 1 [json_name = "header"];
getHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockHeader header = 1 [json_name = "header"];
getHeaderOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockHeader header = 1 [json_name = "header"];
getHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Header is included to provide identity and prevent replay
getHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Payload
Header is included to provide identity and prevent replay
getHeaderOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.PayloadOrBuilder
Header is included to provide identity and prevent replay
getHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockHeader header = 1 [json_name = "header"];
getHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
.common.BlockHeader header = 1 [json_name = "header"];
getHeaderOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationOrBuilder
.common.BlockHeader header = 1 [json_name = "header"];
getHeartbeatTick() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 heartbeat_tick = 3 [json_name = "heartbeatTick"];
getHeartbeatTick() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
uint32 heartbeat_tick = 3 [json_name = "heartbeatTick"];
getHeartbeatTick() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.OptionsOrBuilder
uint32 heartbeat_tick = 3 [json_name = "heartbeatTick"];
getHeight() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
uint64 height = 1 [json_name = "height"];
getHeight() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
uint64 height = 1 [json_name = "height"];
getHeight() - Method in interface org.hyperledger.fabric.protos.common.BlockchainInfoOrBuilder
uint64 height = 1 [json_name = "height"];
getHello() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for push&pull
getHello() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for push&pull
getHello() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for push&pull
getHelloBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for push&pull
getHelloOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for push&pull
getHelloOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for push&pull
getHelloOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for push&pull
GetHistoryForKey - Class in org.hyperledger.fabric.protos.peer
GetHistoryForKey is the payload of a ChaincodeMessage.
GetHistoryForKey.Builder - Class in org.hyperledger.fabric.protos.peer
GetHistoryForKey is the payload of a ChaincodeMessage.
GetHistoryForKeyOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
getHost() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
string host = 1 [json_name = "host"];
getHost() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
string host = 1 [json_name = "host"];
getHost() - Method in interface org.hyperledger.fabric.protos.discovery.EndpointOrBuilder
string host = 1 [json_name = "host"];
getHost() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
string host = 1 [json_name = "host"];
getHost() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
string host = 1 [json_name = "host"];
getHost() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConsenterOrBuilder
string host = 1 [json_name = "host"];
getHost() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
DNS host name of the anchor peer
getHost() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
DNS host name of the anchor peer
getHost() - Method in interface org.hyperledger.fabric.protos.peer.AnchorPeerOrBuilder
DNS host name of the anchor peer
getHostBytes() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
string host = 1 [json_name = "host"];
getHostBytes() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
string host = 1 [json_name = "host"];
getHostBytes() - Method in interface org.hyperledger.fabric.protos.discovery.EndpointOrBuilder
string host = 1 [json_name = "host"];
getHostBytes() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
string host = 1 [json_name = "host"];
getHostBytes() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
string host = 1 [json_name = "host"];
getHostBytes() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConsenterOrBuilder
string host = 1 [json_name = "host"];
getHostBytes() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
DNS host name of the anchor peer
getHostBytes() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
DNS host name of the anchor peer
getHostBytes() - Method in interface org.hyperledger.fabric.protos.peer.AnchorPeerOrBuilder
DNS host name of the anchor peer
getId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Id of the chaincode that's the unique fingerprint for the CC This is not currently used anywhere but serves as a good eyecatcher
getId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Id of the chaincode that's the unique fingerprint for the CC This is not currently used anywhere but serves as a good eyecatcher
getId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Id of the chaincode that's the unique fingerprint for the CC This is not currently used anywhere but serves as a good eyecatcher
getId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the chaincode unique id.
getId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the chaincode unique id.
getId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the chaincode unique id.
getId() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
string id = 3 [json_name = "id"];
getId() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
string id = 3 [json_name = "id"];
getId() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
string id = 3 [json_name = "id"];
getId() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
string id = 1 [json_name = "id"];
getId() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
string id = 1 [json_name = "id"];
getId() - Method in interface org.hyperledger.fabric.protos.peer.QueryStateCloseOrBuilder
string id = 1 [json_name = "id"];
getId() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
string id = 1 [json_name = "id"];
getId() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
string id = 1 [json_name = "id"];
getId() - Method in interface org.hyperledger.fabric.protos.peer.QueryStateNextOrBuilder
string id = 1 [json_name = "id"];
getIdBytes() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
the Identity, serialized according to the rules of its MPS
getIdBytes() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
the Identity, serialized according to the rules of its MPS
getIdBytes() - Method in interface org.hyperledger.fabric.protos.msp.SerializedIdentityOrBuilder
the Identity, serialized according to the rules of its MPS
getIdBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
string id = 3 [json_name = "id"];
getIdBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
string id = 3 [json_name = "id"];
getIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
string id = 3 [json_name = "id"];
getIdBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
string id = 1 [json_name = "id"];
getIdBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
string id = 1 [json_name = "id"];
getIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.QueryStateCloseOrBuilder
string id = 1 [json_name = "id"];
getIdBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
string id = 1 [json_name = "id"];
getIdBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
string id = 1 [json_name = "id"];
getIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.QueryStateNextOrBuilder
string id = 1 [json_name = "id"];
getIdentities(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentities(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentities(int) - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesBuilder(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesBuilderList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesCount() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesCount() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesCount() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesList() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentitiesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
getIdentity() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is the msp.SerializedIdentity of the peer, represented in bytes.
getIdentity() - Method in class org.hyperledger.fabric.protos.discovery.Peer
This is the msp.SerializedIdentity of the peer, represented in bytes.
getIdentity() - Method in interface org.hyperledger.fabric.protos.discovery.PeerOrBuilder
This is the msp.SerializedIdentity of the peer, represented in bytes.
getIdentity() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Client requestor identity.
getIdentity() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Client requestor identity.
getIdentity() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Client requestor identity.
getIdentity() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Client requestor identity.
getIdentity() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
Client requestor identity.
getIdentity() - Method in interface org.hyperledger.fabric.protos.gateway.CommitStatusRequestOrBuilder
Client requestor identity.
getIdentity() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
bytes identity = 4 [json_name = "identity"];
getIdentity() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
bytes identity = 4 [json_name = "identity"];
getIdentity() - Method in interface org.hyperledger.fabric.protos.gossip.AliveMessageOrBuilder
bytes identity = 4 [json_name = "identity"];
getIdentity() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes identity = 2 [json_name = "identity"];
getIdentity() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
bytes identity = 2 [json_name = "identity"];
getIdentity() - Method in interface org.hyperledger.fabric.protos.gossip.ConnEstablishOrBuilder
bytes identity = 2 [json_name = "identity"];
getIdentityIdentifierHashFunction() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
getIdentityIdentifierHashFunction() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
getIdentityIdentifierHashFunction() - Method in interface org.hyperledger.fabric.protos.msp.FabricCryptoConfigOrBuilder
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
getIdentityIdentifierHashFunctionBytes() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
getIdentityIdentifierHashFunctionBytes() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
getIdentityIdentifierHashFunctionBytes() - Method in interface org.hyperledger.fabric.protos.msp.FabricCryptoConfigOrBuilder
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
getIncNum() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
uint64 inc_num = 1 [json_name = "incNum"];
getIncNum() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
uint64 inc_num = 1 [json_name = "incNum"];
getIncNum() - Method in interface org.hyperledger.fabric.protos.gossip.PeerTimeOrBuilder
uint64 inc_num = 1 [json_name = "incNum"];
getIndex() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
uint64 index = 1 [json_name = "index"];
getIndex() - Method in class org.hyperledger.fabric.protos.common.LastConfig
uint64 index = 1 [json_name = "index"];
getIndex() - Method in interface org.hyperledger.fabric.protos.common.LastConfigOrBuilder
uint64 index = 1 [json_name = "index"];
getInfo() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Info string which may contain additional information about the status returned
getInfo() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
Info string which may contain additional information about the status returned
getInfo() - Method in interface org.hyperledger.fabric.protos.orderer.BroadcastResponseOrBuilder
Info string which may contain additional information about the status returned
getInfo() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Info string which may contain additional information about the returned status.
getInfo() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
Info string which may contain additional information about the returned status.
getInfo() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitResponseOrBuilder
Info string which may contain additional information about the returned status.
getInfoBytes() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Info string which may contain additional information about the status returned
getInfoBytes() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
Info string which may contain additional information about the status returned
getInfoBytes() - Method in interface org.hyperledger.fabric.protos.orderer.BroadcastResponseOrBuilder
Info string which may contain additional information about the status returned
getInfoBytes() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Info string which may contain additional information about the returned status.
getInfoBytes() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
Info string which may contain additional information about the returned status.
getInfoBytes() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitResponseOrBuilder
Info string which may contain additional information about the returned status.
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
bool init_required = 2 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
bool init_required = 2 [json_name = "initRequired"];
getInitRequired() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfoOrBuilder
bool init_required = 2 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
bool init_required = 7 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
bool init_required = 7 [json_name = "initRequired"];
getInitRequired() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
bool init_required = 7 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
bool init_required = 7 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
bool init_required = 7 [json_name = "initRequired"];
getInitRequired() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
bool init_required = 7 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
bool init_required = 8 [json_name = "initRequired"];
getInitRequired() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
bool init_required = 8 [json_name = "initRequired"];
getInProgress() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
bool in_progress = 1 [json_name = "inProgress"];
getInProgress() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
bool in_progress = 1 [json_name = "inProgress"];
getInProgress() - Method in interface org.hyperledger.fabric.protos.peer.JoinBySnapshotStatusOrBuilder
bool in_progress = 1 [json_name = "inProgress"];
getInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the chaincode function upon instantiation and its arguments.
getInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the chaincode function upon instantiation and its arguments.
getInput() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the chaincode function upon instantiation and its arguments.
getInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
Input contains the arguments for this invocation.
getInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
Input contains the arguments for this invocation.
getInput() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeProposalPayloadOrBuilder
Input contains the arguments for this invocation.
getInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeInput input = 3 [json_name = "input"];
getInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
.protos.ChaincodeInput input = 3 [json_name = "input"];
getInput() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
.protos.ChaincodeInput input = 3 [json_name = "input"];
getInputBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeInput input = 3 [json_name = "input"];
getInputBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the chaincode function upon instantiation and its arguments.
getInputBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the chaincode function upon instantiation and its arguments.
getInputBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the chaincode function upon instantiation and its arguments.
getInputOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeInput input = 3 [json_name = "input"];
getInputOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
.protos.ChaincodeInput input = 3 [json_name = "input"];
getInputOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
.protos.ChaincodeInput input = 3 [json_name = "input"];
GetInstalledChaincodePackageArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
GetInstalledChaincodePackageArgs is the message used as the argument to '_lifecycle.GetInstalledChaincodePackage'.
GetInstalledChaincodePackageArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
GetInstalledChaincodePackageArgs is the message used as the argument to '_lifecycle.GetInstalledChaincodePackage'.
GetInstalledChaincodePackageArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
GetInstalledChaincodePackageResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
GetInstalledChaincodePackageResult is the message returned by '_lifecycle.GetInstalledChaincodePackage'.
GetInstalledChaincodePackageResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
GetInstalledChaincodePackageResult is the message returned by '_lifecycle.GetInstalledChaincodePackage'.
GetInstalledChaincodePackageResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
getInstalledChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodes(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResultOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResultOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResultOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResultOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstalledChaincodesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResultOrBuilder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
getInstantiationPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
InstantiationPolicy for the chaincode
getInstantiationPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
InstantiationPolicy for the chaincode
getInstantiationPolicy() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
InstantiationPolicy for the chaincode
getInstantiationPolicy() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
This is the instantiation policy which is identical in structure to endorsement policy.
getInstantiationPolicy() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
This is the instantiation policy which is identical in structure to endorsement policy.
getInstantiationPolicy() - Method in interface org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpecOrBuilder
This is the instantiation policy which is identical in structure to endorsement policy.
getInstantiationPolicyBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
InstantiationPolicy for the chaincode
getInstantiationPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
InstantiationPolicy for the chaincode
getInstantiationPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
InstantiationPolicy for the chaincode
getInstantiationPolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
InstantiationPolicy for the chaincode
getInt64() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
int64 Int64 = 1 [json_name = "Int64"];
getInt64() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
int64 Int64 = 1 [json_name = "Int64"];
getInt64() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateDataOrBuilder
int64 Int64 = 1 [json_name = "Int64"];
getInterest() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The chaincode interest derived from simulating the proposal.
getInterest() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
The chaincode interest derived from simulating the proposal.
getInterest() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
The chaincode interest derived from simulating the proposal.
getInterestBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The chaincode interest derived from simulating the proposal.
getInterestOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The chaincode interest derived from simulating the proposal.
getInterestOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
The chaincode interest derived from simulating the proposal.
getInterestOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
The chaincode interest derived from simulating the proposal.
getInterests(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterests(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterests(int) - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryOrBuilder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsCount() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsCount() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsCount() - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryOrBuilder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsList() - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryOrBuilder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryOrBuilder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getInterestsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.discovery.ChaincodeQueryOrBuilder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
getIntermediateCerts(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getIntermediateCerts(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getIntermediateCerts(int) - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getIntermediateCertsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getIntermediateCertsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getIntermediateCertsCount() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getIntermediateCertsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getIntermediateCertsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getIntermediateCertsList() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
getInternalEndpoint() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
getInternalEndpoint() - Method in class org.hyperledger.fabric.protos.gossip.Secret
string internalEndpoint = 1 [json_name = "internalEndpoint"];
getInternalEndpoint() - Method in interface org.hyperledger.fabric.protos.gossip.SecretOrBuilder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
getInternalEndpointBytes() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
getInternalEndpointBytes() - Method in class org.hyperledger.fabric.protos.gossip.Secret
string internalEndpoint = 1 [json_name = "internalEndpoint"];
getInternalEndpointBytes() - Method in interface org.hyperledger.fabric.protos.gossip.SecretOrBuilder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
getIpk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
ipk represents the (serialized) issuer public key
getIpk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
ipk represents the (serialized) issuer public key
getIpk() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPConfigOrBuilder
ipk represents the (serialized) issuer public key
getIsDeclaration() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
bool is_declaration = 3 [json_name = "isDeclaration"];
getIsDeclaration() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
bool is_declaration = 3 [json_name = "isDeclaration"];
getIsDeclaration() - Method in interface org.hyperledger.fabric.protos.gossip.LeadershipMessageOrBuilder
bool is_declaration = 3 [json_name = "isDeclaration"];
getIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
bool is_delete = 4 [json_name = "isDelete"];
getIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
bool is_delete = 4 [json_name = "isDelete"];
getIsDelete() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KeyModificationOrBuilder
bool is_delete = 4 [json_name = "isDelete"];
getIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
bool is_delete = 2 [json_name = "isDelete"];
getIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
bool is_delete = 2 [json_name = "isDelete"];
getIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bool is_delete = 2 [json_name = "isDelete"];
getIsDelete() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
bool is_delete = 2 [json_name = "isDelete"];
getIsDelete() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHashOrBuilder
bool is_delete = 2 [json_name = "isDelete"];
getIsDelete() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteOrBuilder
bool is_delete = 2 [json_name = "isDelete"];
getIsInit() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
is_init is used for the application to signal that an invocation is to be routed to the legacy 'Init' function for compatibility with chaincodes which handled Init in the old way.
getIsInit() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
is_init is used for the application to signal that an invocation is to be routed to the legacy 'Init' function for compatibility with chaincodes which handled Init in the old way.
getIsInit() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInputOrBuilder
is_init is used for the application to signal that an invocation is to be routed to the legacy 'Init' function for compatibility with chaincodes which handled Init in the old way.
getIsolatedData() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Deprecated.
getIsolatedData() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
Deprecated.
getIsolatedData() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
Deprecated.
getIsolatedDataCount() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
getIsolatedDataCount() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
getIsolatedDataCount() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataMap() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataMap() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataMap() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataOrDefault(String, ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataOrDefault(String, ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataOrDefault(String, ByteString) - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsolatedDataOrThrow(String) - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
getIsPurge() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bool is_purge = 4 [json_name = "isPurge"];
getIsPurge() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
bool is_purge = 4 [json_name = "isPurge"];
getIsPurge() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHashOrBuilder
bool is_purge = 4 [json_name = "isPurge"];
getItrExhausted() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
bool itr_exhausted = 3 [json_name = "itrExhausted"];
getItrExhausted() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
bool itr_exhausted = 3 [json_name = "itrExhausted"];
getItrExhausted() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
bool itr_exhausted = 3 [json_name = "itrExhausted"];
getKey() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string key = 2 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
string key = 2 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KVOrBuilder
string key = 2 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.DelState
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.peer.DelStateOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.peer.GetHistoryForKeyOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.GetState
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.peer.GetStateMetadataOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.peer.GetStateOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.peer.PurgePrivateStateOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.PutState
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string key = 1 [json_name = "key"];
getKey() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.peer.PutStateMetadataOrBuilder
string key = 1 [json_name = "key"];
getKey() - Method in interface org.hyperledger.fabric.protos.peer.PutStateOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string key = 2 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
string key = 2 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KVOrBuilder
string key = 2 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.DelState
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.DelStateOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetHistoryForKeyOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetState
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetStateMetadataOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetStateOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.PurgePrivateStateOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.PutState
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.PutStateMetadataOrBuilder
string key = 1 [json_name = "key"];
getKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.PutStateOrBuilder
string key = 1 [json_name = "key"];
getKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
getKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
bytes key_hash = 1 [json_name = "keyHash"];
getKeyHash() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHashOrBuilder
bytes key_hash = 1 [json_name = "keyHash"];
getKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
getKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
bytes key_hash = 1 [json_name = "keyHash"];
getKeyHash() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHashOrBuilder
bytes key_hash = 1 [json_name = "keyHash"];
getKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
getKeyHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
bytes key_hash = 1 [json_name = "keyHash"];
getKeyHash() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHashOrBuilder
bytes key_hash = 1 [json_name = "keyHash"];
getKeyIdentifier() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
getKeyIdentifier() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
getKeyIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.KeyInfoOrBuilder
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
getKeyIdentifierBytes() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
getKeyIdentifierBytes() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
getKeyIdentifierBytes() - Method in interface org.hyperledger.fabric.protos.msp.KeyInfoOrBuilder
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
getKeyMaterial() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
KeyMaterial (optional) for the key to be imported; this is properly encoded key bytes, prefixed by the type of the key
getKeyMaterial() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
KeyMaterial (optional) for the key to be imported; this is properly encoded key bytes, prefixed by the type of the key
getKeyMaterial() - Method in interface org.hyperledger.fabric.protos.msp.KeyInfoOrBuilder
KeyMaterial (optional) for the key to be imported; this is properly encoded key bytes, prefixed by the type of the key
getKeyPolicies(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPolicies(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPolicies(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesCount() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKeyPoliciesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
getKnown(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
repeated bytes known = 2 [json_name = "known"];
getKnown(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
repeated bytes known = 2 [json_name = "known"];
getKnown(int) - Method in interface org.hyperledger.fabric.protos.gossip.MembershipRequestOrBuilder
repeated bytes known = 2 [json_name = "known"];
getKnownCount() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
repeated bytes known = 2 [json_name = "known"];
getKnownCount() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
repeated bytes known = 2 [json_name = "known"];
getKnownCount() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipRequestOrBuilder
repeated bytes known = 2 [json_name = "known"];
getKnownList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
repeated bytes known = 2 [json_name = "known"];
getKnownList() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
repeated bytes known = 2 [json_name = "known"];
getKnownList() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipRequestOrBuilder
repeated bytes known = 2 [json_name = "known"];
getKvReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReads(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsOrBuilder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsOrBuilder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsOrBuilder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsOrBuilder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getKvReadsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsOrBuilder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
getLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string label = 2 [json_name = "label"];
getLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
string label = 2 [json_name = "label"];
getLabel() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResultOrBuilder
string label = 2 [json_name = "label"];
getLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string label = 2 [json_name = "label"];
getLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
string label = 2 [json_name = "label"];
getLabel() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
string label = 2 [json_name = "label"];
getLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string label = 2 [json_name = "label"];
getLabel() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
string label = 2 [json_name = "label"];
getLabel() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
string label = 2 [json_name = "label"];
getLabelBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string label = 2 [json_name = "label"];
getLabelBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
string label = 2 [json_name = "label"];
getLabelBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResultOrBuilder
string label = 2 [json_name = "label"];
getLabelBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string label = 2 [json_name = "label"];
getLabelBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
string label = 2 [json_name = "label"];
getLabelBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
string label = 2 [json_name = "label"];
getLabelBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string label = 2 [json_name = "label"];
getLabelBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
string label = 2 [json_name = "label"];
getLabelBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
string label = 2 [json_name = "label"];
getLastBlockInSnapshot() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
uint64 lastBlockInSnapshot = 1 [json_name = "lastBlockInSnapshot"];
getLastBlockInSnapshot() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
uint64 lastBlockInSnapshot = 1 [json_name = "lastBlockInSnapshot"];
getLastBlockInSnapshot() - Method in interface org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfoOrBuilder
uint64 lastBlockInSnapshot = 1 [json_name = "lastBlockInSnapshot"];
getLastConfig() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
getLastConfig() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
getLastConfig() - Method in interface org.hyperledger.fabric.protos.common.OrdererBlockMetadataOrBuilder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
getLastConfigBuilder() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
getLastConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
getLastConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
getLastConfigOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.OrdererBlockMetadataOrBuilder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
getLastOffsetPersisted() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastOffsetPersisted is the encoded value for the Metadata message which is encoded in the ORDERER block metadata index for the case of the Kafka-based orderer.
getLastOffsetPersisted() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
LastOffsetPersisted is the encoded value for the Metadata message which is encoded in the ORDERER block metadata index for the case of the Kafka-based orderer.
getLastOffsetPersisted() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMetadataOrBuilder
LastOffsetPersisted is the encoded value for the Metadata message which is encoded in the ORDERER block metadata index for the case of the Kafka-based orderer.
getLastOriginalOffsetProcessed() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastOriginalOffsetProcessed is used to keep track of the newest offset processed if a message is re-validated and re-ordered.
getLastOriginalOffsetProcessed() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
LastOriginalOffsetProcessed is used to keep track of the newest offset processed if a message is re-validated and re-ordered.
getLastOriginalOffsetProcessed() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMetadataOrBuilder
LastOriginalOffsetProcessed is used to keep track of the newest offset processed if a message is re-validated and re-ordered.
getLastResubmittedConfigOffset() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastResubmittedConfigOffset is used to capture the newest offset of CONFIG kafka message, which is revalidated and resubmitted.
getLastResubmittedConfigOffset() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
LastResubmittedConfigOffset is used to capture the newest offset of CONFIG kafka message, which is revalidated and resubmitted.
getLastResubmittedConfigOffset() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMetadataOrBuilder
LastResubmittedConfigOffset is used to capture the newest offset of CONFIG kafka message, which is revalidated and resubmitted.
getLastUpdate() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
The last CONFIG_UPDATE message which generated this current configuration
getLastUpdate() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
The last CONFIG_UPDATE message which generated this current configuration
getLastUpdate() - Method in interface org.hyperledger.fabric.protos.common.ConfigEnvelopeOrBuilder
The last CONFIG_UPDATE message which generated this current configuration
getLastUpdateBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
The last CONFIG_UPDATE message which generated this current configuration
getLastUpdateOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
The last CONFIG_UPDATE message which generated this current configuration
getLastUpdateOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
The last CONFIG_UPDATE message which generated this current configuration
getLastUpdateOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.ConfigEnvelopeOrBuilder
The last CONFIG_UPDATE message which generated this current configuration
getLastValidationSeq() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
last_validation_seq denotes the last configuration sequence at which the sender validated this message.
getLastValidationSeq() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
last_validation_seq denotes the last configuration sequence at which the sender validated this message.
getLastValidationSeq() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitRequestOrBuilder
last_validation_seq denotes the last configuration sequence at which the sender validated this message.
getLayouts(int) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
getLayouts(int) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies options of fulfulling the endorsement policy.
getLayouts(int) - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies options of fulfulling the endorsement policy.
getLayoutsBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
getLayoutsBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
getLayoutsCount() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
getLayoutsCount() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies options of fulfulling the endorsement policy.
getLayoutsCount() - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies options of fulfulling the endorsement policy.
getLayoutsList() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
getLayoutsList() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies options of fulfulling the endorsement policy.
getLayoutsList() - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies options of fulfulling the endorsement policy.
getLayoutsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
getLayoutsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies options of fulfulling the endorsement policy.
getLayoutsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies options of fulfulling the endorsement policy.
getLayoutsOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
getLayoutsOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
Specifies options of fulfulling the endorsement policy.
getLayoutsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.discovery.EndorsementDescriptorOrBuilder
Specifies options of fulfulling the endorsement policy.
getLeadershipMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to indicate intent of peer to become leader
getLeadershipMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to indicate intent of peer to become leader
getLeadershipMsg() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to indicate intent of peer to become leader
getLeadershipMsgBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to indicate intent of peer to become leader
getLeadershipMsgOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to indicate intent of peer to become leader
getLeadershipMsgOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to indicate intent of peer to become leader
getLeadershipMsgOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to indicate intent of peer to become leader
getLedgerHeight() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
uint64 ledger_height = 1 [json_name = "ledgerHeight"];
getLedgerHeight() - Method in class org.hyperledger.fabric.protos.gossip.Properties
uint64 ledger_height = 1 [json_name = "ledgerHeight"];
getLedgerHeight() - Method in interface org.hyperledger.fabric.protos.gossip.PropertiesOrBuilder
uint64 ledger_height = 1 [json_name = "ledgerHeight"];
getLeftChannel() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
bool left_channel = 2 [json_name = "leftChannel"];
getLeftChannel() - Method in class org.hyperledger.fabric.protos.gossip.Properties
bool left_channel = 2 [json_name = "leftChannel"];
getLeftChannel() - Method in interface org.hyperledger.fabric.protos.gossip.PropertiesOrBuilder
bool left_channel = 2 [json_name = "leftChannel"];
getLocalPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
getLocalPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
getLocalPackage() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSourceOrBuilder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
getLocalPackageBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
getLocalPackageOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
getLocalPackageOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
getLocalPackageOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSourceOrBuilder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
getLocalPeers() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
getLocalPeers() - Method in class org.hyperledger.fabric.protos.discovery.Query
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
getLocalPeers() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
getLocalPeersBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
getLocalPeersOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
getLocalPeersOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
getLocalPeersOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
getMaxCount() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
The max count of channels to allow to be created, a value of 0 indicates no limit
getMaxCount() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
The max count of channels to allow to be created, a value of 0 indicates no limit
getMaxCount() - Method in interface org.hyperledger.fabric.protos.orderer.ChannelRestrictionsOrBuilder
The max count of channels to allow to be created, a value of 0 indicates no limit
getMaxDegree() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
uint32 max_degree = 1 [json_name = "maxDegree"];
getMaxDegree() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
uint32 max_degree = 1 [json_name = "maxDegree"];
getMaxDegree() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummaryOrBuilder
uint32 max_degree = 1 [json_name = "maxDegree"];
getMaximumPeerCount() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The maximum number of peers that private data will be sent to upon endorsement.
getMaximumPeerCount() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
The maximum number of peers that private data will be sent to upon endorsement.
getMaximumPeerCount() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
The maximum number of peers that private data will be sent to upon endorsement.
getMaximumPeerCount() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The maximum number of peers that private data will be sent to upon endorsement.
getMaximumPeerCount() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
The maximum number of peers that private data will be sent to upon endorsement.
getMaximumPeerCount() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
The maximum number of peers that private data will be sent to upon endorsement.
getMaxInflightBlocks() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 max_inflight_blocks = 4 [json_name = "maxInflightBlocks"];
getMaxInflightBlocks() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
uint32 max_inflight_blocks = 4 [json_name = "maxInflightBlocks"];
getMaxInflightBlocks() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.OptionsOrBuilder
uint32 max_inflight_blocks = 4 [json_name = "maxInflightBlocks"];
getMaxLevel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
uint32 max_level = 2 [json_name = "maxLevel"];
getMaxLevel() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
uint32 max_level = 2 [json_name = "maxLevel"];
getMaxLevel() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummaryOrBuilder
uint32 max_level = 2 [json_name = "maxLevel"];
getMaxLevelHashes(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxLevelHashes(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxLevelHashes(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummaryOrBuilder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxLevelHashesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxLevelHashesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxLevelHashesCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummaryOrBuilder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxLevelHashesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxLevelHashesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxLevelHashesList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummaryOrBuilder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
getMaxMessageCount() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
Simply specified as number of messages for now, in the future we may want to allow this to be specified by size in bytes
getMaxMessageCount() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
Simply specified as number of messages for now, in the future we may want to allow this to be specified by size in bytes
getMaxMessageCount() - Method in interface org.hyperledger.fabric.protos.orderer.BatchSizeOrBuilder
Simply specified as number of messages for now, in the future we may want to allow this to be specified by size in bytes
getMemberOnlyRead() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyRead() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyRead() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyRead() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyRead() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyRead() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyWrite() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyWrite() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyWrite() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyWrite() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyWrite() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOnlyWrite() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
getMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicy() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicy() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicyBuilder() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicyBuilder() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMemberOrgsPolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
getMembers() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
getMembers() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
getMembers() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
getMembersBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
getMembership() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.Member membership = 1 [json_name = "membership"];
getMembership() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
.gossip.Member membership = 1 [json_name = "membership"];
getMembership() - Method in interface org.hyperledger.fabric.protos.gossip.AliveMessageOrBuilder
.gossip.Member membership = 1 [json_name = "membership"];
getMembershipBuilder() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.Member membership = 1 [json_name = "membership"];
getMembershipInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
getMembershipInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
getMembershipInfo() - Method in interface org.hyperledger.fabric.protos.discovery.PeerOrBuilder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
getMembershipInfoBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
getMembershipInfoOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
getMembershipInfoOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peer
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
getMembershipInfoOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.PeerOrBuilder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
getMembershipOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.Member membership = 1 [json_name = "membership"];
getMembershipOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
.gossip.Member membership = 1 [json_name = "membership"];
getMembershipOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.AliveMessageOrBuilder
.gossip.Member membership = 1 [json_name = "membership"];
getMembersOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
getMembersOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
getMembersOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
getMemReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
getMemReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
getMemReq() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
getMemReqBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
getMemReqOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
getMemReqOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
getMemReqOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
getMemRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
getMemRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
getMemRes() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
getMemResBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
getMemResOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
getMemResOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
getMemResOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
getMessage() - Method in class com.google.rpc.Status.Builder
A developer-facing error message, which should be in English.
getMessage() - Method in class com.google.rpc.Status
A developer-facing error message, which should be in English.
getMessage() - Method in interface com.google.rpc.StatusOrBuilder
A developer-facing error message, which should be in English.
getMessage() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The error message returned by this node.
getMessage() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
The error message returned by this node.
getMessage() - Method in interface org.hyperledger.fabric.protos.gateway.ErrorDetailOrBuilder
The error message returned by this node.
getMessage() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A message associated with the response code.
getMessage() - Method in class org.hyperledger.fabric.protos.peer.Response
A message associated with the response code.
getMessage() - Method in interface org.hyperledger.fabric.protos.peer.ResponseOrBuilder
A message associated with the response code.
getMessageBytes() - Method in class com.google.rpc.Status.Builder
A developer-facing error message, which should be in English.
getMessageBytes() - Method in class com.google.rpc.Status
A developer-facing error message, which should be in English.
getMessageBytes() - Method in interface com.google.rpc.StatusOrBuilder
A developer-facing error message, which should be in English.
getMessageBytes() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The error message returned by this node.
getMessageBytes() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
The error message returned by this node.
getMessageBytes() - Method in interface org.hyperledger.fabric.protos.gateway.ErrorDetailOrBuilder
The error message returned by this node.
getMessageBytes() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A message associated with the response code.
getMessageBytes() - Method in class org.hyperledger.fabric.protos.peer.Response
A message associated with the response code.
getMessageBytes() - Method in interface org.hyperledger.fabric.protos.peer.ResponseOrBuilder
A message associated with the response code.
getMetadata() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
getMetadata(int) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadata(int) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadata(int) - Method in interface org.hyperledger.fabric.protos.common.BlockMetadataOrBuilder
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.gossip.ChaincodeOrBuilder
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
bytes metadata = 2 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
bytes metadata = 2 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.gossip.GossipHelloOrBuilder
bytes metadata = 2 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
bytes metadata = 2 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.gossip.Member
bytes metadata = 2 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.gossip.MemberOrBuilder
bytes metadata = 2 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.gossip.PeerIdentityOrBuilder
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationOrBuilder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusRequestOrBuilder
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
Opaque metadata, dependent on the consensus type.
getMetadata() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
Opaque metadata, dependent on the consensus type.
getMetadata() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusTypeOrBuilder
Opaque metadata, dependent on the consensus type.
getMetadata() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.peer.GetQueryResultOrBuilder
bytes metadata = 3 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
bytes metadata = 4 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
bytes metadata = 4 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.peer.GetStateByRangeOrBuilder
bytes metadata = 4 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.peer.PutStateMetadataOrBuilder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
bytes metadata = 4 [json_name = "metadata"];
getMetadata() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
bytes metadata = 4 [json_name = "metadata"];
getMetadata() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
bytes metadata = 4 [json_name = "metadata"];
getMetadataBuilder() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
getMetadataBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
getMetadataBuilder() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
getMetadataCount() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadataCount() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadataCount() - Method in interface org.hyperledger.fabric.protos.common.BlockMetadataOrBuilder
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadatahash() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
hash of ChaincodeID.name + ChaincodeID.version
getMetadatahash() - Method in class org.hyperledger.fabric.protos.peer.CDSData
hash of ChaincodeID.name + ChaincodeID.version
getMetadatahash() - Method in interface org.hyperledger.fabric.protos.peer.CDSDataOrBuilder
hash of ChaincodeID.name + ChaincodeID.version
getMetadataList() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadataList() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadataList() - Method in interface org.hyperledger.fabric.protos.common.BlockMetadataOrBuilder
repeated bytes metadata = 1 [json_name = "metadata"];
getMetadataOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
getMetadataOrBuilder() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
getMetadataOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
getMetadataOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
getMetadataOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
getMetadataOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationOrBuilder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
getMetadataOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
getMetadataOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
getMetadataOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.PutStateMetadataOrBuilder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
getMetadataWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWrites(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWrites(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSetOrBuilder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
getMetadataWritesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetadataWritesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
getMetakey() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
string metakey = 1 [json_name = "metakey"];
getMetakey() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
string metakey = 1 [json_name = "metakey"];
getMetakey() - Method in interface org.hyperledger.fabric.protos.peer.StateMetadataOrBuilder
string metakey = 1 [json_name = "metakey"];
getMetakeyBytes() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
string metakey = 1 [json_name = "metakey"];
getMetakeyBytes() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
string metakey = 1 [json_name = "metakey"];
getMetakeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.StateMetadataOrBuilder
string metakey = 1 [json_name = "metakey"];
getModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
string mod_policy = 5 [json_name = "modPolicy"];
getModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
string mod_policy = 5 [json_name = "modPolicy"];
getModPolicy() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
string mod_policy = 5 [json_name = "modPolicy"];
getModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicy() - Method in interface org.hyperledger.fabric.protos.common.ConfigPolicyOrBuilder
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicy() - Method in interface org.hyperledger.fabric.protos.common.ConfigValueOrBuilder
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicyBytes() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
string mod_policy = 5 [json_name = "modPolicy"];
getModPolicyBytes() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
string mod_policy = 5 [json_name = "modPolicy"];
getModPolicyBytes() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
string mod_policy = 5 [json_name = "modPolicy"];
getModPolicyBytes() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicyBytes() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicyBytes() - Method in interface org.hyperledger.fabric.protos.common.ConfigPolicyOrBuilder
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicyBytes() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicyBytes() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
string mod_policy = 3 [json_name = "modPolicy"];
getModPolicyBytes() - Method in interface org.hyperledger.fabric.protos.common.ConfigValueOrBuilder
string mod_policy = 3 [json_name = "modPolicy"];
getMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in interface org.hyperledger.fabric.protos.gossip.DataDigestOrBuilder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in interface org.hyperledger.fabric.protos.gossip.DataRequestOrBuilder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in interface org.hyperledger.fabric.protos.gossip.DataUpdateOrBuilder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgType() - Method in interface org.hyperledger.fabric.protos.gossip.GossipHelloOrBuilder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in interface org.hyperledger.fabric.protos.gossip.DataDigestOrBuilder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in interface org.hyperledger.fabric.protos.gossip.DataRequestOrBuilder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in interface org.hyperledger.fabric.protos.gossip.DataUpdateOrBuilder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMsgTypeValue() - Method in interface org.hyperledger.fabric.protos.gossip.GossipHelloOrBuilder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
getMspId() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The MSP Identifier of this node.
getMspId() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
The MSP Identifier of this node.
getMspId() - Method in interface org.hyperledger.fabric.protos.gateway.ErrorDetailOrBuilder
The MSP Identifier of this node.
getMspid() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
The identifier of the associated membership service provider
getMspid() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
The identifier of the associated membership service provider
getMspid() - Method in interface org.hyperledger.fabric.protos.msp.SerializedIdentityOrBuilder
The identifier of the associated membership service provider
getMspIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The MSP Identifier of this node.
getMspIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
The MSP Identifier of this node.
getMspIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.ErrorDetailOrBuilder
The MSP Identifier of this node.
getMspidBytes() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
The identifier of the associated membership service provider
getMspidBytes() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
The identifier of the associated membership service provider
getMspidBytes() - Method in interface org.hyperledger.fabric.protos.msp.SerializedIdentityOrBuilder
The identifier of the associated membership service provider
getMspIdentifier() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPIdentifier represents the identifier of the MSP this principal refers to
getMspIdentifier() - Method in class org.hyperledger.fabric.protos.common.MSPRole
MSPIdentifier represents the identifier of the MSP this principal refers to
getMspIdentifier() - Method in interface org.hyperledger.fabric.protos.common.MSPRoleOrBuilder
MSPIdentifier represents the identifier of the MSP this principal refers to
getMspIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
MSPIdentifier represents the identifier of the MSP this organization unit refers to
getMspIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
MSPIdentifier represents the identifier of the MSP this organization unit refers to
getMspIdentifier() - Method in interface org.hyperledger.fabric.protos.common.OrganizationUnitOrBuilder
MSPIdentifier represents the identifier of the MSP this organization unit refers to
getMspIdentifierBytes() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPIdentifier represents the identifier of the MSP this principal refers to
getMspIdentifierBytes() - Method in class org.hyperledger.fabric.protos.common.MSPRole
MSPIdentifier represents the identifier of the MSP this principal refers to
getMspIdentifierBytes() - Method in interface org.hyperledger.fabric.protos.common.MSPRoleOrBuilder
MSPIdentifier represents the identifier of the MSP this principal refers to
getMspIdentifierBytes() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
MSPIdentifier represents the identifier of the MSP this organization unit refers to
getMspIdentifierBytes() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
MSPIdentifier represents the identifier of the MSP this organization unit refers to
getMspIdentifierBytes() - Method in interface org.hyperledger.fabric.protos.common.OrganizationUnitOrBuilder
MSPIdentifier represents the identifier of the MSP this organization unit refers to
getMsps() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
Deprecated.
getMsps() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
Deprecated.
getMsps() - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
Deprecated.
getMspsCount() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
getMspsCount() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
getMspsCount() - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
msps is a map from MSP_ID to FabricMSPConfig
getMspsMap() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
msps is a map from MSP_ID to FabricMSPConfig
getMspsMap() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
msps is a map from MSP_ID to FabricMSPConfig
getMspsMap() - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
msps is a map from MSP_ID to FabricMSPConfig
getMspsOrDefault(String, FabricMSPConfig) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
msps is a map from MSP_ID to FabricMSPConfig
getMspsOrDefault(String, FabricMSPConfig) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
msps is a map from MSP_ID to FabricMSPConfig
getMspsOrDefault(String, FabricMSPConfig) - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
msps is a map from MSP_ID to FabricMSPConfig
getMspsOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
msps is a map from MSP_ID to FabricMSPConfig
getMspsOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
msps is a map from MSP_ID to FabricMSPConfig
getMspsOrThrow(String) - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
msps is a map from MSP_ID to FabricMSPConfig
getMutableAcls() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
Deprecated.
getMutableApprovals() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
Deprecated.
getMutableApprovals() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
Deprecated.
getMutableCapabilities() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
Deprecated.
getMutableCollectionConfigs() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
Deprecated.
getMutableDecorations() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
Deprecated.
getMutableEndorsersByGroups() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Deprecated.
getMutableGroups() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
Deprecated.
getMutableIsolatedData() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Deprecated.
getMutableMsps() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
Deprecated.
getMutableOrderers() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
Deprecated.
getMutablePeersByOrg() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
Deprecated.
getMutablePolicies() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
Deprecated.
getMutablePrivateDataMap() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
Deprecated.
getMutableQuantitiesByGroup() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Deprecated.
getMutableReferences() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
Deprecated.
getMutableReferences() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
Deprecated.
getMutableTransientMap() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
Deprecated.
getMutableValues() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
Deprecated.
getN() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
int32 n = 1 [json_name = "n"];
getN() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
int32 n = 1 [json_name = "n"];
getN() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOfOrBuilder
int32 n = 1 [json_name = "n"];
getName() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.common.Consortium
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.common.ConsortiumOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
SHA256 is currently the only supported and tested algorithm.
getName() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
SHA256 is currently the only supported and tested algorithm.
getName() - Method in interface org.hyperledger.fabric.protos.common.HashingAlgorithmOrBuilder
SHA256 is currently the only supported and tested algorithm.
getName() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
the name of the collection inside the denoted chaincode
getName() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
the name of the collection inside the denoted chaincode
getName() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
the name of the collection inside the denoted chaincode
getName() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.gossip.ChaincodeOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntryOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
getName() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
getName() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
getName() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
Name holds the identifier of the MSP
getName() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
Name holds the identifier of the MSP
getName() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPConfigOrBuilder
Name holds the identifier of the MSP
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Name of the chaincode
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Name of the chaincode
getName() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Name of the chaincode
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
Specifies what code to run for endorsements, defaults 'escc'
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
Specifies what code to run for endorsements, defaults 'escc'
getName() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEndorsementOrBuilder
Specifies what code to run for endorsements, defaults 'escc'
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
all other requests will use the name (really a hashcode) generated by the deploy transaction
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
all other requests will use the name (really a hashcode) generated by the deploy transaction
getName() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIDOrBuilder
all other requests will use the name (really a hashcode) generated by the deploy transaction
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
Specifies which code to run to validate transactions, defaults to 'vscc'
getName() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
Specifies which code to run to validate transactions, defaults to 'vscc'
getName() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeValidationOrBuilder
Specifies which code to run to validate transactions, defaults to 'vscc'
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string name = 2 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
string name = 2 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
string name = 2 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string name = 2 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
string name = 2 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
string name = 2 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string name = 2 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
string name = 2 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
string name = 2 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgsOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgsOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ChaincodeOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
string name = 1 [json_name = "name"];
getName() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ChaincodeOrBuilder
string name = 1 [json_name = "name"];
getName() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
the name of the collection inside the denoted chaincode
getName() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
the name of the collection inside the denoted chaincode
getName() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
the name of the collection inside the denoted chaincode
getNameBytes() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.common.Consortium
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.common.ConsortiumOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
SHA256 is currently the only supported and tested algorithm.
getNameBytes() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
SHA256 is currently the only supported and tested algorithm.
getNameBytes() - Method in interface org.hyperledger.fabric.protos.common.HashingAlgorithmOrBuilder
SHA256 is currently the only supported and tested algorithm.
getNameBytes() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
the name of the collection inside the denoted chaincode
getNameBytes() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
the name of the collection inside the denoted chaincode
getNameBytes() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
the name of the collection inside the denoted chaincode
getNameBytes() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.gossip.ChaincodeOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntryOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
getNameBytes() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
getNameBytes() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
getNameBytes() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
Name holds the identifier of the MSP
getNameBytes() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
Name holds the identifier of the MSP
getNameBytes() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPConfigOrBuilder
Name holds the identifier of the MSP
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Name of the chaincode
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Name of the chaincode
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Name of the chaincode
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
Specifies what code to run for endorsements, defaults 'escc'
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
Specifies what code to run for endorsements, defaults 'escc'
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEndorsementOrBuilder
Specifies what code to run for endorsements, defaults 'escc'
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
all other requests will use the name (really a hashcode) generated by the deploy transaction
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
all other requests will use the name (really a hashcode) generated by the deploy transaction
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIDOrBuilder
all other requests will use the name (really a hashcode) generated by the deploy transaction
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
Specifies which code to run to validate transactions, defaults to 'vscc'
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
Specifies which code to run to validate transactions, defaults to 'vscc'
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeValidationOrBuilder
Specifies which code to run to validate transactions, defaults to 'vscc'
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string name = 2 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
string name = 2 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
string name = 2 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string name = 2 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
string name = 2 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
string name = 2 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string name = 2 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
string name = 2 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
string name = 2 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgsOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgsOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ChaincodeOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
string name = 1 [json_name = "name"];
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ChaincodeOrBuilder
string name = 1 [json_name = "name"];
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
the name of the collection inside the denoted chaincode
getNameBytes() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
the name of the collection inside the denoted chaincode
getNameBytes() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
the name of the collection inside the denoted chaincode
getNamespace() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string namespace = 2 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
string namespace = 2 [json_name = "namespace"];
getNamespace() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
string namespace = 2 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string namespace = 2 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
string namespace = 2 [json_name = "namespace"];
getNamespace() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataDigestOrBuilder
string namespace = 2 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string namespace = 1 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
string namespace = 1 [json_name = "namespace"];
getNamespace() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KVOrBuilder
string namespace = 1 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
string namespace = 1 [json_name = "namespace"];
getNamespace() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSetOrBuilder
string namespace = 1 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
getNamespace() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
string namespace = 1 [json_name = "namespace"];
getNamespace() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSetOrBuilder
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string namespace = 2 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
string namespace = 2 [json_name = "namespace"];
getNamespaceBytes() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
string namespace = 2 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string namespace = 2 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
string namespace = 2 [json_name = "namespace"];
getNamespaceBytes() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataDigestOrBuilder
string namespace = 2 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KVOrBuilder
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSetOrBuilder
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
string namespace = 1 [json_name = "namespace"];
getNamespaceBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSetOrBuilder
string namespace = 1 [json_name = "namespace"];
getNewest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
getNewest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekNewest newest = 1 [json_name = "newest"];
getNewest() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
getNewestBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
getNewestOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
getNewestOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekNewest newest = 1 [json_name = "newest"];
getNewestOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
getNextCommit() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
getNextCommit() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
getNextCommit() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
getNextCommitBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
getNextCommitOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
getNextCommitOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
getNextCommitOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
getNextConsenterId() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Carries the Raft ID value that will be assigned to the next OSN that will join this cluster.
getNextConsenterId() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
Carries the Raft ID value that will be assigned to the next OSN that will join this cluster.
getNextConsenterId() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadataOrBuilder
Carries the Raft ID value that will be assigned to the next OSN that will join this cluster.
getNonce() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
Arbitrary number that may only be used once.
getNonce() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
Arbitrary number that may only be used once.
getNonce() - Method in interface org.hyperledger.fabric.protos.common.SignatureHeaderOrBuilder
Arbitrary number that may only be used once.
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in interface org.hyperledger.fabric.protos.gossip.DataDigestOrBuilder
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in interface org.hyperledger.fabric.protos.gossip.DataRequestOrBuilder
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in interface org.hyperledger.fabric.protos.gossip.DataUpdateOrBuilder
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in interface org.hyperledger.fabric.protos.gossip.GossipHelloOrBuilder
uint64 nonce = 1 [json_name = "nonce"];
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
used mainly for testing, but will might be used in the future for ensuring message delivery by acking
getNonce() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
used mainly for testing, but will might be used in the future for ensuring message delivery by acking
getNonce() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
used mainly for testing, but will might be used in the future for ensuring message delivery by acking
getNoPrivateReads() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we do not need to read from private data
getNoPrivateReads() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
Indicates we do not need to read from private data
getNoPrivateReads() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
Indicates we do not need to read from private data
getNoPublicWrites() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we do not need to write to the chaincode namespace
getNoPublicWrites() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
Indicates we do not need to write to the chaincode namespace
getNoPublicWrites() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeCallOrBuilder
Indicates we do not need to write to the chaincode namespace
getNOutOf() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
getNOutOf() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
getNOutOf() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyOrBuilder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
getNOutOfBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
getNOutOfOrBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
getNOutOfOrBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
getNOutOfOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyOrBuilder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
getNsPvtRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwset(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSetOrBuilder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSetOrBuilder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSetOrBuilder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSetOrBuilder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsPvtRwsetOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSetOrBuilder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
getNsRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwset(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSetOrBuilder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSetOrBuilder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSetOrBuilder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSetOrBuilder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNsRwsetOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSetOrBuilder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
getNumber() - Method in enum org.hyperledger.fabric.protos.common.ApplicationPolicy.TypeCase
Deprecated.
 
getNumber() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The position in the blockchain
getNumber() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
The position in the blockchain
getNumber() - Method in interface org.hyperledger.fabric.protos.common.BlockHeaderOrBuilder
The position in the blockchain
getNumber() - Method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.CollectionConfig.PayloadCase
Deprecated.
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.CollectionPolicyConfig.PayloadCase
Deprecated.
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.HeaderType
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.SignaturePolicy.TypeCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.common.Status
 
getNumber() - Method in enum org.hyperledger.fabric.protos.discovery.Query.QueryCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.discovery.QueryResult.ResultCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.ContentCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
 
getNumber() - Method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
 
getNumber() - Method in enum org.hyperledger.fabric.protos.gossip.Secret.ContentCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.ReadsInfoCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.TypeCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.DeliverResponse.TypeCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.KafkaMessage.TypeCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.SeekPosition.TypeCase
 
getNumber() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
uint64 number = 1 [json_name = "number"];
getNumber() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
uint64 number = 1 [json_name = "number"];
getNumber() - Method in interface org.hyperledger.fabric.protos.orderer.SeekSpecifiedOrBuilder
uint64 number = 1 [json_name = "number"];
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.StepRequest.PayloadCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.orderer.StepResponse.PayloadCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.ApplicationPolicy.TypeCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.CollectionConfig.PayloadCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.PayloadCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.DeliverResponse.TypeCase
 
getNumber() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
The position in the blockchain
getNumber() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
The position in the blockchain
getNumber() - Method in interface org.hyperledger.fabric.protos.peer.FilteredBlockOrBuilder
The position in the blockchain
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.FilteredTransaction.DataCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.TypeCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.lifecycle.StateData.TypeCase
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
 
getNumber() - Method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
 
getNymX() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
nym_x is the X-component of the pseudonym elliptic curve point.
getNymX() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
nym_x is the X-component of the pseudonym elliptic curve point.
getNymX() - Method in interface org.hyperledger.fabric.protos.msp.SerializedIdemixIdentityOrBuilder
nym_x is the X-component of the pseudonym elliptic curve point.
getNymY() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
nym_y is the Y-component of the pseudonym elliptic curve point.
getNymY() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
nym_y is the Y-component of the pseudonym elliptic curve point.
getNymY() - Method in interface org.hyperledger.fabric.protos.msp.SerializedIdemixIdentityOrBuilder
nym_y is the Y-component of the pseudonym elliptic curve point.
getOldest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
getOldest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
getOldest() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
getOldestBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
getOldestOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
getOldestOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
getOldestOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
getOptions() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
.etcdraft.Options options = 2 [json_name = "options"];
getOptions() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
.etcdraft.Options options = 2 [json_name = "options"];
getOptions() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadataOrBuilder
.etcdraft.Options options = 2 [json_name = "options"];
getOptionsBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
.etcdraft.Options options = 2 [json_name = "options"];
getOptionsOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
.etcdraft.Options options = 2 [json_name = "options"];
getOptionsOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
.etcdraft.Options options = 2 [json_name = "options"];
getOptionsOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadataOrBuilder
.etcdraft.Options options = 2 [json_name = "options"];
getOrdererOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the orderers
getOrdererOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the orderers
getOrdererOuIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the orderers
getOrdererOuIdentifierBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the orderers
getOrdererOuIdentifierOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the orderers
getOrdererOuIdentifierOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the orderers
getOrdererOuIdentifierOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the orderers
getOrderers() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
Deprecated.
getOrderers() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
Deprecated.
getOrderers() - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
Deprecated.
getOrderersCount() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
getOrderersCount() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
getOrderersCount() - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersMap() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersMap() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersMap() - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersOrDefault(String, Endpoints) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersOrDefault(String, Endpoints) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersOrDefault(String, Endpoints) - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
orderers is a map from MSP_ID to endpoint lists of orderers
getOrderersOrThrow(String) - Method in interface org.hyperledger.fabric.protos.discovery.ConfigResultOrBuilder
orderers is a map from MSP_ID to endpoint lists of orderers
getOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifier() - Method in interface org.hyperledger.fabric.protos.common.OrganizationUnitOrBuilder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricOUIdentifierOrBuilder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
organizational_unit_identifier defines the organizational unit the default signer is in
getOrganizationalUnitIdentifier() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
organizational_unit_identifier defines the organizational unit the default signer is in
getOrganizationalUnitIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfigOrBuilder
organizational_unit_identifier defines the organizational unit the default signer is in
getOrganizationalUnitIdentifierBytes() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifierBytes() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifierBytes() - Method in interface org.hyperledger.fabric.protos.common.OrganizationUnitOrBuilder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifierBytes() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifierBytes() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifierBytes() - Method in interface org.hyperledger.fabric.protos.msp.FabricOUIdentifierOrBuilder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
getOrganizationalUnitIdentifierBytes() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
organizational_unit_identifier defines the organizational unit the default signer is in
getOrganizationalUnitIdentifierBytes() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
organizational_unit_identifier defines the organizational unit the default signer is in
getOrganizationalUnitIdentifierBytes() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfigOrBuilder
organizational_unit_identifier defines the organizational unit the default signer is in
getOrganizationalUnitIdentifiers(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiers(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiers(int) - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersBuilder(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersBuilderList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersCount() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersList() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersOrBuilder(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersOrBuilder(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersOrBuilderList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersOrBuilderList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOrganizationalUnitIdentifiersOrBuilderList() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
getOriginalOffset() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
int64 original_offset = 4 [json_name = "originalOffset"];
getOriginalOffset() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
int64 original_offset = 4 [json_name = "originalOffset"];
getOriginalOffset() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageRegularOrBuilder
int64 original_offset = 4 [json_name = "originalOffset"];
getOu() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
ou contains the organizational unit of the idemix identity
getOu() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
ou contains the organizational unit of the idemix identity
getOu() - Method in interface org.hyperledger.fabric.protos.msp.SerializedIdemixIdentityOrBuilder
ou contains the organizational unit of the idemix identity
getOwnerEndorsements(int) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsements(int) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsements(int) - Method in interface org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpecOrBuilder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsBuilderList() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsCount() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsCount() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsCount() - Method in interface org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpecOrBuilder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsList() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsList() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsList() - Method in interface org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpecOrBuilder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpecOrBuilder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getOwnerEndorsementsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpecOrBuilder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.LocalOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgsOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResultOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgsOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
string package_id = 1 [json_name = "packageId"];
getPackageId() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.LocalOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgsOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResultOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgsOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
string package_id = 1 [json_name = "packageId"];
getPackageIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
string package_id = 1 [json_name = "packageId"];
getPageSize() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
int32 pageSize = 1 [json_name = "pageSize"];
getPageSize() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
int32 pageSize = 1 [json_name = "pageSize"];
getPageSize() - Method in interface org.hyperledger.fabric.protos.peer.QueryMetadataOrBuilder
int32 pageSize = 1 [json_name = "pageSize"];
getParserForType() - Method in class com.google.rpc.Status
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Block
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.BlockData
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Capability
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Config
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Consortium
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Envelope
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Header
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Metadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Payload
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.Policy
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
getParserForType() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Error
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Request
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.Response
 
getParserForType() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.Member
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
getParserForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
getParserForType() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.DelState
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.GetState
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.PutState
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.Response
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
getParserForType() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
getParserForType() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
getPath() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
deploy transaction will use the path
getPath() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
deploy transaction will use the path
getPath() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIDOrBuilder
deploy transaction will use the path
getPath() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the path as specified by the install/instantiate transaction
getPath() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the path as specified by the install/instantiate transaction
getPath() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the path as specified by the install/instantiate transaction
getPathBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
deploy transaction will use the path
getPathBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
deploy transaction will use the path
getPathBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIDOrBuilder
deploy transaction will use the path
getPathBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the path as specified by the install/instantiate transaction
getPathBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the path as specified by the install/instantiate transaction
getPathBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the path as specified by the install/instantiate transaction
getPayload() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
A marshaled Payload
getPayload() - Method in class org.hyperledger.fabric.protos.common.Envelope
A marshaled Payload
getPayload() - Method in interface org.hyperledger.fabric.protos.common.EnvelopeOrBuilder
A marshaled Payload
getPayload() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.discovery.SignedRequestOrBuilder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
.gossip.Payload payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
.gossip.Payload payload = 1 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.gossip.DataMessageOrBuilder
.gossip.Payload payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.gossip.EnvelopeOrBuilder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.gossip.PrivateDataMessageOrBuilder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
getPayload(int) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
the payload is a marshaled kvrwset.KVRWSet
getPayload(int) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
the payload is a marshaled kvrwset.KVRWSet
getPayload(int) - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataElementOrBuilder
the payload is a marshaled kvrwset.KVRWSet
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
Encodes marhslaed bytes of rwset.TxPvtReadWriteSet defined in rwset.proto
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
Encodes marhslaed bytes of rwset.TxPvtReadWriteSet defined in rwset.proto
getPayload() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataPayloadOrBuilder
Encodes marhslaed bytes of rwset.TxPvtReadWriteSet defined in rwset.proto
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.gossip.SecretEnvelopeOrBuilder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
bytes payload = 2 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
bytes payload = 2 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusRequestOrBuilder
bytes payload = 2 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageConnectOrBuilder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageRegularOrBuilder
bytes payload = 1 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
content is the fabric transaction that is forwarded to the cluster member.
getPayload() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
content is the fabric transaction that is forwarded to the cluster member.
getPayload() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitRequestOrBuilder
content is the fabric transaction that is forwarded to the cluster member.
getPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
bytes payload = 4 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
bytes payload = 4 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEventOrBuilder
bytes payload = 4 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
bytes payload = 3 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
bytes payload = 3 [json_name = "payload"];
getPayload() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
bytes payload = 3 [json_name = "payload"];
getPayload() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
The payload of the proposal as defined by the type in the proposal header.
getPayload() - Method in class org.hyperledger.fabric.protos.peer.Proposal
The payload of the proposal as defined by the type in the proposal header.
getPayload() - Method in interface org.hyperledger.fabric.protos.peer.ProposalOrBuilder
The payload of the proposal as defined by the type in the proposal header.
getPayload() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The payload of response.
getPayload() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
The payload of response.
getPayload() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
The payload of response.
getPayload() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A payload that can be used to include metadata with this response.
getPayload() - Method in class org.hyperledger.fabric.protos.peer.Response
A payload that can be used to include metadata with this response.
getPayload() - Method in interface org.hyperledger.fabric.protos.peer.ResponseOrBuilder
A payload that can be used to include metadata with this response.
getPayload() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
The payload of the action as defined by the type in the header For chaincode, it's the bytes of ChaincodeActionPayload
getPayload() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
The payload of the action as defined by the type in the header For chaincode, it's the bytes of ChaincodeActionPayload
getPayload() - Method in interface org.hyperledger.fabric.protos.peer.TransactionActionOrBuilder
The payload of the action as defined by the type in the header For chaincode, it's the bytes of ChaincodeActionPayload
getPayloadBuilder() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
.gossip.Payload payload = 1 [json_name = "payload"];
getPayloadBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
getPayloadBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
content is the fabric transaction that is forwarded to the cluster member.
getPayloadCase() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
getPayloadCase() - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigOrBuilder
Deprecated.
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
getPayloadCase() - Method in interface org.hyperledger.fabric.protos.common.CollectionPolicyConfigOrBuilder
Deprecated.
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
getPayloadCase() - Method in interface org.hyperledger.fabric.protos.orderer.StepRequestOrBuilder
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
getPayloadCase() - Method in interface org.hyperledger.fabric.protos.orderer.StepResponseOrBuilder
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
getPayloadCase() - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigOrBuilder
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
getPayloadCase() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
getPayloadCase() - Method in interface org.hyperledger.fabric.protos.peer.CollectionPolicyConfigOrBuilder
 
getPayloadCount() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
the payload is a marshaled kvrwset.KVRWSet
getPayloadCount() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
the payload is a marshaled kvrwset.KVRWSet
getPayloadCount() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataElementOrBuilder
the payload is a marshaled kvrwset.KVRWSet
getPayloadList() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
the payload is a marshaled kvrwset.KVRWSet
getPayloadList() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
the payload is a marshaled kvrwset.KVRWSet
getPayloadList() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataElementOrBuilder
the payload is a marshaled kvrwset.KVRWSet
getPayloadOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
.gossip.Payload payload = 1 [json_name = "payload"];
getPayloadOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
.gossip.Payload payload = 1 [json_name = "payload"];
getPayloadOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.DataMessageOrBuilder
.gossip.Payload payload = 1 [json_name = "payload"];
getPayloadOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
getPayloadOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
getPayloadOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.PrivateDataMessageOrBuilder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
getPayloadOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
content is the fabric transaction that is forwarded to the cluster member.
getPayloadOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
content is the fabric transaction that is forwarded to the cluster member.
getPayloadOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitRequestOrBuilder
content is the fabric transaction that is forwarded to the cluster member.
getPayloads(int) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloads(int) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloads(int) - Method in interface org.hyperledger.fabric.protos.gossip.RemoteStateResponseOrBuilder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsCount() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsCount() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsCount() - Method in interface org.hyperledger.fabric.protos.gossip.RemoteStateResponseOrBuilder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsList() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsList() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsList() - Method in interface org.hyperledger.fabric.protos.gossip.RemoteStateResponseOrBuilder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.gossip.RemoteStateResponseOrBuilder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsOrBuilderList() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPayloadsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.gossip.RemoteStateResponseOrBuilder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
getPeerIdentity() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to learn of a peer's certificate
getPeerIdentity() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to learn of a peer's certificate
getPeerIdentity() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to learn of a peer's certificate
getPeerIdentityBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to learn of a peer's certificate
getPeerIdentityOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to learn of a peer's certificate
getPeerIdentityOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to learn of a peer's certificate
getPeerIdentityOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to learn of a peer's certificate
getPeerOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the peers
getPeerOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the peers
getPeerOuIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the peers
getPeerOuIdentifierBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the peers
getPeerOuIdentifierOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the peers
getPeerOuIdentifierOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the peers
getPeerOuIdentifierOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the peers
getPeerQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
getPeerQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
getPeerQuery() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
getPeerQueryBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
getPeerQueryOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
getPeerQueryOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
getPeerQueryOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
getPeers(int) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeers(int) - Method in class org.hyperledger.fabric.protos.discovery.Peers
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeers(int) - Method in interface org.hyperledger.fabric.protos.discovery.PeersOrBuilder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersByOrg() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
Deprecated.
getPeersByOrg() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
Deprecated.
getPeersByOrg() - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipResultOrBuilder
Deprecated.
getPeersByOrgCount() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
getPeersByOrgCount() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
getPeersByOrgCount() - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipResultOrBuilder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgMap() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgMap() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgMap() - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipResultOrBuilder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgOrDefault(String, Peers) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgOrDefault(String, Peers) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgOrDefault(String, Peers) - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipResultOrBuilder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersByOrgOrThrow(String) - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipResultOrBuilder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
getPeersCount() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersCount() - Method in class org.hyperledger.fabric.protos.discovery.Peers
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersCount() - Method in interface org.hyperledger.fabric.protos.discovery.PeersOrBuilder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersList() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersList() - Method in class org.hyperledger.fabric.protos.discovery.Peers
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersList() - Method in interface org.hyperledger.fabric.protos.discovery.PeersOrBuilder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Peers
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.discovery.PeersOrBuilder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Peers
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPeersOrBuilderList() - Method in interface org.hyperledger.fabric.protos.discovery.PeersOrBuilder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
getPingMethod() - Static method in class org.hyperledger.fabric.protos.gossip.GossipGrpc
 
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in interface org.hyperledger.fabric.protos.gossip.ConnEstablishOrBuilder
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in interface org.hyperledger.fabric.protos.gossip.LeadershipMessageOrBuilder
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
bytes pki_id = 3 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.Member
bytes pki_id = 3 [json_name = "pkiId"];
getPkiId() - Method in interface org.hyperledger.fabric.protos.gossip.MemberOrBuilder
bytes pki_id = 3 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in interface org.hyperledger.fabric.protos.gossip.PeerIdentityOrBuilder
bytes pki_id = 1 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
bytes pki_id = 3 [json_name = "pkiId"];
getPkiId() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
bytes pki_id = 3 [json_name = "pkiId"];
getPkiId() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoOrBuilder
bytes pki_id = 3 [json_name = "pkiId"];
getPolicies() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
Deprecated.
getPolicies() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
Deprecated.
getPolicies() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
Deprecated.
getPoliciesCount() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
getPoliciesCount() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getPoliciesCount() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesMap() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesMap() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesMap() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesOrDefault(String, ConfigPolicy) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesOrDefault(String, ConfigPolicy) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesOrDefault(String, ConfigPolicy) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPoliciesOrThrow(String) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
getPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
.common.Policy policy = 2 [json_name = "policy"];
getPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
.common.Policy policy = 2 [json_name = "policy"];
getPolicy() - Method in interface org.hyperledger.fabric.protos.common.ConfigPolicyOrBuilder
.common.Policy policy = 2 [json_name = "policy"];
getPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Policy endorsement policy for the chaincode instance
getPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Policy endorsement policy for the chaincode instance
getPolicy() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Policy endorsement policy for the chaincode instance
getPolicyBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
.common.Policy policy = 2 [json_name = "policy"];
getPolicyBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Policy endorsement policy for the chaincode instance
getPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
.common.Policy policy = 2 [json_name = "policy"];
getPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
.common.Policy policy = 2 [json_name = "policy"];
getPolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.ConfigPolicyOrBuilder
.common.Policy policy = 2 [json_name = "policy"];
getPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Policy endorsement policy for the chaincode instance
getPolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Policy endorsement policy for the chaincode instance
getPolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Policy endorsement policy for the chaincode instance
getPolicyRef() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
The policy name to use for this API
getPolicyRef() - Method in class org.hyperledger.fabric.protos.peer.APIResource
The policy name to use for this API
getPolicyRef() - Method in interface org.hyperledger.fabric.protos.peer.APIResourceOrBuilder
The policy name to use for this API
getPolicyRefBytes() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
The policy name to use for this API
getPolicyRefBytes() - Method in class org.hyperledger.fabric.protos.peer.APIResource
The policy name to use for this API
getPolicyRefBytes() - Method in interface org.hyperledger.fabric.protos.peer.APIResourceOrBuilder
The policy name to use for this API
getPort() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
uint32 port = 2 [json_name = "port"];
getPort() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
uint32 port = 2 [json_name = "port"];
getPort() - Method in interface org.hyperledger.fabric.protos.discovery.EndpointOrBuilder
uint32 port = 2 [json_name = "port"];
getPort() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
uint32 port = 2 [json_name = "port"];
getPort() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
uint32 port = 2 [json_name = "port"];
getPort() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConsenterOrBuilder
uint32 port = 2 [json_name = "port"];
getPort() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
The port number
getPort() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
The port number
getPort() - Method in interface org.hyperledger.fabric.protos.peer.AnchorPeerOrBuilder
The port number
getPreferredMaxBytes() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
The byte count of the serialized messages in a batch should not exceed this value.
getPreferredMaxBytes() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
The byte count of the serialized messages in a batch should not exceed this value.
getPreferredMaxBytes() - Method in interface org.hyperledger.fabric.protos.orderer.BatchSizeOrBuilder
The byte count of the serialized messages in a batch should not exceed this value.
getPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
getPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
getPreparedTransaction() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseResponseOrBuilder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
getPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
The signed set of endorsed transaction responses to submit.
getPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
The signed set of endorsed transaction responses to submit.
getPreparedTransaction() - Method in interface org.hyperledger.fabric.protos.gateway.SubmitRequestOrBuilder
The signed set of endorsed transaction responses to submit.
getPreparedTransactionBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
getPreparedTransactionBuilder() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
The signed set of endorsed transaction responses to submit.
getPreparedTransactionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
getPreparedTransactionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
getPreparedTransactionOrBuilder() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseResponseOrBuilder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
getPreparedTransactionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
The signed set of endorsed transaction responses to submit.
getPreparedTransactionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
The signed set of endorsed transaction responses to submit.
getPreparedTransactionOrBuilder() - Method in interface org.hyperledger.fabric.protos.gateway.SubmitRequestOrBuilder
The signed set of endorsed transaction responses to submit.
getPreviousBlockHash() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
bytes previousBlockHash = 3 [json_name = "previousBlockHash"];
getPreviousBlockHash() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
bytes previousBlockHash = 3 [json_name = "previousBlockHash"];
getPreviousBlockHash() - Method in interface org.hyperledger.fabric.protos.common.BlockchainInfoOrBuilder
bytes previousBlockHash = 3 [json_name = "previousBlockHash"];
getPreviousHash() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The hash of the previous block header
getPreviousHash() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
The hash of the previous block header
getPreviousHash() - Method in interface org.hyperledger.fabric.protos.common.BlockHeaderOrBuilder
The hash of the previous block header
getPrincipal() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
Principal completes the policy principal definition.
getPrincipal() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
Principal completes the policy principal definition.
getPrincipal() - Method in interface org.hyperledger.fabric.protos.common.MSPPrincipalOrBuilder
Principal completes the policy principal definition.
getPrincipalClassification() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
Classification describes the way that one should process Principal.
getPrincipalClassification() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
Classification describes the way that one should process Principal.
getPrincipalClassification() - Method in interface org.hyperledger.fabric.protos.common.MSPPrincipalOrBuilder
Classification describes the way that one should process Principal.
getPrincipalClassificationValue() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
Classification describes the way that one should process Principal.
getPrincipalClassificationValue() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
Classification describes the way that one should process Principal.
getPrincipalClassificationValue() - Method in interface org.hyperledger.fabric.protos.common.MSPPrincipalOrBuilder
Classification describes the way that one should process Principal.
getPrincipals(int) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
getPrincipals(int) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
Principals refer to combined principals
getPrincipals(int) - Method in interface org.hyperledger.fabric.protos.common.CombinedPrincipalOrBuilder
Principals refer to combined principals
getPrincipalsBuilder(int) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
getPrincipalsBuilderList() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
getPrincipalsCount() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
getPrincipalsCount() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
Principals refer to combined principals
getPrincipalsCount() - Method in interface org.hyperledger.fabric.protos.common.CombinedPrincipalOrBuilder
Principals refer to combined principals
getPrincipalsList() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
getPrincipalsList() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
Principals refer to combined principals
getPrincipalsList() - Method in interface org.hyperledger.fabric.protos.common.CombinedPrincipalOrBuilder
Principals refer to combined principals
getPrincipalsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
getPrincipalsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
Principals refer to combined principals
getPrincipalsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.common.CombinedPrincipalOrBuilder
Principals refer to combined principals
getPrincipalsOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
getPrincipalsOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
Principals refer to combined principals
getPrincipalsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.common.CombinedPrincipalOrBuilder
Principals refer to combined principals
getPrivateData() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Encapsulates private data used to distribute private rwset after the endorsement
getPrivateData() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Encapsulates private data used to distribute private rwset after the endorsement
getPrivateData() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Encapsulates private data used to distribute private rwset after the endorsement
getPrivateData(int) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateData(int) - Method in class org.hyperledger.fabric.protos.gossip.Payload
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateData(int) - Method in interface org.hyperledger.fabric.protos.gossip.PayloadOrBuilder
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateDataBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Encapsulates private data used to distribute private rwset after the endorsement
getPrivateDataCount() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateDataCount() - Method in class org.hyperledger.fabric.protos.gossip.Payload
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateDataCount() - Method in interface org.hyperledger.fabric.protos.gossip.PayloadOrBuilder
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateDataList() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateDataList() - Method in class org.hyperledger.fabric.protos.gossip.Payload
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateDataList() - Method in interface org.hyperledger.fabric.protos.gossip.PayloadOrBuilder
repeated bytes private_data = 3 [json_name = "privateData"];
getPrivateDataMap() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
Deprecated.
getPrivateDataMap() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
Deprecated.
getPrivateDataMap() - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
Deprecated.
getPrivateDataMapCount() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
getPrivateDataMapCount() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
getPrivateDataMapCount() - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapMap() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapMap() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapMap() - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapOrDefault(long, TxPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapOrDefault(long, TxPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapOrDefault(long, TxPvtReadWriteSet) - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapOrThrow(long) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapOrThrow(long) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataMapOrThrow(long) - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
getPrivateDataOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Encapsulates private data used to distribute private rwset after the endorsement
getPrivateDataOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Encapsulates private data used to distribute private rwset after the endorsement
getPrivateDataOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Encapsulates private data used to distribute private rwset after the endorsement
getPrivateReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to request private data
getPrivateReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to request private data
getPrivateReq() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to request private data
getPrivateReqBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to request private data
getPrivateReqOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to request private data
getPrivateReqOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to request private data
getPrivateReqOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to request private data
getPrivateRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to respond to private data requests
getPrivateRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to respond to private data requests
getPrivateRes() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to respond to private data requests
getPrivateResBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to respond to private data requests
getPrivateResOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to respond to private data requests
getPrivateResOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to respond to private data requests
getPrivateResOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to respond to private data requests
getPrivateRwset() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
bytes private_rwset = 4 [json_name = "privateRwset"];
getPrivateRwset() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
bytes private_rwset = 4 [json_name = "privateRwset"];
getPrivateRwset() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
bytes private_rwset = 4 [json_name = "privateRwset"];
getPrivateSigner() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PrivateSigner denotes a reference to the private key of the peer's signing identity
getPrivateSigner() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
PrivateSigner denotes a reference to the private key of the peer's signing identity
getPrivateSigner() - Method in interface org.hyperledger.fabric.protos.msp.SigningIdentityInfoOrBuilder
PrivateSigner denotes a reference to the private key of the peer's signing identity
getPrivateSignerBuilder() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PrivateSigner denotes a reference to the private key of the peer's signing identity
getPrivateSignerOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PrivateSigner denotes a reference to the private key of the peer's signing identity
getPrivateSignerOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
PrivateSigner denotes a reference to the private key of the peer's signing identity
getPrivateSignerOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.SigningIdentityInfoOrBuilder
PrivateSigner denotes a reference to the private key of the peer's signing identity
getPrivateSimHeight() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
uint64 private_sim_height = 5 [json_name = "privateSimHeight"];
getPrivateSimHeight() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
uint64 private_sim_height = 5 [json_name = "privateSimHeight"];
getPrivateSimHeight() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
uint64 private_sim_height = 5 [json_name = "privateSimHeight"];
getProbe() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bool probe = 4 [json_name = "probe"];
getProbe() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
bool probe = 4 [json_name = "probe"];
getProbe() - Method in interface org.hyperledger.fabric.protos.gossip.ConnEstablishOrBuilder
bool probe = 4 [json_name = "probe"];
getProcessProposalMethod() - Static method in class org.hyperledger.fabric.protos.peer.EndorserGrpc
 
getProof() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
proof contains the cryptographic evidence that this identity is valid
getProof() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
proof contains the cryptographic evidence that this identity is valid
getProof() - Method in interface org.hyperledger.fabric.protos.msp.SerializedIdemixIdentityOrBuilder
proof contains the cryptographic evidence that this identity is valid
getProperties() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.Properties properties = 5 [json_name = "properties"];
getProperties() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
.gossip.Properties properties = 5 [json_name = "properties"];
getProperties() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoOrBuilder
.gossip.Properties properties = 5 [json_name = "properties"];
getPropertiesBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.Properties properties = 5 [json_name = "properties"];
getPropertiesOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.Properties properties = 5 [json_name = "properties"];
getPropertiesOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
.gossip.Properties properties = 5 [json_name = "properties"];
getPropertiesOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoOrBuilder
.gossip.Properties properties = 5 [json_name = "properties"];
getProposal() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The signed proposal.
getProposal() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
The signed proposal.
getProposal() - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
The signed proposal.
getProposal() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
getProposal() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
getProposal() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
getProposalBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The signed proposal.
getProposalBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
getProposalBytes() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
The bytes of Proposal
getProposalBytes() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
The bytes of Proposal
getProposalBytes() - Method in interface org.hyperledger.fabric.protos.peer.SignedProposalOrBuilder
The bytes of Proposal
getProposalHash() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
Hash of the proposal that triggered this response.
getProposalHash() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
Hash of the proposal that triggered this response.
getProposalHash() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponsePayloadOrBuilder
Hash of the proposal that triggered this response.
getProposalOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The signed proposal.
getProposalOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
The signed proposal.
getProposalOrBuilder() - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
The signed proposal.
getProposalOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
getProposalOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
getProposalOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
getProposalResponsePayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
This is the bytes of the ProposalResponsePayload message signed by the endorsers.
getProposalResponsePayload() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
This is the bytes of the ProposalResponsePayload message signed by the endorsers.
getProposalResponsePayload() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEndorsedActionOrBuilder
This is the bytes of the ProposalResponsePayload message signed by the endorsers.
getProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The signed proposal ready for endorsement.
getProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
The signed proposal ready for endorsement.
getProposedTransaction() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
The signed proposal ready for endorsement.
getProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
The signed proposal ready for evaluation.
getProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
The signed proposal ready for evaluation.
getProposedTransaction() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
The signed proposal ready for evaluation.
getProposedTransactionBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The signed proposal ready for endorsement.
getProposedTransactionBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
The signed proposal ready for evaluation.
getProposedTransactionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The signed proposal ready for endorsement.
getProposedTransactionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
The signed proposal ready for endorsement.
getProposedTransactionOrBuilder() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
The signed proposal ready for endorsement.
getProposedTransactionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
The signed proposal ready for evaluation.
getProposedTransactionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
The signed proposal ready for evaluation.
getProposedTransactionOrBuilder() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
The signed proposal ready for evaluation.
getPublicSigner() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PublicSigner carries the public information of the signing identity.
getPublicSigner() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
PublicSigner carries the public information of the signing identity.
getPublicSigner() - Method in interface org.hyperledger.fabric.protos.msp.SigningIdentityInfoOrBuilder
PublicSigner carries the public information of the signing identity.
getPvtRwset() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
getPvtRwset() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
getPvtRwset() - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
getPvtRwsetBuilder() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
getPvtRwsetHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
Hash of entire private read-write set for a specific collection.
getPvtRwsetHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
Hash of entire private read-write set for a specific collection.
getPvtRwsetHash() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSetOrBuilder
Hash of entire private read-write set for a specific collection.
getPvtRwsetOrBuilder() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
getPvtRwsetOrBuilder() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
getPvtRwsetOrBuilder() - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
getQuantitiesByGroup() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Deprecated.
getQuantitiesByGroup() - Method in class org.hyperledger.fabric.protos.discovery.Layout
Deprecated.
getQuantitiesByGroup() - Method in interface org.hyperledger.fabric.protos.discovery.LayoutOrBuilder
Deprecated.
getQuantitiesByGroupCount() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
getQuantitiesByGroupCount() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
getQuantitiesByGroupCount() - Method in interface org.hyperledger.fabric.protos.discovery.LayoutOrBuilder
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupMap() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupMap() - Method in class org.hyperledger.fabric.protos.discovery.Layout
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupMap() - Method in interface org.hyperledger.fabric.protos.discovery.LayoutOrBuilder
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupOrDefault(String, int) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupOrDefault(String, int) - Method in class org.hyperledger.fabric.protos.discovery.Layout
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupOrDefault(String, int) - Method in interface org.hyperledger.fabric.protos.discovery.LayoutOrBuilder
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupOrThrow(String) - Method in class org.hyperledger.fabric.protos.discovery.Layout
Specifies how many non repeated signatures of each group are needed for endorsement
getQuantitiesByGroupOrThrow(String) - Method in interface org.hyperledger.fabric.protos.discovery.LayoutOrBuilder
Specifies how many non repeated signatures of each group are needed for endorsement
getQueries(int) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
getQueries(int) - Method in class org.hyperledger.fabric.protos.discovery.Request
queries
getQueries(int) - Method in interface org.hyperledger.fabric.protos.discovery.RequestOrBuilder
queries
getQueriesBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
getQueriesBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
getQueriesCount() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
getQueriesCount() - Method in class org.hyperledger.fabric.protos.discovery.Request
queries
getQueriesCount() - Method in interface org.hyperledger.fabric.protos.discovery.RequestOrBuilder
queries
getQueriesList() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
getQueriesList() - Method in class org.hyperledger.fabric.protos.discovery.Request
queries
getQueriesList() - Method in interface org.hyperledger.fabric.protos.discovery.RequestOrBuilder
queries
getQueriesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
getQueriesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Request
queries
getQueriesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.discovery.RequestOrBuilder
queries
getQueriesOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
getQueriesOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Request
queries
getQueriesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.discovery.RequestOrBuilder
queries
getQuery() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string query = 1 [json_name = "query"];
getQuery() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
string query = 1 [json_name = "query"];
getQuery() - Method in interface org.hyperledger.fabric.protos.peer.GetQueryResultOrBuilder
string query = 1 [json_name = "query"];
getQueryBytes() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string query = 1 [json_name = "query"];
getQueryBytes() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
string query = 1 [json_name = "query"];
getQueryBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetQueryResultOrBuilder
string query = 1 [json_name = "query"];
getQueryCase() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
getQueryCase() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
getQueryCase() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
 
getQueryPendingsMethod() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc
 
GetQueryResult - Class in org.hyperledger.fabric.protos.peer
GetQueryResult is the payload of a ChaincodeMessage.
GetQueryResult.Builder - Class in org.hyperledger.fabric.protos.peer
GetQueryResult is the payload of a ChaincodeMessage.
GetQueryResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
getRaftIndex() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Index of etcd/raft entry for current block.
getRaftIndex() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
Index of etcd/raft entry for current block.
getRaftIndex() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadataOrBuilder
Index of etcd/raft entry for current block.
getRangeQueriesInfo(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfo(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfo(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRangeQueriesInfoOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
getRawReads() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
getRawReads() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
getRawReads() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
getRawReadsBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
getRawReadsOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
getRawReadsOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
getRawReadsOrBuilder() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
getReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReads(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
getReadSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
getReadSet() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
getReadSetBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
getReadSetOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
getReadSetOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
getReadSetOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
getReadsInfoCase() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
getReadsInfoCase() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
getReadsInfoCase() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
 
getReadsList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsMerkleHashes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
getReadsMerkleHashes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
getReadsMerkleHashes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
getReadsMerkleHashesBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
getReadsMerkleHashesOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
getReadsMerkleHashesOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
getReadsMerkleHashesOrBuilder() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
getReadsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReadsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
getReferences() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
Deprecated.
getReferences() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
Deprecated.
getReferences() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
Deprecated.
getReferences() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
Deprecated.
getReferences() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
Deprecated.
getReferences() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
Deprecated.
getReferencesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
getReferencesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
getReferencesCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
getReferencesCount() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
getReferencesCount() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesMap() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesMap() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesMap() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesMap() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesMap() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesMap() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesOrDefault(String, QueryInstalledChaincodeResult.References) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesOrDefault(String, QueryInstalledChaincodeResult.References) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesOrDefault(String, QueryInstalledChaincodeResult.References) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesOrDefault(String, QueryInstalledChaincodesResult.References) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesOrDefault(String, QueryInstalledChaincodesResult.References) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesOrDefault(String, QueryInstalledChaincodesResult.References) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesOrThrow(String) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResultOrBuilder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
getReferencesOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getReferencesOrThrow(String) - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
getRegisterMethod() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc
 
getRegular() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
getRegular() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
getRegular() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
getRegularBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
getRegularOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
getRegularOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
getRegularOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
getRequest() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
Serialized ChaincodeEventsRequest message.
getRequest() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
Serialized ChaincodeEventsRequest message.
getRequest() - Method in interface org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequestOrBuilder
Serialized ChaincodeEventsRequest message.
getRequest() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
Serialized CommitStatusRequest message.
getRequest() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
Serialized CommitStatusRequest message.
getRequest() - Method in interface org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequestOrBuilder
Serialized CommitStatusRequest message.
getRequest() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
The bytes of SnapshotRequest or SnapshotQuery
getRequest() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
The bytes of SnapshotRequest or SnapshotQuery
getRequest() - Method in interface org.hyperledger.fabric.protos.peer.SignedSnapshotRequestOrBuilder
The bytes of SnapshotRequest or SnapshotQuery
getRequiredPeerCount() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The minimum number of peers private data will be sent to upon endorsement.
getRequiredPeerCount() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
The minimum number of peers private data will be sent to upon endorsement.
getRequiredPeerCount() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
The minimum number of peers private data will be sent to upon endorsement.
getRequiredPeerCount() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The minimum number of peers private data will be sent to upon endorsement.
getRequiredPeerCount() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
The minimum number of peers private data will be sent to upon endorsement.
getRequiredPeerCount() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
The minimum number of peers private data will be sent to upon endorsement.
getResourcesConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
getResourcesConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
getResourcesConfig() - Method in interface org.hyperledger.fabric.protos.peer.ConfigTreeOrBuilder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
getResourcesConfigBuilder() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
getResourcesConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
getResourcesConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
getResourcesConfigOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ConfigTreeOrBuilder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
getResponse() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the result of executing this invocation.
getResponse() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
This field contains the result of executing this invocation.
getResponse() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionOrBuilder
This field contains the result of executing this invocation.
getResponse() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
A response message indicating whether the endorsement of the action was successful
getResponse() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
A response message indicating whether the endorsement of the action was successful
getResponse() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
A response message indicating whether the endorsement of the action was successful
getResponseBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the result of executing this invocation.
getResponseBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
A response message indicating whether the endorsement of the action was successful
getResponseOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the result of executing this invocation.
getResponseOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
This field contains the result of executing this invocation.
getResponseOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionOrBuilder
This field contains the result of executing this invocation.
getResponseOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
A response message indicating whether the endorsement of the action was successful
getResponseOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
A response message indicating whether the endorsement of the action was successful
getResponseOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
A response message indicating whether the endorsement of the action was successful
getResult() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
The result of the transaction commit, as defined in peer/transaction.proto.
getResult() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
The result of the transaction commit, as defined in peer/transaction.proto.
getResult() - Method in interface org.hyperledger.fabric.protos.gateway.CommitStatusResponseOrBuilder
The result of the transaction commit, as defined in peer/transaction.proto.
getResult() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
getResult() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
getResult() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateResponseOrBuilder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
getResultBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
getResultBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
bytes resultBytes = 1 [json_name = "resultBytes"];
getResultBytes() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
bytes resultBytes = 1 [json_name = "resultBytes"];
getResultBytes() - Method in interface org.hyperledger.fabric.protos.peer.QueryResultBytesOrBuilder
bytes resultBytes = 1 [json_name = "resultBytes"];
getResultCase() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
getResultCase() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
getResultCase() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
 
getResultOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
getResultOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
getResultOrBuilder() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateResponseOrBuilder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
getResults(int) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
getResults(int) - Method in class org.hyperledger.fabric.protos.discovery.Response
The results are returned in the same order of the queries
getResults(int) - Method in interface org.hyperledger.fabric.protos.discovery.ResponseOrBuilder
The results are returned in the same order of the queries
getResults() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the read set and the write set produced by the chaincode executing this invocation.
getResults() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
This field contains the read set and the write set produced by the chaincode executing this invocation.
getResults() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionOrBuilder
This field contains the read set and the write set produced by the chaincode executing this invocation.
getResults(int) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResults(int) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResults(int) - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
getResultsBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
getResultsBuilderList() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsCount() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
getResultsCount() - Method in class org.hyperledger.fabric.protos.discovery.Response
The results are returned in the same order of the queries
getResultsCount() - Method in interface org.hyperledger.fabric.protos.discovery.ResponseOrBuilder
The results are returned in the same order of the queries
getResultsCount() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsCount() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsCount() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsList() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
getResultsList() - Method in class org.hyperledger.fabric.protos.discovery.Response
The results are returned in the same order of the queries
getResultsList() - Method in interface org.hyperledger.fabric.protos.discovery.ResponseOrBuilder
The results are returned in the same order of the queries
getResultsList() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsList() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsList() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
getResultsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.discovery.Response
The results are returned in the same order of the queries
getResultsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.discovery.ResponseOrBuilder
The results are returned in the same order of the queries
getResultsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsOrBuilder(int) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
getResultsOrBuilderList() - Method in class org.hyperledger.fabric.protos.discovery.Response
The results are returned in the same order of the queries
getResultsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.discovery.ResponseOrBuilder
The results are returned in the same order of the queries
getResultsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsOrBuilderList() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultsOrBuilderList() - Method in interface org.hyperledger.fabric.protos.peer.QueryResponseOrBuilder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
getResultValue() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
The result of the transaction commit, as defined in peer/transaction.proto.
getResultValue() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
The result of the transaction commit, as defined in peer/transaction.proto.
getResultValue() - Method in interface org.hyperledger.fabric.protos.gateway.CommitStatusResponseOrBuilder
The result of the transaction commit, as defined in peer/transaction.proto.
getRevocationList(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity revocation list
getRevocationList(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
Identity revocation list
getRevocationList(int) - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
Identity revocation list
getRevocationListCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity revocation list
getRevocationListCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
Identity revocation list
getRevocationListCount() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
Identity revocation list
getRevocationListList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity revocation list
getRevocationListList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
Identity revocation list
getRevocationListList() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
Identity revocation list
getRevocationPk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
revocation_pk is the public key used for revocation of credentials
getRevocationPk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
revocation_pk is the public key used for revocation of credentials
getRevocationPk() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPConfigOrBuilder
revocation_pk is the public key used for revocation of credentials
getRole() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
getRole() - Method in class org.hyperledger.fabric.protos.common.MSPRole
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
getRole() - Method in interface org.hyperledger.fabric.protos.common.MSPRoleOrBuilder
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
getRole() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
role defines whether the default signer is admin, peer, member or client
getRole() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
role defines whether the default signer is admin, peer, member or client
getRole() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfigOrBuilder
role defines whether the default signer is admin, peer, member or client
getRole() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
role contains the role of this identity (e.g., ADMIN or MEMBER)
getRole() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
role contains the role of this identity (e.g., ADMIN or MEMBER)
getRole() - Method in interface org.hyperledger.fabric.protos.msp.SerializedIdemixIdentityOrBuilder
role contains the role of this identity (e.g., ADMIN or MEMBER)
getRoleValue() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
getRoleValue() - Method in class org.hyperledger.fabric.protos.common.MSPRole
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
getRoleValue() - Method in interface org.hyperledger.fabric.protos.common.MSPRoleOrBuilder
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
getRootCerts(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRootCerts(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRootCerts(int) - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRootCertsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRootCertsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRootCertsCount() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRootCertsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRootCertsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRootCertsList() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
getRule() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
getRule() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
getRule() - Method in interface org.hyperledger.fabric.protos.common.ImplicitMetaPolicyOrBuilder
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
getRule() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
getRule() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
.common.SignaturePolicy rule = 2 [json_name = "rule"];
getRule() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
getRuleBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
getRuleOrBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
getRuleOrBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
.common.SignaturePolicy rule = 2 [json_name = "rule"];
getRuleOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
getRules(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRules(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRules(int) - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOfOrBuilder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesBuilder(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesBuilderList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesCount() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesCount() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesCount() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOfOrBuilder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesList() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOfOrBuilder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOfOrBuilder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRulesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOfOrBuilder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
getRuleValue() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
getRuleValue() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
getRuleValue() - Method in interface org.hyperledger.fabric.protos.common.ImplicitMetaPolicyOrBuilder
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
getRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
getRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
getRwset() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSetOrBuilder
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
getRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
getRwset() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
getRwset() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSetOrBuilder
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
getSecretEnvelope() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
getSecretEnvelope() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
getSecretEnvelope() - Method in interface org.hyperledger.fabric.protos.gossip.EnvelopeOrBuilder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
getSecretEnvelopeBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
getSecretEnvelopeOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
getSecretEnvelopeOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
getSecretEnvelopeOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.EnvelopeOrBuilder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
getSelfInformation() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
getSelfInformation() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
getSelfInformation() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipRequestOrBuilder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
getSelfInformationBuilder() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
getSelfInformationOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
getSelfInformationOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
getSelfInformationOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipRequestOrBuilder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
getSeqInBlock() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
uint64 seq_in_block = 5 [json_name = "seqInBlock"];
getSeqInBlock() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
uint64 seq_in_block = 5 [json_name = "seqInBlock"];
getSeqInBlock() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataDigestOrBuilder
uint64 seq_in_block = 5 [json_name = "seqInBlock"];
getSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
uint64 seq_num = 1 [json_name = "seqNum"];
getSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.Payload
uint64 seq_num = 1 [json_name = "seqNum"];
getSeqNum() - Method in interface org.hyperledger.fabric.protos.gossip.PayloadOrBuilder
uint64 seq_num = 1 [json_name = "seqNum"];
getSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
uint64 seq_num = 2 [json_name = "seqNum"];
getSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
uint64 seq_num = 2 [json_name = "seqNum"];
getSeqNum() - Method in interface org.hyperledger.fabric.protos.gossip.PeerTimeOrBuilder
uint64 seq_num = 2 [json_name = "seqNum"];
getSequence() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
uint64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.common.Config
uint64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in interface org.hyperledger.fabric.protos.common.ConfigOrBuilder
uint64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
int64 sequence = 2 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
int64 sequence = 2 [json_name = "sequence"];
getSequence() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgsOrBuilder
int64 sequence = 2 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
int64 sequence = 1 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
int64 sequence = 2 [json_name = "sequence"];
getSequence() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
int64 sequence = 2 [json_name = "sequence"];
getSequence() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
int64 sequence = 2 [json_name = "sequence"];
getSerializedSize() - Method in class com.google.rpc.Status
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Block
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.BlockData
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Capability
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Config
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Consortium
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Envelope
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Header
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Metadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Payload
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.Policy
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Error
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Request
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.Response
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.Member
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.DelState
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.GetState
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.PutState
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.Response
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
getSerializedSize() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
getServerTlsCert() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
bytes server_tls_cert = 4 [json_name = "serverTlsCert"];
getServerTlsCert() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
bytes server_tls_cert = 4 [json_name = "serverTlsCert"];
getServerTlsCert() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConsenterOrBuilder
bytes server_tls_cert = 4 [json_name = "serverTlsCert"];
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.gossip.GossipGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.orderer.ClusterGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.DeliverGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.EndorserGrpc
 
getServiceDescriptor() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc
 
getSignature() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
Signature over the concatenation signatureHeader bytes and config bytes
getSignature() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
Signature over the concatenation signatureHeader bytes and config bytes
getSignature() - Method in interface org.hyperledger.fabric.protos.common.ConfigSignatureOrBuilder
Signature over the concatenation signatureHeader bytes and config bytes
getSignature() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
A signature by the creator specified in the Payload header
getSignature() - Method in class org.hyperledger.fabric.protos.common.Envelope
A signature by the creator specified in the Payload header
getSignature() - Method in interface org.hyperledger.fabric.protos.common.EnvelopeOrBuilder
A signature by the creator specified in the Payload header
getSignature() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
The signature over the concatenation of the Metadata value bytes, signatureHeader, and block header
getSignature() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
The signature over the concatenation of the Metadata value bytes, signatureHeader, and block header
getSignature() - Method in interface org.hyperledger.fabric.protos.common.MetadataSignatureOrBuilder
The signature over the concatenation of the Metadata value bytes, signatureHeader, and block header
getSignature() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in interface org.hyperledger.fabric.protos.discovery.SignedRequestOrBuilder
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
Signature for request message.
getSignature() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
Signature for request message.
getSignature() - Method in interface org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequestOrBuilder
Signature for request message.
getSignature() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
Signature for request message.
getSignature() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
Signature for request message.
getSignature() - Method in interface org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequestOrBuilder
Signature for request message.
getSignature() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in interface org.hyperledger.fabric.protos.gossip.EnvelopeOrBuilder
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in interface org.hyperledger.fabric.protos.gossip.SecretEnvelopeOrBuilder
bytes signature = 2 [json_name = "signature"];
getSignature() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
Signature of the payload included in ProposalResponse concatenated with the endorser's certificate; ie, sign(ProposalResponse.payload + endorser)
getSignature() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
Signature of the payload included in ProposalResponse concatenated with the endorser's certificate; ie, sign(ProposalResponse.payload + endorser)
getSignature() - Method in interface org.hyperledger.fabric.protos.peer.EndorsementOrBuilder
Signature of the payload included in ProposalResponse concatenated with the endorser's certificate; ie, sign(ProposalResponse.payload + endorser)
getSignature() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
Signaure over proposalBytes; this signature is to be verified against the creator identity contained in the header of the Proposal message marshaled as proposalBytes
getSignature() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
Signaure over proposalBytes; this signature is to be verified against the creator identity contained in the header of the Proposal message marshaled as proposalBytes
getSignature() - Method in interface org.hyperledger.fabric.protos.peer.SignedProposalOrBuilder
Signaure over proposalBytes; this signature is to be verified against the creator identity contained in the header of the Proposal message marshaled as proposalBytes
getSignature() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
Signaure over request bytes; this signature is to be verified against the client identity
getSignature() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
Signaure over request bytes; this signature is to be verified against the client identity
getSignature() - Method in interface org.hyperledger.fabric.protos.peer.SignedSnapshotRequestOrBuilder
Signaure over request bytes; this signature is to be verified against the client identity
getSignatureHashFamily() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
getSignatureHashFamily() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
getSignatureHashFamily() - Method in interface org.hyperledger.fabric.protos.msp.FabricCryptoConfigOrBuilder
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
getSignatureHashFamilyBytes() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
getSignatureHashFamilyBytes() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
getSignatureHashFamilyBytes() - Method in interface org.hyperledger.fabric.protos.msp.FabricCryptoConfigOrBuilder
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
A marshaled SignatureHeader
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
A marshaled SignatureHeader
getSignatureHeader() - Method in interface org.hyperledger.fabric.protos.common.ConfigSignatureOrBuilder
A marshaled SignatureHeader
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
bytes signature_header = 2 [json_name = "signatureHeader"];
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.Header
bytes signature_header = 2 [json_name = "signatureHeader"];
getSignatureHeader() - Method in interface org.hyperledger.fabric.protos.common.HeaderOrBuilder
bytes signature_header = 2 [json_name = "signatureHeader"];
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
An encoded SignatureHeader
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
An encoded SignatureHeader
getSignatureHeader() - Method in interface org.hyperledger.fabric.protos.common.MetadataSignatureOrBuilder
An encoded SignatureHeader
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The signature header that contains creator identity and nonce
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
The signature header that contains creator identity and nonce
getSignatureHeader() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotQueryOrBuilder
The signature header that contains creator identity and nonce
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The signature header that contains creator identity and nonce
getSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
The signature header that contains creator identity and nonce
getSignatureHeader() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotRequestOrBuilder
The signature header that contains creator identity and nonce
getSignatureHeaderBuilder() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The signature header that contains creator identity and nonce
getSignatureHeaderBuilder() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The signature header that contains creator identity and nonce
getSignatureHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The signature header that contains creator identity and nonce
getSignatureHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
The signature header that contains creator identity and nonce
getSignatureHeaderOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotQueryOrBuilder
The signature header that contains creator identity and nonce
getSignatureHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The signature header that contains creator identity and nonce
getSignatureHeaderOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
The signature header that contains creator identity and nonce
getSignatureHeaderOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotRequestOrBuilder
The signature header that contains creator identity and nonce
getSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicy() - Method in interface org.hyperledger.fabric.protos.common.ApplicationPolicyOrBuilder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
Initially, only a signature policy is supported.
getSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
Initially, only a signature policy is supported.
getSignaturePolicy() - Method in interface org.hyperledger.fabric.protos.common.CollectionPolicyConfigOrBuilder
Deprecated.
Initially, only a signature policy is supported.
getSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicy() - Method in interface org.hyperledger.fabric.protos.peer.ApplicationPolicyOrBuilder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
Initially, only a signature policy is supported.
getSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
Initially, only a signature policy is supported.
getSignaturePolicy() - Method in interface org.hyperledger.fabric.protos.peer.CollectionPolicyConfigOrBuilder
Initially, only a signature policy is supported.
getSignaturePolicyBuilder() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicyBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
Initially, only a signature policy is supported.
getSignaturePolicyBuilder() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicyBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
Initially, only a signature policy is supported.
getSignaturePolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.ApplicationPolicyOrBuilder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
Initially, only a signature policy is supported.
getSignaturePolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
Initially, only a signature policy is supported.
getSignaturePolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.CollectionPolicyConfigOrBuilder
Deprecated.
Initially, only a signature policy is supported.
getSignaturePolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ApplicationPolicyOrBuilder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
getSignaturePolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
Initially, only a signature policy is supported.
getSignaturePolicyOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
Initially, only a signature policy is supported.
getSignaturePolicyOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.CollectionPolicyConfigOrBuilder
Initially, only a signature policy is supported.
getSignatures(int) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
getSignatures(int) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
Signatures over the config_update
getSignatures(int) - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateEnvelopeOrBuilder
Signatures over the config_update
getSignatures(int) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignatures(int) - Method in class org.hyperledger.fabric.protos.common.Metadata
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignatures(int) - Method in interface org.hyperledger.fabric.protos.common.MetadataOrBuilder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesBuilder(int) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
getSignaturesBuilder(int) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesBuilderList() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
getSignaturesBuilderList() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesCount() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
getSignaturesCount() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
Signatures over the config_update
getSignaturesCount() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateEnvelopeOrBuilder
Signatures over the config_update
getSignaturesCount() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesCount() - Method in class org.hyperledger.fabric.protos.common.Metadata
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesCount() - Method in interface org.hyperledger.fabric.protos.common.MetadataOrBuilder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesList() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
getSignaturesList() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
Signatures over the config_update
getSignaturesList() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateEnvelopeOrBuilder
Signatures over the config_update
getSignaturesList() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesList() - Method in class org.hyperledger.fabric.protos.common.Metadata
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesList() - Method in interface org.hyperledger.fabric.protos.common.MetadataOrBuilder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
getSignaturesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
Signatures over the config_update
getSignaturesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateEnvelopeOrBuilder
Signatures over the config_update
getSignaturesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.common.Metadata
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.common.MetadataOrBuilder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
getSignaturesOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
Signatures over the config_update
getSignaturesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateEnvelopeOrBuilder
Signatures over the config_update
getSignaturesOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesOrBuilderList() - Method in class org.hyperledger.fabric.protos.common.Metadata
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignaturesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.common.MetadataOrBuilder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
getSignedBy() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
int32 signed_by = 1 [json_name = "signedBy"];
getSignedBy() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
int32 signed_by = 1 [json_name = "signedBy"];
getSignedBy() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyOrBuilder
int32 signed_by = 1 [json_name = "signedBy"];
getSigner() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
signer may contain crypto material to configure a default signer
getSigner() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
signer may contain crypto material to configure a default signer
getSigner() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPConfigOrBuilder
signer may contain crypto material to configure a default signer
getSignerBuilder() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
signer may contain crypto material to configure a default signer
getSignerOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
signer may contain crypto material to configure a default signer
getSignerOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
signer may contain crypto material to configure a default signer
getSignerOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPConfigOrBuilder
signer may contain crypto material to configure a default signer
getSigningIdentity() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
getSigningIdentity() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
getSigningIdentity() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
getSigningIdentityBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
getSigningIdentityOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
getSigningIdentityOrBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
getSigningIdentityOrBuilder() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
getSk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
sk is the secret key of the default signer, corresponding to credential Cred
getSk() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
sk is the secret key of the default signer, corresponding to credential Cred
getSk() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfigOrBuilder
sk is the secret key of the default signer, corresponding to credential Cred
getSnapshotIntervalSize() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
Take snapshot when cumulative data exceeds certain size in bytes.
getSnapshotIntervalSize() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
Take snapshot when cumulative data exceeds certain size in bytes.
getSnapshotIntervalSize() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.OptionsOrBuilder
Take snapshot when cumulative data exceeds certain size in bytes.
getSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
getSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
getSource() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
getSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
getSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
getSource() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
getSourceBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
getSourceBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
getSourceOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
getSourceOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
getSourceOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
getSourceOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
getSourceOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
getSourceOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
getSpecified() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
getSpecified() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
getSpecified() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
getSpecifiedBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
getSpecifiedOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
getSpecifiedOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
getSpecifiedOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
getStart() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to start the deliver from
getStart() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
The position to start the deliver from
getStart() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
The position to start the deliver from
getStartBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to start the deliver from
getStartKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string start_key = 1 [json_name = "startKey"];
getStartKey() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
string start_key = 1 [json_name = "startKey"];
getStartKey() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
string start_key = 1 [json_name = "startKey"];
getStartKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string startKey = 1 [json_name = "startKey"];
getStartKey() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
string startKey = 1 [json_name = "startKey"];
getStartKey() - Method in interface org.hyperledger.fabric.protos.peer.GetStateByRangeOrBuilder
string startKey = 1 [json_name = "startKey"];
getStartKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string start_key = 1 [json_name = "startKey"];
getStartKeyBytes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
string start_key = 1 [json_name = "startKey"];
getStartKeyBytes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
string start_key = 1 [json_name = "startKey"];
getStartKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string startKey = 1 [json_name = "startKey"];
getStartKeyBytes() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
string startKey = 1 [json_name = "startKey"];
getStartKeyBytes() - Method in interface org.hyperledger.fabric.protos.peer.GetStateByRangeOrBuilder
string startKey = 1 [json_name = "startKey"];
getStartOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to start the deliver from
getStartOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
The position to start the deliver from
getStartOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
The position to start the deliver from
getStartPosition() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Position within the ledger at which to start reading events.
getStartPosition() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Position within the ledger at which to start reading events.
getStartPosition() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Position within the ledger at which to start reading events.
getStartPositionBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Position within the ledger at which to start reading events.
getStartPositionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Position within the ledger at which to start reading events.
getStartPositionOrBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Position within the ledger at which to start reading events.
getStartPositionOrBuilder() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Position within the ledger at which to start reading events.
getStartSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
uint64 start_seq_num = 1 [json_name = "startSeqNum"];
getStartSeqNum() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
uint64 start_seq_num = 1 [json_name = "startSeqNum"];
getStartSeqNum() - Method in interface org.hyperledger.fabric.protos.gossip.RemoteStateRequestOrBuilder
uint64 start_seq_num = 1 [json_name = "startSeqNum"];
getState() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
getState() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
getState() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusTypeOrBuilder
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
GetState - Class in org.hyperledger.fabric.protos.peer
GetState is the payload of a ChaincodeMessage.
GetState.Builder - Class in org.hyperledger.fabric.protos.peer
GetState is the payload of a ChaincodeMessage.
GetStateByRange - Class in org.hyperledger.fabric.protos.peer
GetStateByRange is the payload of a ChaincodeMessage.
GetStateByRange.Builder - Class in org.hyperledger.fabric.protos.peer
GetStateByRange is the payload of a ChaincodeMessage.
GetStateByRangeOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
getStateInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
getStateInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer
This is an Envelope of a GossipMessage with a gossip.StateInfo message
getStateInfo() - Method in interface org.hyperledger.fabric.protos.discovery.PeerOrBuilder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
getStateInfo() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for relaying information about state
getStateInfo() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for relaying information about state
getStateInfo() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for relaying information about state
getStateInfoBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
getStateInfoBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for relaying information about state
getStateInfoOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
getStateInfoOrBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peer
This is an Envelope of a GossipMessage with a gossip.StateInfo message
getStateInfoOrBuilder() - Method in interface org.hyperledger.fabric.protos.discovery.PeerOrBuilder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
getStateInfoOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for relaying information about state
getStateInfoOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for relaying information about state
getStateInfoOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for relaying information about state
getStateInfoPullReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for asking for StateInfoSnapshots
getStateInfoPullReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for asking for StateInfoSnapshots
getStateInfoPullReq() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for asking for StateInfoSnapshots
getStateInfoPullReqBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for asking for StateInfoSnapshots
getStateInfoPullReqOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for asking for StateInfoSnapshots
getStateInfoPullReqOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for asking for StateInfoSnapshots
getStateInfoPullReqOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for asking for StateInfoSnapshots
GetStateMetadata - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.GetStateMetadata
GetStateMetadata.Builder - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.GetStateMetadata
GetStateMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
GetStateOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
getStateRequest() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to ask from a remote peer a set of blocks
getStateRequest() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to ask from a remote peer a set of blocks
getStateRequest() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to ask from a remote peer a set of blocks
getStateRequestBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to ask from a remote peer a set of blocks
getStateRequestOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to ask from a remote peer a set of blocks
getStateRequestOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to ask from a remote peer a set of blocks
getStateRequestOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to ask from a remote peer a set of blocks
getStateResponse() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to send a set of blocks to a remote peer
getStateResponse() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to send a set of blocks to a remote peer
getStateResponse() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to send a set of blocks to a remote peer
getStateResponseBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to send a set of blocks to a remote peer
getStateResponseOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to send a set of blocks to a remote peer
getStateResponseOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to send a set of blocks to a remote peer
getStateResponseOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to send a set of blocks to a remote peer
getStateSnapshot() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for sending sets of StateInfo messages
getStateSnapshot() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for sending sets of StateInfo messages
getStateSnapshot() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for sending sets of StateInfo messages
getStateSnapshotBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for sending sets of StateInfo messages
getStateSnapshotOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for sending sets of StateInfo messages
getStateSnapshotOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for sending sets of StateInfo messages
getStateSnapshotOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for sending sets of StateInfo messages
getStateValue() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
getStateValue() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
getStateValue() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusTypeOrBuilder
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
getStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfig() - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigOrBuilder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfig() - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigOrBuilder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfigBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfigBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfigOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigOrBuilder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfigOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStaticCollectionConfigOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigOrBuilder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
getStatus() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Status code, which may be used to programatically respond to success/failure
getStatus() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
Status code, which may be used to programatically respond to success/failure
getStatus() - Method in interface org.hyperledger.fabric.protos.orderer.BroadcastResponseOrBuilder
Status code, which may be used to programatically respond to success/failure
getStatus() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in interface org.hyperledger.fabric.protos.orderer.DeliverResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Status code, which may be used to programatically respond to success/failure.
getStatus() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
Status code, which may be used to programatically respond to success/failure.
getStatus() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitResponseOrBuilder
Status code, which may be used to programatically respond to success/failure.
getStatus() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
getStatus() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A status code that should follow the HTTP status codes.
getStatus() - Method in class org.hyperledger.fabric.protos.peer.Response
A status code that should follow the HTTP status codes.
getStatus() - Method in interface org.hyperledger.fabric.protos.peer.ResponseOrBuilder
A status code that should follow the HTTP status codes.
getStatusValue() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.common.Status status = 1 [json_name = "status"];
getStatusValue() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
.common.Status status = 1 [json_name = "status"];
getStatusValue() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
getStatusValue() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Status code, which may be used to programatically respond to success/failure
getStatusValue() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
Status code, which may be used to programatically respond to success/failure
getStatusValue() - Method in interface org.hyperledger.fabric.protos.orderer.BroadcastResponseOrBuilder
Status code, which may be used to programatically respond to success/failure
getStatusValue() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
getStatusValue() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
.common.Status status = 1 [json_name = "status"];
getStatusValue() - Method in interface org.hyperledger.fabric.protos.orderer.DeliverResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
getStatusValue() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Status code, which may be used to programatically respond to success/failure.
getStatusValue() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
Status code, which may be used to programatically respond to success/failure.
getStatusValue() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitResponseOrBuilder
Status code, which may be used to programatically respond to success/failure.
getStatusValue() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
getStatusValue() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.common.Status status = 1 [json_name = "status"];
getStatusValue() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
getStepMethod() - Static method in class org.hyperledger.fabric.protos.orderer.ClusterGrpc
 
getStop() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to stop the deliver
getStop() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
The position to stop the deliver
getStop() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
The position to stop the deliver
getStopBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to stop the deliver
getStopOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to stop the deliver
getStopOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
The position to stop the deliver
getStopOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
The position to stop the deliver
getString() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
string String = 3 [json_name = "String"];
getString() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
string String = 3 [json_name = "String"];
getString() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateDataOrBuilder
string String = 3 [json_name = "String"];
getStringBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
string String = 3 [json_name = "String"];
getStringBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
string String = 3 [json_name = "String"];
getStringBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateDataOrBuilder
string String = 3 [json_name = "String"];
getSubmitMethod() - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
 
getSubmitRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
submit_request is a relay of a transaction.
getSubmitRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
submit_request is a relay of a transaction.
getSubmitRequest() - Method in interface org.hyperledger.fabric.protos.orderer.StepRequestOrBuilder
submit_request is a relay of a transaction.
getSubmitRequestBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
submit_request is a relay of a transaction.
getSubmitRequestOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
submit_request is a relay of a transaction.
getSubmitRequestOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
submit_request is a relay of a transaction.
getSubmitRequestOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.StepRequestOrBuilder
submit_request is a relay of a transaction.
getSubmitRes() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
getSubmitRes() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
getSubmitRes() - Method in interface org.hyperledger.fabric.protos.orderer.StepResponseOrBuilder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
getSubmitResBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
getSubmitResOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
getSubmitResOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
getSubmitResOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.StepResponseOrBuilder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
getSubPolicy() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
string sub_policy = 1 [json_name = "subPolicy"];
getSubPolicy() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
string sub_policy = 1 [json_name = "subPolicy"];
getSubPolicy() - Method in interface org.hyperledger.fabric.protos.common.ImplicitMetaPolicyOrBuilder
string sub_policy = 1 [json_name = "subPolicy"];
getSubPolicyBytes() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
string sub_policy = 1 [json_name = "subPolicy"];
getSubPolicyBytes() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
string sub_policy = 1 [json_name = "subPolicy"];
getSubPolicyBytes() - Method in interface org.hyperledger.fabric.protos.common.ImplicitMetaPolicyOrBuilder
string sub_policy = 1 [json_name = "subPolicy"];
getTag() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
determines to which peers it is allowed to forward the message
getTag() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
determines to which peers it is allowed to forward the message
getTag() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
determines to which peers it is allowed to forward the message
getTagValue() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
determines to which peers it is allowed to forward the message
getTagValue() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
determines to which peers it is allowed to forward the message
getTagValue() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
determines to which peers it is allowed to forward the message
getTargetOrganizations(int) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
getTargetOrganizations(int) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
If targeting the peers of specific organizations (e.g.
getTargetOrganizations(int) - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsBytes(int) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsBytes(int) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsBytes(int) - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsCount() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsCount() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsCount() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsList() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsList() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
If targeting the peers of specific organizations (e.g.
getTargetOrganizationsList() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
If targeting the peers of specific organizations (e.g.
getTickInterval() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
time duration format, e.g.
getTickInterval() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
time duration format, e.g.
getTickInterval() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.OptionsOrBuilder
time duration format, e.g.
getTickIntervalBytes() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
time duration format, e.g.
getTickIntervalBytes() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
time duration format, e.g.
getTickIntervalBytes() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.OptionsOrBuilder
time duration format, e.g.
getTimeout() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
getTimeout() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
getTimeout() - Method in interface org.hyperledger.fabric.protos.orderer.BatchTimeoutOrBuilder
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
getTimeout() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
int32 timeout = 4 [json_name = "timeout"];
getTimeout() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
int32 timeout = 4 [json_name = "timeout"];
getTimeout() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
int32 timeout = 4 [json_name = "timeout"];
getTimeoutBytes() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
getTimeoutBytes() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
getTimeoutBytes() - Method in interface org.hyperledger.fabric.protos.orderer.BatchTimeoutOrBuilder
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
getTimestamp() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Timestamp is the local time when the message was created by the sender
getTimestamp() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
Timestamp is the local time when the message was created by the sender
getTimestamp() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
Timestamp is the local time when the message was created by the sender
getTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in interface org.hyperledger.fabric.protos.gossip.AliveMessageOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in interface org.hyperledger.fabric.protos.gossip.LeadershipMessageOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
getTimestamp() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KeyModificationOrBuilder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
getTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Timestamp is the time that the message was created as defined by the sender
getTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
Timestamp is the time that the message was created as defined by the sender
getTimestamp() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
Timestamp is the time that the message was created as defined by the sender
getTimestampBuilder() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Timestamp is the local time when the message was created by the sender
getTimestampBuilder() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampBuilder() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampBuilder() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
getTimestampBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
getTimestampBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Timestamp is the time that the message was created as defined by the sender
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Timestamp is the local time when the message was created by the sender
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
Timestamp is the local time when the message was created by the sender
getTimestampOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
Timestamp is the local time when the message was created by the sender
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.AliveMessageOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.LeadershipMessageOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KeyModificationOrBuilder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Timestamp is the time that the message was created as defined by the sender
getTimestampOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
Timestamp is the time that the message was created as defined by the sender
getTimestampOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
Timestamp is the time that the message was created as defined by the sender
getTimeToCut() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
getTimeToCut() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
getTimeToCut() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
getTimeToCutBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
getTimeToCutOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
getTimeToCutOrBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
getTimeToCutOrBuilder() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
getTlsCertHash() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
If mutual TLS is employed, this represents the hash of the client's TLS certificate
getTlsCertHash() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
If mutual TLS is employed, this represents the hash of the client's TLS certificate
getTlsCertHash() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
If mutual TLS is employed, this represents the hash of the client's TLS certificate
getTlsCertHash() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes tls_cert_hash = 3 [json_name = "tlsCertHash"];
getTlsCertHash() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
bytes tls_cert_hash = 3 [json_name = "tlsCertHash"];
getTlsCertHash() - Method in interface org.hyperledger.fabric.protos.gossip.ConnEstablishOrBuilder
bytes tls_cert_hash = 3 [json_name = "tlsCertHash"];
getTlsIntermediateCerts(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsIntermediateCerts(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsIntermediateCerts(int) - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsIntermediateCertsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsIntermediateCertsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsIntermediateCertsCount() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsIntermediateCertsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsIntermediateCertsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsIntermediateCertsList() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
getTlsRootCerts(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS root certificates trusted by this MSP.
getTlsRootCerts(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of TLS root certificates trusted by this MSP.
getTlsRootCerts(int) - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of TLS root certificates trusted by this MSP.
getTlsRootCertsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS root certificates trusted by this MSP.
getTlsRootCertsCount() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of TLS root certificates trusted by this MSP.
getTlsRootCertsCount() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of TLS root certificates trusted by this MSP.
getTlsRootCertsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS root certificates trusted by this MSP.
getTlsRootCertsList() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
List of TLS root certificates trusted by this MSP.
getTlsRootCertsList() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
List of TLS root certificates trusted by this MSP.
getTransactionActions() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
getTransactionActions() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
getTransactionActions() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
getTransactionActionsBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
getTransactionActionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
getTransactionActionsOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
getTransactionActionsOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
getTransactionEnvelope() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An Envelope which includes a processed transaction
getTransactionEnvelope() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
An Envelope which includes a processed transaction
getTransactionEnvelope() - Method in interface org.hyperledger.fabric.protos.peer.ProcessedTransactionOrBuilder
An Envelope which includes a processed transaction
getTransactionEnvelopeBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An Envelope which includes a processed transaction
getTransactionEnvelopeOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An Envelope which includes a processed transaction
getTransactionEnvelopeOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
An Envelope which includes a processed transaction
getTransactionEnvelopeOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.ProcessedTransactionOrBuilder
An Envelope which includes a processed transaction
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the transaction to check.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
Identifier of the transaction to check.
getTransactionId() - Method in interface org.hyperledger.fabric.protos.gateway.CommitStatusRequestOrBuilder
Identifier of the transaction to check.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The unique identifier for the transaction.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
The unique identifier for the transaction.
getTransactionId() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
The unique identifier for the transaction.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the transaction to evaluate.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
Identifier of the transaction to evaluate.
getTransactionId() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
Identifier of the transaction to evaluate.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
Identifier of the prepared transaction.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
Identifier of the prepared transaction.
getTransactionId() - Method in interface org.hyperledger.fabric.protos.gateway.PreparedTransactionOrBuilder
Identifier of the prepared transaction.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
Identifier of the proposed transaction.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
Identifier of the proposed transaction.
getTransactionId() - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
Identifier of the proposed transaction.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the transaction to submit.
getTransactionId() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
Identifier of the transaction to submit.
getTransactionId() - Method in interface org.hyperledger.fabric.protos.gateway.SubmitRequestOrBuilder
Identifier of the transaction to submit.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the transaction to check.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
Identifier of the transaction to check.
getTransactionIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.CommitStatusRequestOrBuilder
Identifier of the transaction to check.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The unique identifier for the transaction.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
The unique identifier for the transaction.
getTransactionIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
The unique identifier for the transaction.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the transaction to evaluate.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
Identifier of the transaction to evaluate.
getTransactionIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
Identifier of the transaction to evaluate.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
Identifier of the prepared transaction.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
Identifier of the prepared transaction.
getTransactionIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.PreparedTransactionOrBuilder
Identifier of the prepared transaction.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
Identifier of the proposed transaction.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
Identifier of the proposed transaction.
getTransactionIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
Identifier of the proposed transaction.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the transaction to submit.
getTransactionIdBytes() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
Identifier of the transaction to submit.
getTransactionIdBytes() - Method in interface org.hyperledger.fabric.protos.gateway.SubmitRequestOrBuilder
Identifier of the transaction to submit.
getTransientMap() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
Deprecated.
getTransientMap() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
Deprecated.
getTransientMap() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeProposalPayloadOrBuilder
Deprecated.
getTransientMapCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
getTransientMapCount() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
getTransientMapCount() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeProposalPayloadOrBuilder
TransientMap contains data (e.g.
getTransientMapMap() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
TransientMap contains data (e.g.
getTransientMapMap() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
TransientMap contains data (e.g.
getTransientMapMap() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeProposalPayloadOrBuilder
TransientMap contains data (e.g.
getTransientMapOrDefault(String, ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
TransientMap contains data (e.g.
getTransientMapOrDefault(String, ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
TransientMap contains data (e.g.
getTransientMapOrDefault(String, ByteString) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeProposalPayloadOrBuilder
TransientMap contains data (e.g.
getTransientMapOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
TransientMap contains data (e.g.
getTransientMapOrThrow(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
TransientMap contains data (e.g.
getTransientMapOrThrow(String) - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeProposalPayloadOrBuilder
TransientMap contains data (e.g.
getTxId() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
An unique identifier that is used end-to-end.
getTxId() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
An unique identifier that is used end-to-end.
getTxId() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
An unique identifier that is used end-to-end.
getTxId() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string tx_id = 3 [json_name = "txId"];
getTxId() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
string tx_id = 3 [json_name = "txId"];
getTxId() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
string tx_id = 3 [json_name = "txId"];
getTxId() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string tx_id = 1 [json_name = "txId"];
getTxId() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
string tx_id = 1 [json_name = "txId"];
getTxId() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataDigestOrBuilder
string tx_id = 1 [json_name = "txId"];
getTxId() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
string tx_id = 1 [json_name = "txId"];
getTxId() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
string tx_id = 1 [json_name = "txId"];
getTxId() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KeyModificationOrBuilder
string tx_id = 1 [json_name = "txId"];
getTxId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string tx_id = 2 [json_name = "txId"];
getTxId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
string tx_id = 2 [json_name = "txId"];
getTxId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEventOrBuilder
string tx_id = 2 [json_name = "txId"];
getTxid() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
string txid = 4 [json_name = "txid"];
getTxid() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
string txid = 4 [json_name = "txid"];
getTxid() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
string txid = 4 [json_name = "txid"];
getTxid() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
string txid = 1 [json_name = "txid"];
getTxid() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
string txid = 1 [json_name = "txid"];
getTxid() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
string txid = 1 [json_name = "txid"];
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
An unique identifier that is used end-to-end.
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
An unique identifier that is used end-to-end.
getTxIdBytes() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
An unique identifier that is used end-to-end.
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string tx_id = 3 [json_name = "txId"];
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
string tx_id = 3 [json_name = "txId"];
getTxIdBytes() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
string tx_id = 3 [json_name = "txId"];
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string tx_id = 1 [json_name = "txId"];
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
string tx_id = 1 [json_name = "txId"];
getTxIdBytes() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataDigestOrBuilder
string tx_id = 1 [json_name = "txId"];
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
string tx_id = 1 [json_name = "txId"];
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
string tx_id = 1 [json_name = "txId"];
getTxIdBytes() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KeyModificationOrBuilder
string tx_id = 1 [json_name = "txId"];
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string tx_id = 2 [json_name = "txId"];
getTxIdBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
string tx_id = 2 [json_name = "txId"];
getTxIdBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeEventOrBuilder
string tx_id = 2 [json_name = "txId"];
getTxidBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
string txid = 4 [json_name = "txid"];
getTxidBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
string txid = 4 [json_name = "txid"];
getTxidBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
string txid = 4 [json_name = "txid"];
getTxidBytes() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
string txid = 1 [json_name = "txid"];
getTxidBytes() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
string txid = 1 [json_name = "txid"];
getTxidBytes() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
string txid = 1 [json_name = "txid"];
getTxNum() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
uint64 tx_num = 2 [json_name = "txNum"];
getTxNum() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
uint64 tx_num = 2 [json_name = "txNum"];
getTxNum() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.VersionOrBuilder
uint64 tx_num = 2 [json_name = "txNum"];
getTxSeqInBlock() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
uint64 tx_seq_in_block = 1 [json_name = "txSeqInBlock"];
getTxSeqInBlock() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
uint64 tx_seq_in_block = 1 [json_name = "txSeqInBlock"];
getTxSeqInBlock() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataPayloadOrBuilder
uint64 tx_seq_in_block = 1 [json_name = "txSeqInBlock"];
getTxValidationCode() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
getTxValidationCode() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
getTxValidationCode() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
getTxValidationCodeValue() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
getTxValidationCodeValue() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
getTxValidationCodeValue() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
getType() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Header types 0-10000 are reserved and defined by HeaderType
getType() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
Header types 0-10000 are reserved and defined by HeaderType
getType() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
Header types 0-10000 are reserved and defined by HeaderType
getType() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
For outside implementors, consider the first 1000 types reserved, otherwise one of PolicyType
getType() - Method in class org.hyperledger.fabric.protos.common.Policy
For outside implementors, consider the first 1000 types reserved, otherwise one of PolicyType
getType() - Method in interface org.hyperledger.fabric.protos.common.PolicyOrBuilder
For outside implementors, consider the first 1000 types reserved, otherwise one of PolicyType
getType() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
Type holds the type of the MSP; the default one would be of type FABRIC implementing an X.509 based provider
getType() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
Type holds the type of the MSP; the default one would be of type FABRIC implementing an X.509 based provider
getType() - Method in interface org.hyperledger.fabric.protos.msp.MSPConfigOrBuilder
Type holds the type of the MSP; the default one would be of type FABRIC implementing an X.509 based provider
getType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The consensus type: "solo", "kafka" or "etcdraft".
getType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
The consensus type: "solo", "kafka" or "etcdraft".
getType() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusTypeOrBuilder
The consensus type: "solo", "kafka" or "etcdraft".
getType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
getType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
getType() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
getType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
getType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
getType() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
getType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.common.HeaderType type = 2 [json_name = "type"];
getType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
.common.HeaderType type = 2 [json_name = "type"];
getType() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
.common.HeaderType type = 2 [json_name = "type"];
getTypeBytes() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The consensus type: "solo", "kafka" or "etcdraft".
getTypeBytes() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
The consensus type: "solo", "kafka" or "etcdraft".
getTypeBytes() - Method in interface org.hyperledger.fabric.protos.orderer.ConsensusTypeOrBuilder
The consensus type: "solo", "kafka" or "etcdraft".
getTypeCase() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.common.ApplicationPolicyOrBuilder
Deprecated.
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyOrBuilder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationResponseOrBuilder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.orderer.DeliverResponseOrBuilder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.peer.ApplicationPolicyOrBuilder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSourceOrBuilder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
getTypeCase() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
getTypeCase() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateDataOrBuilder
 
getTypeValue() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
getTypeValue() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
getTypeValue() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
getTypeValue() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
getTypeValue() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
getTypeValue() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
getTypeValue() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.common.HeaderType type = 2 [json_name = "type"];
getTypeValue() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
.common.HeaderType type = 2 [json_name = "type"];
getTypeValue() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
.common.HeaderType type = 2 [json_name = "type"];
getUnavailable() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
getUnavailable() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
getUnavailable() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSourceOrBuilder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
getUnavailableBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
getUnavailableOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
getUnavailableOrBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
getUnavailableOrBuilder() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSourceOrBuilder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
getUnknownFields() - Method in class com.google.rpc.Status
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Block
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.BlockData
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Capability
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Config
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Consortium
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Envelope
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Header
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Metadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Payload
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.Policy
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Error
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Request
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.Response
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.Member
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.DelState
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.GetState
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.PutState
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.Response
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
getUnknownFields() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
getValidationCode() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An indication of whether the transaction was validated or invalidated by committing peer
getValidationCode() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
An indication of whether the transaction was validated or invalidated by committing peer
getValidationCode() - Method in interface org.hyperledger.fabric.protos.peer.ProcessedTransactionOrBuilder
An indication of whether the transaction was validated or invalidated by committing peer
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
bytes validation_parameter = 2 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
bytes validation_parameter = 2 [json_name = "validationParameter"];
getValidationParameter() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfoOrBuilder
bytes validation_parameter = 2 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
bytes validation_parameter = 5 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
bytes validation_parameter = 5 [json_name = "validationParameter"];
getValidationParameter() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
bytes validation_parameter = 5 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
bytes validation_parameter = 5 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
bytes validation_parameter = 5 [json_name = "validationParameter"];
getValidationParameter() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
bytes validation_parameter = 5 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationParameter() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
bytes validation_parameter = 6 [json_name = "validationParameter"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
string validation_plugin = 1 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
string validation_plugin = 1 [json_name = "validationPlugin"];
getValidationPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfoOrBuilder
string validation_plugin = 1 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPlugin() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
string validation_plugin = 1 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
string validation_plugin = 1 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfoOrBuilder
string validation_plugin = 1 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
string validation_plugin = 4 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
string validation_plugin = 5 [json_name = "validationPlugin"];
getValidationPluginBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
string validation_plugin = 5 [json_name = "validationPlugin"];
getValue() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
bytes value = 2 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.common.ConfigValueOrBuilder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
bytes value = 1 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.common.Metadata
bytes value = 1 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.common.MetadataOrBuilder
bytes value = 1 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.common.Policy
bytes value = 2 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.common.PolicyOrBuilder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
bytes value = 2 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KeyModificationOrBuilder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
bytes value = 3 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
bytes value = 3 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KVOrBuilder
bytes value = 3 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
bytes value = 2 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntryOrBuilder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
bytes value = 3 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
bytes value = 3 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteOrBuilder
bytes value = 3 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.peer.PutState
bytes value = 2 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.peer.PutStateOrBuilder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
bytes value = 2 [json_name = "value"];
getValue() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
bytes value = 2 [json_name = "value"];
getValue() - Method in interface org.hyperledger.fabric.protos.peer.StateMetadataOrBuilder
bytes value = 2 [json_name = "value"];
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.common.HeaderType
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.common.Status
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
 
getValueDescriptor() - Method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
 
getValueHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bytes value_hash = 3 [json_name = "valueHash"];
getValueHash() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
bytes value_hash = 3 [json_name = "valueHash"];
getValueHash() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHashOrBuilder
bytes value_hash = 3 [json_name = "valueHash"];
getValues() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
Deprecated.
getValues() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
Deprecated.
getValues() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
Deprecated.
getValuesCount() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
getValuesCount() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
getValuesCount() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesMap() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesMap() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesMap() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesOrDefault(String, ConfigValue) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesOrDefault(String, ConfigValue) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesOrDefault(String, ConfigValue) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesOrThrow(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getValuesOrThrow(String) - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
getVersion() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Version indicates message protocol version
getVersion() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
Version indicates message protocol version
getVersion() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
Version indicates message protocol version
getVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
uint64 version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
uint64 version = 1 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.common.ConfigGroupOrBuilder
uint64 version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
uint64 version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
uint64 version = 1 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.common.ConfigPolicyOrBuilder
uint64 version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
uint64 version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
uint64 version = 1 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.common.ConfigValueOrBuilder
uint64 version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
int32 version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
int32 version = 1 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
int32 version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
string version = 2 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.gossip.ChaincodeOrBuilder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
.kvrwset.Version version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
.kvrwset.Version version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
.kvrwset.Version version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
.kvrwset.Version version = 2 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHashOrBuilder
.kvrwset.Version version = 2 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadOrBuilder
.kvrwset.Version version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Version of the chaincode
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Version of the chaincode
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Version of the chaincode
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
user friendly version name for the chaincode
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
user friendly version name for the chaincode
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
A user friendly human readable name corresponding to the ID
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
A user friendly human readable name corresponding to the ID
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIdentifierOrBuilder
A user friendly human readable name corresponding to the ID
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIDOrBuilder
user friendly version name for the chaincode
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
string version = 2 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string version = 3 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
string version = 3 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
string version = 3 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
string version = 1 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfoOrBuilder
string version = 1 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string version = 3 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
string version = 3 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
string version = 3 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string version = 3 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
string version = 3 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
string version = 3 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
string version = 2 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
string version = 2 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string version = 3 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
string version = 3 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
string version = 3 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
string version = 2 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ChaincodeOrBuilder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
string version = 2 [json_name = "version"];
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ChaincodeOrBuilder
string version = 2 [json_name = "version"];
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Version indicates message protocol version
getVersion() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
Version indicates message protocol version
getVersion() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
Version indicates message protocol version
getVersionBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
.kvrwset.Version version = 2 [json_name = "version"];
getVersionBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
.kvrwset.Version version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
string version = 2 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.gossip.ChaincodeOrBuilder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Version of the chaincode
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Version of the chaincode
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Version of the chaincode
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
user friendly version name for the chaincode
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
user friendly version name for the chaincode
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
A user friendly human readable name corresponding to the ID
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
A user friendly human readable name corresponding to the ID
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIdentifierOrBuilder
A user friendly human readable name corresponding to the ID
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeIDOrBuilder
user friendly version name for the chaincode
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
string version = 2 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string version = 3 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
string version = 3 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
string version = 3 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string version = 1 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
string version = 1 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfoOrBuilder
string version = 1 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string version = 3 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
string version = 3 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
string version = 3 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string version = 3 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
string version = 3 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
string version = 3 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
string version = 2 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
string version = 2 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string version = 3 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
string version = 3 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
string version = 3 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
string version = 2 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.ChaincodeOrBuilder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string version = 2 [json_name = "version"];
getVersionBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
string version = 2 [json_name = "version"];
getVersionBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.ChaincodeOrBuilder
string version = 2 [json_name = "version"];
getVersionOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
.kvrwset.Version version = 2 [json_name = "version"];
getVersionOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
.kvrwset.Version version = 2 [json_name = "version"];
getVersionOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
.kvrwset.Version version = 2 [json_name = "version"];
getVersionOrBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
.kvrwset.Version version = 2 [json_name = "version"];
getVersionOrBuilder() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHashOrBuilder
.kvrwset.Version version = 2 [json_name = "version"];
getVersionOrBuilder() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadOrBuilder
.kvrwset.Version version = 2 [json_name = "version"];
getVscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Vscc for the chaincode instance
getVscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Vscc for the chaincode instance
getVscc() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Vscc for the chaincode instance
getVscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the VSCC for this chaincode.
getVscc() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the name of the VSCC for this chaincode.
getVscc() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the name of the VSCC for this chaincode.
getVsccBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Vscc for the chaincode instance
getVsccBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Vscc for the chaincode instance
getVsccBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Vscc for the chaincode instance
getVsccBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the VSCC for this chaincode.
getVsccBytes() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
the name of the VSCC for this chaincode.
getVsccBytes() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInfoOrBuilder
the name of the VSCC for this chaincode.
getWidth() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
width specifies the width of the Merkle tree to use when computing the BlockDataHash in order to replicate flat hashing, set this width to MAX_UINT32
getWidth() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
width specifies the width of the Merkle tree to use when computing the BlockDataHash in order to replicate flat hashing, set this width to MAX_UINT32
getWidth() - Method in interface org.hyperledger.fabric.protos.common.BlockDataHashingStructureOrBuilder
width specifies the width of the Merkle tree to use when computing the BlockDataHash in order to replicate flat hashing, set this width to MAX_UINT32
getWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWrites(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesCount() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesCount() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWriteSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
WriteSet lists the portion of the config which was written, this should included updated Versions
getWriteSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
WriteSet lists the portion of the config which was written, this should included updated Versions
getWriteSet() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
WriteSet lists the portion of the config which was written, this should included updated Versions
getWriteSetBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
WriteSet lists the portion of the config which was written, this should included updated Versions
getWriteSetOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
WriteSet lists the portion of the config which was written, this should included updated Versions
getWriteSetOrBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
WriteSet lists the portion of the config which was written, this should included updated Versions
getWriteSetOrBuilder() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
WriteSet lists the portion of the config which was written, this should included updated Versions
getWritesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesOrBuilder(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesOrBuilder(int) - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesOrBuilderList() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
getWritesOrBuilderList() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetOrBuilder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
GOLANG_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
GOLANG = 1;
GossipGrpc - Class in org.hyperledger.fabric.protos.gossip
Gossip
GossipGrpc.GossipBlockingStub - Class in org.hyperledger.fabric.protos.gossip
Gossip
GossipGrpc.GossipFutureStub - Class in org.hyperledger.fabric.protos.gossip
Gossip
GossipGrpc.GossipImplBase - Class in org.hyperledger.fabric.protos.gossip
Gossip
GossipGrpc.GossipStub - Class in org.hyperledger.fabric.protos.gossip
Gossip
GossipHello - Class in org.hyperledger.fabric.protos.gossip
GossipHello is the message that is used for the peer to initiate a pull round with another peer
GossipHello.Builder - Class in org.hyperledger.fabric.protos.gossip
GossipHello is the message that is used for the peer to initiate a pull round with another peer
GossipHelloOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
GossipImplBase() - Constructor for class org.hyperledger.fabric.protos.gossip.GossipGrpc.GossipImplBase
 
GossipMessage - Class in org.hyperledger.fabric.protos.gossip
GossipMessage defines the message sent in a gossip network
GossipMessage.Builder - Class in org.hyperledger.fabric.protos.gossip
GossipMessage defines the message sent in a gossip network
GossipMessage.ContentCase - Enum in org.hyperledger.fabric.protos.gossip
 
GossipMessage.Tag - Enum in org.hyperledger.fabric.protos.gossip
Protobuf enum gossip.GossipMessage.Tag
GossipMessageOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
gossipStream(StreamObserver<Envelope>) - Method in class org.hyperledger.fabric.protos.gossip.GossipGrpc.GossipImplBase
GossipStream is the gRPC stream used for sending and receiving messages
gossipStream(StreamObserver<Envelope>) - Method in class org.hyperledger.fabric.protos.gossip.GossipGrpc.GossipStub
GossipStream is the gRPC stream used for sending and receiving messages
GROUPS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigGroup
 

H

HAS_MORE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryResponse
 
hasAck() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
hasAck() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
hasAck() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
hasAction() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
The list of actions to apply to the ledger
hasAction() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
The list of actions to apply to the ledger
hasAction() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionPayloadOrBuilder
The list of actions to apply to the ledger
hasAdminOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the admins
hasAdminOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the admins
hasAdminOuIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the admins
hasAliveMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Membership
hasAliveMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Membership
hasAliveMsg() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Membership
hasAuthentication() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
authentication contains information that the service uses to check the client's eligibility for the queries.
hasAuthentication() - Method in class org.hyperledger.fabric.protos.discovery.Request
authentication contains information that the service uses to check the client's eligibility for the queries.
hasAuthentication() - Method in interface org.hyperledger.fabric.protos.discovery.RequestOrBuilder
authentication contains information that the service uses to check the client's eligibility for the queries.
hasBlock() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
hasBlock() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
.common.Block block = 2 [json_name = "block"];
hasBlock() - Method in interface org.hyperledger.fabric.protos.orderer.DeliverResponseOrBuilder
.common.Block block = 2 [json_name = "block"];
hasBlock() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
.common.Block block = 1 [json_name = "block"];
hasBlock() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
.common.Block block = 1 [json_name = "block"];
hasBlock() - Method in interface org.hyperledger.fabric.protos.peer.BlockAndPrivateDataOrBuilder
.common.Block block = 1 [json_name = "block"];
hasBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
hasBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.common.Block block = 2 [json_name = "block"];
hasBlock() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.common.Block block = 2 [json_name = "block"];
hasBlockAndPrivateData() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
hasBlockAndPrivateData() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
hasBlockAndPrivateData() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
hasBlockAttestation() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
hasBlockAttestation() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
hasBlockAttestation() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationResponseOrBuilder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
hasBootstrappingSnapshotInfo() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
hasBootstrappingSnapshotInfo() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
hasBootstrappingSnapshotInfo() - Method in interface org.hyperledger.fabric.protos.common.BlockchainInfoOrBuilder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
hasBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
bytes Bytes = 2 [json_name = "Bytes"];
hasBytes() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
bytes Bytes = 2 [json_name = "Bytes"];
hasBytes() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateDataOrBuilder
bytes Bytes = 2 [json_name = "Bytes"];
hasCcQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ChaincodeQuery queries for chaincodes by their name and version.
hasCcQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query
ChaincodeQuery queries for chaincodes by their name and version.
hasCcQuery() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
ChaincodeQuery queries for chaincodes by their name and version.
hasCcQueryRes() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
hasCcQueryRes() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
hasCcQueryRes() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
hasChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
event emitted by chaincode.
hasChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
event emitted by chaincode.
hasChaincodeEvent() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
event emitted by chaincode.
hasChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
hasChaincodeEvent() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
hasChaincodeEvent() - Method in interface org.hyperledger.fabric.protos.peer.FilteredChaincodeActionOrBuilder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
hasChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the ChaincodeID of executing this invocation.
hasChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
This field contains the ChaincodeID of executing this invocation.
hasChaincodeId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionOrBuilder
This field contains the ChaincodeID of executing this invocation.
hasChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
The ID of the chaincode to target.
hasChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
The ID of the chaincode to target.
hasChaincodeId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtensionOrBuilder
The ID of the chaincode to target.
hasChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
hasChaincodeId() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
hasChaincodeId() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
hasChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
hasChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
hasChaincodeSpec() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpecOrBuilder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
hasChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
hasChaincodeSpec() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
hasChaincodeSpec() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpecOrBuilder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
hasChannelConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config channel_config = 1 [json_name = "channelConfig"];
hasChannelConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
.common.Config channel_config = 1 [json_name = "channelConfig"];
hasChannelConfig() - Method in interface org.hyperledger.fabric.protos.peer.ConfigTreeOrBuilder
.common.Config channel_config = 1 [json_name = "channelConfig"];
hasChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
hasChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
hasChannelConfigPolicyReference() - Method in interface org.hyperledger.fabric.protos.common.ApplicationPolicyOrBuilder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
hasChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
hasChannelConfigPolicyReference() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
hasChannelConfigPolicyReference() - Method in interface org.hyperledger.fabric.protos.peer.ApplicationPolicyOrBuilder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
hasChannelGroup() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
hasChannelGroup() - Method in class org.hyperledger.fabric.protos.common.Config
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
hasChannelGroup() - Method in interface org.hyperledger.fabric.protos.common.ConfigOrBuilder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
hasClientOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the clients
hasClientOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the clients
hasClientOuIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the clients
hasCollectionConfigs() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
hasCollectionConfigs() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
hasCollectionConfigs() - Method in interface org.hyperledger.fabric.protos.gossip.PrivatePayloadOrBuilder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgsOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
hasCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
hasCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResultOrBuilder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasCollections() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
hasConfig() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
A marshaled Config structure
hasConfig() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
A marshaled Config structure
hasConfig() - Method in interface org.hyperledger.fabric.protos.common.ConfigEnvelopeOrBuilder
A marshaled Config structure
hasConfigQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
hasConfigQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
hasConfigQuery() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
hasConfigResult() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
hasConfigResult() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
hasConfigResult() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
hasConn() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
ConnEstablish, used for establishing a connection
hasConn() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
ConnEstablish, used for establishing a connection
hasConn() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
ConnEstablish, used for establishing a connection
hasConnect() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
hasConnect() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
hasConnect() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
hasConsensusRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
consensus_request is a consensus specific message.
hasConsensusRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
consensus_request is a consensus specific message.
hasConsensusRequest() - Method in interface org.hyperledger.fabric.protos.orderer.StepRequestOrBuilder
consensus_request is a consensus specific message.
hasCryptoConfig() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
hasCryptoConfig() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
hasCryptoConfig() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
hasData() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockData data = 2 [json_name = "data"];
hasData() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockData data = 2 [json_name = "data"];
hasData() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockData data = 2 [json_name = "data"];
hasDataDig() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
hasDataDig() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
hasDataDig() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
hasDataMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Contains a ledger block
hasDataMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Contains a ledger block
hasDataMsg() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Contains a ledger block
hasDataReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
hasDataReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
hasDataReq() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
hasDataUpdate() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
hasDataUpdate() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
hasDataUpdate() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
hasDigest() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
hasDigest() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
hasDigest() - Method in interface org.hyperledger.fabric.protos.gossip.PvtDataElementOrBuilder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
hasEmpty() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Empty message, used for pinging
hasEmpty() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Empty message, used for pinging
hasEmpty() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Empty message, used for pinging
hasEndorsement() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The endorsement of the proposal, basically the endorser's signature over the payload
hasEndorsement() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
The endorsement of the proposal, basically the endorser's signature over the payload
hasEndorsement() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
The endorsement of the proposal, basically the endorser's signature over the payload
hasEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
hasEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
hasEndorsementPolicy() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
hasEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
hasEndorsementPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
hasEndorsementPolicy() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
hasEnvelope() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
The transaction envelope.
hasEnvelope() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
The transaction envelope.
hasEnvelope() - Method in interface org.hyperledger.fabric.protos.gateway.PreparedTransactionOrBuilder
The transaction envelope.
hasError() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
Error indicates failure or refusal to process the query
hasError() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
Error indicates failure or refusal to process the query
hasError() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
Error indicates failure or refusal to process the query
hasFabricNodeOus() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
hasFabricNodeOus() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
hasFabricNodeOus() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
hasFilter() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
hasFilter() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
hasFilter() - Method in interface org.hyperledger.fabric.protos.discovery.PeerMembershipQueryOrBuilder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
hasFilteredBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
hasFilteredBlock() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
hasFilteredBlock() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.CDSData
 
HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
hashCode() - Method in class com.google.rpc.Status
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Block
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.BlockData
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Capability
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Config
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Consortium
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Envelope
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Header
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Metadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Payload
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.Policy
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
hashCode() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Error
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Request
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.Response
 
hashCode() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.Member
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
hashCode() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
hashCode() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.DelState
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.GetState
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.PutState
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.Response
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
hashCode() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
hashCode() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
hasHeader() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockHeader header = 1 [json_name = "header"];
hasHeader() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockHeader header = 1 [json_name = "header"];
hasHeader() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockHeader header = 1 [json_name = "header"];
hasHeader() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Header is included to provide identity and prevent replay
hasHeader() - Method in class org.hyperledger.fabric.protos.common.Payload
Header is included to provide identity and prevent replay
hasHeader() - Method in interface org.hyperledger.fabric.protos.common.PayloadOrBuilder
Header is included to provide identity and prevent replay
hasHeader() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockHeader header = 1 [json_name = "header"];
hasHeader() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
.common.BlockHeader header = 1 [json_name = "header"];
hasHeader() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationOrBuilder
.common.BlockHeader header = 1 [json_name = "header"];
HASHED_READS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
HASHED_RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
HASHED_WRITES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
HashedRWSet - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
HashedRWSet encapsulates hashed representation of a private read-write set for KV or Document data model
HashedRWSet.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
HashedRWSet encapsulates hashed representation of a private read-write set for KV or Document data model
HashedRWSetOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
hasHello() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for push&pull
hasHello() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for push&pull
hasHello() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for push&pull
HashingAlgorithm - Class in org.hyperledger.fabric.protos.common
HashingAlgorithm is encoded into the configuration transaction as a configuration item of type Chain with a Key of "HashingAlgorithm" and a Value of HashingAlgorithm as marshaled protobuf bytes
HashingAlgorithm.Builder - Class in org.hyperledger.fabric.protos.common
HashingAlgorithm is encoded into the configuration transaction as a configuration item of type Chain with a Key of "HashingAlgorithm" and a Value of HashingAlgorithm as marshaled protobuf bytes
HashingAlgorithmOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
hasInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeInput input = 3 [json_name = "input"];
hasInput() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
.protos.ChaincodeInput input = 3 [json_name = "input"];
hasInput() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeSpecOrBuilder
.protos.ChaincodeInput input = 3 [json_name = "input"];
hasInstantiationPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
InstantiationPolicy for the chaincode
hasInstantiationPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
InstantiationPolicy for the chaincode
hasInstantiationPolicy() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
InstantiationPolicy for the chaincode
hasInt64() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
int64 Int64 = 1 [json_name = "Int64"];
hasInt64() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
int64 Int64 = 1 [json_name = "Int64"];
hasInt64() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateDataOrBuilder
int64 Int64 = 1 [json_name = "Int64"];
hasInterest() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The chaincode interest derived from simulating the proposal.
hasInterest() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
The chaincode interest derived from simulating the proposal.
hasInterest() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
The chaincode interest derived from simulating the proposal.
hasInternalEndpoint() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
hasInternalEndpoint() - Method in class org.hyperledger.fabric.protos.gossip.Secret
string internalEndpoint = 1 [json_name = "internalEndpoint"];
hasInternalEndpoint() - Method in interface org.hyperledger.fabric.protos.gossip.SecretOrBuilder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
hasLastConfig() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
hasLastConfig() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
hasLastConfig() - Method in interface org.hyperledger.fabric.protos.common.OrdererBlockMetadataOrBuilder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
hasLastUpdate() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
The last CONFIG_UPDATE message which generated this current configuration
hasLastUpdate() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
The last CONFIG_UPDATE message which generated this current configuration
hasLastUpdate() - Method in interface org.hyperledger.fabric.protos.common.ConfigEnvelopeOrBuilder
The last CONFIG_UPDATE message which generated this current configuration
hasLeadershipMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to indicate intent of peer to become leader
hasLeadershipMsg() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to indicate intent of peer to become leader
hasLeadershipMsg() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to indicate intent of peer to become leader
hasLocalPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
hasLocalPackage() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
hasLocalPackage() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSourceOrBuilder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
hasLocalPeers() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
hasLocalPeers() - Method in class org.hyperledger.fabric.protos.discovery.Query
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
hasLocalPeers() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
hasMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
hasMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
hasMemberOrgsPolicy() - Method in interface org.hyperledger.fabric.protos.common.StaticCollectionConfigOrBuilder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
hasMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
hasMemberOrgsPolicy() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
hasMemberOrgsPolicy() - Method in interface org.hyperledger.fabric.protos.peer.StaticCollectionConfigOrBuilder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
hasMembers() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
hasMembers() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
hasMembers() - Method in interface org.hyperledger.fabric.protos.discovery.QueryResultOrBuilder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
hasMembership() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.Member membership = 1 [json_name = "membership"];
hasMembership() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
.gossip.Member membership = 1 [json_name = "membership"];
hasMembership() - Method in interface org.hyperledger.fabric.protos.gossip.AliveMessageOrBuilder
.gossip.Member membership = 1 [json_name = "membership"];
hasMembershipInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
hasMembershipInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
hasMembershipInfo() - Method in interface org.hyperledger.fabric.protos.discovery.PeerOrBuilder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
hasMemReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
hasMemReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
hasMemReq() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
hasMemRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
hasMemRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
hasMemRes() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
hasMetadata() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
hasMetadata() - Method in class org.hyperledger.fabric.protos.common.Block
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
hasMetadata() - Method in interface org.hyperledger.fabric.protos.common.BlockOrBuilder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
hasMetadata() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
hasMetadata() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
hasMetadata() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationOrBuilder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
hasMetadata() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
hasMetadata() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
hasMetadata() - Method in interface org.hyperledger.fabric.protos.peer.PutStateMetadataOrBuilder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
hasNewest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
hasNewest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekNewest newest = 1 [json_name = "newest"];
hasNewest() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
hasNextCommit() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
hasNextCommit() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
hasNextCommit() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
hasNOutOf() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
hasNOutOf() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
hasNOutOf() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyOrBuilder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
hasOldest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
hasOldest() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
hasOldest() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
hasOptions() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
.etcdraft.Options options = 2 [json_name = "options"];
hasOptions() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
.etcdraft.Options options = 2 [json_name = "options"];
hasOptions() - Method in interface org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadataOrBuilder
.etcdraft.Options options = 2 [json_name = "options"];
hasOrdererOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the orderers
hasOrdererOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the orderers
hasOrdererOuIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the orderers
hasPayload() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
.gossip.Payload payload = 1 [json_name = "payload"];
hasPayload() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
.gossip.Payload payload = 1 [json_name = "payload"];
hasPayload() - Method in interface org.hyperledger.fabric.protos.gossip.DataMessageOrBuilder
.gossip.Payload payload = 1 [json_name = "payload"];
hasPayload() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
hasPayload() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
hasPayload() - Method in interface org.hyperledger.fabric.protos.gossip.PrivateDataMessageOrBuilder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
hasPayload() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
content is the fabric transaction that is forwarded to the cluster member.
hasPayload() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
content is the fabric transaction that is forwarded to the cluster member.
hasPayload() - Method in interface org.hyperledger.fabric.protos.orderer.SubmitRequestOrBuilder
content is the fabric transaction that is forwarded to the cluster member.
hasPeerIdentity() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to learn of a peer's certificate
hasPeerIdentity() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to learn of a peer's certificate
hasPeerIdentity() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to learn of a peer's certificate
hasPeerOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the peers
hasPeerOuIdentifier() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
OU Identifier of the peers
hasPeerOuIdentifier() - Method in interface org.hyperledger.fabric.protos.msp.FabricNodeOUsOrBuilder
OU Identifier of the peers
hasPeerQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
hasPeerQuery() - Method in class org.hyperledger.fabric.protos.discovery.Query
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
hasPeerQuery() - Method in interface org.hyperledger.fabric.protos.discovery.QueryOrBuilder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
hasPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
.common.Policy policy = 2 [json_name = "policy"];
hasPolicy() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
.common.Policy policy = 2 [json_name = "policy"];
hasPolicy() - Method in interface org.hyperledger.fabric.protos.common.ConfigPolicyOrBuilder
.common.Policy policy = 2 [json_name = "policy"];
hasPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Policy endorsement policy for the chaincode instance
hasPolicy() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
Policy endorsement policy for the chaincode instance
hasPolicy() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeDataOrBuilder
Policy endorsement policy for the chaincode instance
hasPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
hasPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
hasPreparedTransaction() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseResponseOrBuilder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
hasPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
The signed set of endorsed transaction responses to submit.
hasPreparedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
The signed set of endorsed transaction responses to submit.
hasPreparedTransaction() - Method in interface org.hyperledger.fabric.protos.gateway.SubmitRequestOrBuilder
The signed set of endorsed transaction responses to submit.
hasPrivateData() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Encapsulates private data used to distribute private rwset after the endorsement
hasPrivateData() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Encapsulates private data used to distribute private rwset after the endorsement
hasPrivateData() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Encapsulates private data used to distribute private rwset after the endorsement
hasPrivateReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to request private data
hasPrivateReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to request private data
hasPrivateReq() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to request private data
hasPrivateRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to respond to private data requests
hasPrivateRes() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to respond to private data requests
hasPrivateRes() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to respond to private data requests
hasPrivateSigner() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PrivateSigner denotes a reference to the private key of the peer's signing identity
hasPrivateSigner() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
PrivateSigner denotes a reference to the private key of the peer's signing identity
hasPrivateSigner() - Method in interface org.hyperledger.fabric.protos.msp.SigningIdentityInfoOrBuilder
PrivateSigner denotes a reference to the private key of the peer's signing identity
hasProperties() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.Properties properties = 5 [json_name = "properties"];
hasProperties() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
.gossip.Properties properties = 5 [json_name = "properties"];
hasProperties() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoOrBuilder
.gossip.Properties properties = 5 [json_name = "properties"];
hasProposal() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The signed proposal.
hasProposal() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
The signed proposal.
hasProposal() - Method in interface org.hyperledger.fabric.protos.gateway.ProposedTransactionOrBuilder
The signed proposal.
hasProposal() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
hasProposal() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
hasProposal() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
hasProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The signed proposal ready for endorsement.
hasProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
The signed proposal ready for endorsement.
hasProposedTransaction() - Method in interface org.hyperledger.fabric.protos.gateway.EndorseRequestOrBuilder
The signed proposal ready for endorsement.
hasProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
The signed proposal ready for evaluation.
hasProposedTransaction() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
The signed proposal ready for evaluation.
hasProposedTransaction() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateRequestOrBuilder
The signed proposal ready for evaluation.
hasPvtRwset() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
hasPvtRwset() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
hasPvtRwset() - Method in interface org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfoOrBuilder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
hasRawReads() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
hasRawReads() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
hasRawReads() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
hasReadSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
hasReadSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
hasReadSet() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
hasReadsMerkleHashes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
hasReadsMerkleHashes() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
hasReadsMerkleHashes() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfoOrBuilder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
hasRegular() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
hasRegular() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
hasRegular() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
hasResourcesConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
hasResourcesConfig() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
hasResourcesConfig() - Method in interface org.hyperledger.fabric.protos.peer.ConfigTreeOrBuilder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
hasResponse() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the result of executing this invocation.
hasResponse() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
This field contains the result of executing this invocation.
hasResponse() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeActionOrBuilder
This field contains the result of executing this invocation.
hasResponse() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
A response message indicating whether the endorsement of the action was successful
hasResponse() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
A response message indicating whether the endorsement of the action was successful
hasResponse() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
A response message indicating whether the endorsement of the action was successful
hasResult() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
hasResult() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
hasResult() - Method in interface org.hyperledger.fabric.protos.gateway.EvaluateResponseOrBuilder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
hasRule() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
hasRule() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
.common.SignaturePolicy rule = 2 [json_name = "rule"];
hasRule() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyEnvelopeOrBuilder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
hasSecretEnvelope() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
hasSecretEnvelope() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
hasSecretEnvelope() - Method in interface org.hyperledger.fabric.protos.gossip.EnvelopeOrBuilder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
hasSelfInformation() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
hasSelfInformation() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
hasSelfInformation() - Method in interface org.hyperledger.fabric.protos.gossip.MembershipRequestOrBuilder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
hasSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The signature header that contains creator identity and nonce
hasSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
The signature header that contains creator identity and nonce
hasSignatureHeader() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotQueryOrBuilder
The signature header that contains creator identity and nonce
hasSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The signature header that contains creator identity and nonce
hasSignatureHeader() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
The signature header that contains creator identity and nonce
hasSignatureHeader() - Method in interface org.hyperledger.fabric.protos.peer.SnapshotRequestOrBuilder
The signature header that contains creator identity and nonce
hasSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
hasSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
hasSignaturePolicy() - Method in interface org.hyperledger.fabric.protos.common.ApplicationPolicyOrBuilder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
hasSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
Initially, only a signature policy is supported.
hasSignaturePolicy() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
Initially, only a signature policy is supported.
hasSignaturePolicy() - Method in interface org.hyperledger.fabric.protos.common.CollectionPolicyConfigOrBuilder
Deprecated.
Initially, only a signature policy is supported.
hasSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
hasSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
hasSignaturePolicy() - Method in interface org.hyperledger.fabric.protos.peer.ApplicationPolicyOrBuilder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
hasSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
Initially, only a signature policy is supported.
hasSignaturePolicy() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
Initially, only a signature policy is supported.
hasSignaturePolicy() - Method in interface org.hyperledger.fabric.protos.peer.CollectionPolicyConfigOrBuilder
Initially, only a signature policy is supported.
hasSignedBy() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
int32 signed_by = 1 [json_name = "signedBy"];
hasSignedBy() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
int32 signed_by = 1 [json_name = "signedBy"];
hasSignedBy() - Method in interface org.hyperledger.fabric.protos.common.SignaturePolicyOrBuilder
int32 signed_by = 1 [json_name = "signedBy"];
hasSigner() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
signer may contain crypto material to configure a default signer
hasSigner() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
signer may contain crypto material to configure a default signer
hasSigner() - Method in interface org.hyperledger.fabric.protos.msp.IdemixMSPConfigOrBuilder
signer may contain crypto material to configure a default signer
hasSigningIdentity() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
hasSigningIdentity() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
hasSigningIdentity() - Method in interface org.hyperledger.fabric.protos.msp.FabricMSPConfigOrBuilder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
hasSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
hasSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
hasSource() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgsOrBuilder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
hasSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
hasSource() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
hasSource() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResultOrBuilder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
hasSpecified() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
hasSpecified() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
hasSpecified() - Method in interface org.hyperledger.fabric.protos.orderer.SeekPositionOrBuilder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
hasStart() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to start the deliver from
hasStart() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
The position to start the deliver from
hasStart() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
The position to start the deliver from
hasStartPosition() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Position within the ledger at which to start reading events.
hasStartPosition() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
Position within the ledger at which to start reading events.
hasStartPosition() - Method in interface org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequestOrBuilder
Position within the ledger at which to start reading events.
hasStateInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
hasStateInfo() - Method in class org.hyperledger.fabric.protos.discovery.Peer
This is an Envelope of a GossipMessage with a gossip.StateInfo message
hasStateInfo() - Method in interface org.hyperledger.fabric.protos.discovery.PeerOrBuilder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
hasStateInfo() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for relaying information about state
hasStateInfo() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for relaying information about state
hasStateInfo() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for relaying information about state
hasStateInfoPullReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for asking for StateInfoSnapshots
hasStateInfoPullReq() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for asking for StateInfoSnapshots
hasStateInfoPullReq() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for asking for StateInfoSnapshots
hasStateRequest() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to ask from a remote peer a set of blocks
hasStateRequest() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to ask from a remote peer a set of blocks
hasStateRequest() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to ask from a remote peer a set of blocks
hasStateResponse() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to send a set of blocks to a remote peer
hasStateResponse() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used to send a set of blocks to a remote peer
hasStateResponse() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used to send a set of blocks to a remote peer
hasStateSnapshot() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for sending sets of StateInfo messages
hasStateSnapshot() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
Used for sending sets of StateInfo messages
hasStateSnapshot() - Method in interface org.hyperledger.fabric.protos.gossip.GossipMessageOrBuilder
Used for sending sets of StateInfo messages
hasStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
hasStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
hasStaticCollectionConfig() - Method in interface org.hyperledger.fabric.protos.common.CollectionConfigOrBuilder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
hasStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
hasStaticCollectionConfig() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
hasStaticCollectionConfig() - Method in interface org.hyperledger.fabric.protos.peer.CollectionConfigOrBuilder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
hasStatus() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.common.Status status = 1 [json_name = "status"];
hasStatus() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
.common.Status status = 1 [json_name = "status"];
hasStatus() - Method in interface org.hyperledger.fabric.protos.orderer.BlockAttestationResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
hasStatus() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
hasStatus() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
.common.Status status = 1 [json_name = "status"];
hasStatus() - Method in interface org.hyperledger.fabric.protos.orderer.DeliverResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
hasStatus() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
hasStatus() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
.common.Status status = 1 [json_name = "status"];
hasStatus() - Method in interface org.hyperledger.fabric.protos.peer.DeliverResponseOrBuilder
.common.Status status = 1 [json_name = "status"];
hasStop() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to stop the deliver
hasStop() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
The position to stop the deliver
hasStop() - Method in interface org.hyperledger.fabric.protos.orderer.SeekInfoOrBuilder
The position to stop the deliver
hasString() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
string String = 3 [json_name = "String"];
hasString() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
string String = 3 [json_name = "String"];
hasString() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.StateDataOrBuilder
string String = 3 [json_name = "String"];
hasSubmitRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
submit_request is a relay of a transaction.
hasSubmitRequest() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
submit_request is a relay of a transaction.
hasSubmitRequest() - Method in interface org.hyperledger.fabric.protos.orderer.StepRequestOrBuilder
submit_request is a relay of a transaction.
hasSubmitRes() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
hasSubmitRes() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
hasSubmitRes() - Method in interface org.hyperledger.fabric.protos.orderer.StepResponseOrBuilder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Timestamp is the local time when the message was created by the sender
hasTimestamp() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
Timestamp is the local time when the message was created by the sender
hasTimestamp() - Method in interface org.hyperledger.fabric.protos.common.ChannelHeaderOrBuilder
Timestamp is the local time when the message was created by the sender
hasTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in interface org.hyperledger.fabric.protos.gossip.AliveMessageOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in interface org.hyperledger.fabric.protos.gossip.LeadershipMessageOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in interface org.hyperledger.fabric.protos.gossip.StateInfoOrBuilder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
hasTimestamp() - Method in interface org.hyperledger.fabric.protos.ledger.queryresult.KeyModificationOrBuilder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in interface org.hyperledger.fabric.protos.peer.ChaincodeMessageOrBuilder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
hasTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Timestamp is the time that the message was created as defined by the sender
hasTimestamp() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
Timestamp is the time that the message was created as defined by the sender
hasTimestamp() - Method in interface org.hyperledger.fabric.protos.peer.ProposalResponseOrBuilder
Timestamp is the time that the message was created as defined by the sender
hasTimeToCut() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
hasTimeToCut() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
hasTimeToCut() - Method in interface org.hyperledger.fabric.protos.orderer.KafkaMessageOrBuilder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
hasTransactionActions() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
hasTransactionActions() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
hasTransactionActions() - Method in interface org.hyperledger.fabric.protos.peer.FilteredTransactionOrBuilder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
hasTransactionEnvelope() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An Envelope which includes a processed transaction
hasTransactionEnvelope() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
An Envelope which includes a processed transaction
hasTransactionEnvelope() - Method in interface org.hyperledger.fabric.protos.peer.ProcessedTransactionOrBuilder
An Envelope which includes a processed transaction
hasUnavailable() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
hasUnavailable() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
hasUnavailable() - Method in interface org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSourceOrBuilder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
hasVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
.kvrwset.Version version = 2 [json_name = "version"];
hasVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
.kvrwset.Version version = 2 [json_name = "version"];
hasVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
.kvrwset.Version version = 2 [json_name = "version"];
hasVersion() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
.kvrwset.Version version = 2 [json_name = "version"];
hasVersion() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHashOrBuilder
.kvrwset.Version version = 2 [json_name = "version"];
hasVersion() - Method in interface org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadOrBuilder
.kvrwset.Version version = 2 [json_name = "version"];
hasWriteSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
WriteSet lists the portion of the config which was written, this should included updated Versions
hasWriteSet() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
WriteSet lists the portion of the config which was written, this should included updated Versions
hasWriteSet() - Method in interface org.hyperledger.fabric.protos.common.ConfigUpdateOrBuilder
WriteSet lists the portion of the config which was written, this should included updated Versions
Header - Class in org.hyperledger.fabric.protos.common
Protobuf type common.Header
Header.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.Header
HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Block
 
HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Payload
 
HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Proposal
 
HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.TransactionAction
 
HeaderOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
HeaderType - Enum in org.hyperledger.fabric.protos.common
Protobuf enum common.HeaderType
HEARTBEAT_TICK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
HEIGHT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
HELLO_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
HOST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Endpoint
 
HOST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
HOST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.AnchorPeer
 

I

ID_BYTES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryResponse
 
ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
IdemixMSPConfig - Class in org.hyperledger.fabric.protos.msp
IdemixMSPConfig collects all the configuration information for an Idemix MSP.
IdemixMSPConfig.Builder - Class in org.hyperledger.fabric.protos.msp
IdemixMSPConfig collects all the configuration information for an Idemix MSP.
IdemixMSPConfigOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
IdemixMSPSignerConfig - Class in org.hyperledger.fabric.protos.msp
IdemixMSPSIgnerConfig contains the crypto material to set up an idemix signing identity
IdemixMSPSignerConfig.Builder - Class in org.hyperledger.fabric.protos.msp
IdemixMSPSIgnerConfig contains the crypto material to set up an idemix signing identity
IdemixMSPSignerConfigOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
IDENTITIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
IdentitiesProto - Class in org.hyperledger.fabric.protos.msp
 
IDENTITY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Peer
 
IDENTITY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
IDENTITY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
IDENTITY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
IDENTITY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
IDENTITY_IDENTIFIER_HASH_FUNCTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
IDENTITY_MSG_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.PullMsgType
IDENTITY_MSG = 2;
IDENTITY_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
groupping of entities, per MSP affiliation E.g., this can well be represented by an MSP's Organization unit
ILLEGAL_WRITESET_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
ILLEGAL_WRITESET = 23;
IMPLICIT_META_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
IMPLICIT_META = 3;
ImplicitMetaPolicy - Class in org.hyperledger.fabric.protos.common
ImplicitMetaPolicy is a policy type which depends on the hierarchical nature of the configuration It is implicit because the rule is generate implicitly based on the number of sub policies It is meta because it depends only on the result of other policies When evaluated, this policy iterates over all immediate child sub-groups, retrieves the policy of name sub_policy, evaluates the collection and applies the rule.
ImplicitMetaPolicy.Builder - Class in org.hyperledger.fabric.protos.common
ImplicitMetaPolicy is a policy type which depends on the hierarchical nature of the configuration It is implicit because the rule is generate implicitly based on the number of sub policies It is meta because it depends only on the result of other policies When evaluated, this policy iterates over all immediate child sub-groups, retrieves the policy of name sub_policy, evaluates the collection and applies the rule.
ImplicitMetaPolicy.Rule - Enum in org.hyperledger.fabric.protos.common
Protobuf enum common.ImplicitMetaPolicy.Rule
ImplicitMetaPolicyOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
IN_PROGRESS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
INC_NUM_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PeerTime
 
INDEX_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.LastConfig
 
INFO_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
INFO_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
INIT_REQUIRED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
INIT_REQUIRED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
INIT_REQUIRED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
INIT_REQUIRED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
INIT_REQUIRED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
INIT_REQUIRED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
INIT_REQUIRED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
INIT_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
INIT = 3;
INPUT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
INPUT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
INPUT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
InstallChaincodeArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
InstallChaincodeArgs is the message used as the argument to '_lifecycle.InstallChaincode'.
InstallChaincodeArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
InstallChaincodeArgs is the message used as the argument to '_lifecycle.InstallChaincode'.
InstallChaincodeArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
InstallChaincodeResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
InstallChaincodeArgs is the message returned by '_lifecycle.InstallChaincode'.
InstallChaincodeResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
InstallChaincodeArgs is the message returned by '_lifecycle.InstallChaincode'.
InstallChaincodeResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
INSTALLED_CHAINCODES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
INSTANTIATION_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
INSTANTIATION_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
INT64_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
INTEREST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
INTERESTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
INTERMEDIATE_CERTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
INTERNAL_SERVER_ERROR_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
INTERNAL_SERVER_ERROR = 500;
INTERNALENDPOINT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Secret
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.common.HeaderType
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.common.Status
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
 
internalGetValueMap() - Static method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
 
INVALID_CHAINCODE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
INVALID_CHAINCODE = 25;
INVALID_CONFIG_TRANSACTION_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
INVALID_CONFIG_TRANSACTION = 6;
INVALID_ENDORSER_TRANSACTION_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
INVALID_ENDORSER_TRANSACTION = 5;
INVALID_OTHER_REASON_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
INVALID_OTHER_REASON = 255;
INVALID_WRITESET_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
INVALID_WRITESET = 24;
INVOKE_CHAINCODE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
INVOKE_CHAINCODE = 11;
IPK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
IS_DECLARATION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
IS_DELETE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
IS_DELETE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
IS_DELETE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
IS_INIT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
IS_PURGE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
isInitialized() - Method in class com.google.rpc.Status.Builder
 
isInitialized() - Method in class com.google.rpc.Status
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Block
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockData
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Capability
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Config
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Consortium
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Envelope
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Header
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Metadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Payload
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.Policy
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Error
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Request
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.Response
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Member
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.DelState
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetState
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.PutState
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.Response
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
isInitialized() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
isInitialized() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
ISOLATED_DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
ITR_EXHAUSTED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 

J

JAVA_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
JAVA = 4;
JoinBySnapshotStatus - Class in org.hyperledger.fabric.protos.peer
JoinBySnapshotStatus contains information about whether or a JoinBySnapshot operation is in progress and the related bootstrap dir if it is running.
JoinBySnapshotStatus.Builder - Class in org.hyperledger.fabric.protos.peer
JoinBySnapshotStatus contains information about whether or a JoinBySnapshot operation is in progress and the related bootstrap dir if it is running.
JoinBySnapshotStatusOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 

K

KafkaBrokers - Class in org.hyperledger.fabric.protos.orderer
Carries a list of bootstrap brokers, i.e.
KafkaBrokers.Builder - Class in org.hyperledger.fabric.protos.orderer
Carries a list of bootstrap brokers, i.e.
KafkaBrokersOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
KafkaMessage - Class in org.hyperledger.fabric.protos.orderer
KafkaMessage is a wrapper type for the messages that the Kafka-based orderer deals with.
KafkaMessage.Builder - Class in org.hyperledger.fabric.protos.orderer
KafkaMessage is a wrapper type for the messages that the Kafka-based orderer deals with.
KafkaMessage.TypeCase - Enum in org.hyperledger.fabric.protos.orderer
 
KafkaMessageConnect - Class in org.hyperledger.fabric.protos.orderer
KafkaMessageConnect is posted by an orderer upon booting up.
KafkaMessageConnect.Builder - Class in org.hyperledger.fabric.protos.orderer
KafkaMessageConnect is posted by an orderer upon booting up.
KafkaMessageConnectOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
KafkaMessageOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
KafkaMessageRegular - Class in org.hyperledger.fabric.protos.orderer
KafkaMessageRegular wraps a marshalled envelope.
KafkaMessageRegular.Builder - Class in org.hyperledger.fabric.protos.orderer
KafkaMessageRegular wraps a marshalled envelope.
KafkaMessageRegular.Class - Enum in org.hyperledger.fabric.protos.orderer
Protobuf enum orderer.KafkaMessageRegular.Class
KafkaMessageRegularOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
KafkaMessageTimeToCut - Class in org.hyperledger.fabric.protos.orderer
KafkaMessageTimeToCut is used to signal to the orderers that it is time to cut block <block_number>.
KafkaMessageTimeToCut.Builder - Class in org.hyperledger.fabric.protos.orderer
KafkaMessageTimeToCut is used to signal to the orderers that it is time to cut block <block_number>.
KafkaMessageTimeToCutOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
KafkaMetadata - Class in org.hyperledger.fabric.protos.orderer
KafkaMetadata is encoded into the ORDERER block to keep track of Kafka-related metadata associated with this block.
KafkaMetadata.Builder - Class in org.hyperledger.fabric.protos.orderer
KafkaMetadata is encoded into the ORDERER block to keep track of Kafka-related metadata associated with this block.
KafkaMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
KafkaProto - Class in org.hyperledger.fabric.protos.orderer
 
KEEPALIVE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
KEEPALIVE = 18;
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.DelState
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetState
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.PutState
 
KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
KEY_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
KEY_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
KEY_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
KEY_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.KeyInfo
 
KEY_MATERIAL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.KeyInfo
 
KEY_POLICIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
KeyInfo - Class in org.hyperledger.fabric.protos.msp
KeyInfo represents a (secret) key that is either already stored in the bccsp/keystore or key material to be imported to the bccsp key-store.
KeyInfo.Builder - Class in org.hyperledger.fabric.protos.msp
KeyInfo represents a (secret) key that is either already stored in the bccsp/keystore or key material to be imported to the bccsp key-store.
KeyInfoOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
KeyModification - Class in org.hyperledger.fabric.protos.ledger.queryresult
KeyModification -- QueryResult for history query.
KeyModification.Builder - Class in org.hyperledger.fabric.protos.ledger.queryresult
KeyModification -- QueryResult for history query.
KeyModificationOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.queryresult
 
KNOWN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
KV - Class in org.hyperledger.fabric.protos.ledger.queryresult
KV -- QueryResult for range/execute query.
KV.Builder - Class in org.hyperledger.fabric.protos.ledger.queryresult
KV -- QueryResult for range/execute query.
KV_READS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
KV_VALUE - Static variable in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
KV = 0;
KVMetadataEntry - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVMetadataEntry captures a 'name'ed entry in the metadata of a key/key-hash.
KVMetadataEntry.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVMetadataEntry captures a 'name'ed entry in the metadata of a key/key-hash.
KVMetadataEntryOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
KVMetadataWrite - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVMetadataWrite captures all the entries in the metadata associated with a key
KVMetadataWrite.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVMetadataWrite captures all the entries in the metadata associated with a key
KVMetadataWriteHash - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVMetadataWriteHash captures all the upserts to the metadata associated with a key hash
KVMetadataWriteHash.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVMetadataWriteHash captures all the upserts to the metadata associated with a key hash
KVMetadataWriteHashOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
KVMetadataWriteOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
KVOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.queryresult
 
KVQueryResultProto - Class in org.hyperledger.fabric.protos.ledger.queryresult
 
KVRead - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVRead captures a read operation performed during transaction simulation A 'nil' version indicates a non-existing key read by the transaction
KVRead.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVRead captures a read operation performed during transaction simulation A 'nil' version indicates a non-existing key read by the transaction
KVReadHash - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVReadHash is similar to the KVRead in spirit.
KVReadHash.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVReadHash is similar to the KVRead in spirit.
KVReadHashOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
KVReadOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
KVRWSet - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVRWSet encapsulates the read-write set for a chaincode that operates upon a KV or Document data model This structure is used for both the public data and the private data
KVRWSet.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVRWSet encapsulates the read-write set for a chaincode that operates upon a KV or Document data model This structure is used for both the public data and the private data
KVRWSetOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
KVRWSetProto - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
KVWrite - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVWrite captures a write (update/delete) operation performed during transaction simulation
KVWrite.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVWrite captures a write (update/delete) operation performed during transaction simulation
KVWriteHash - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVWriteHash is similar to the KVWrite.
KVWriteHash.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
KVWriteHash is similar to the KVWrite.
KVWriteHashOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
KVWriteOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 

L

LABEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
LABEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
LABEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
LAST_CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
LAST_CONFIG_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
Deprecated.
LAST_OFFSET_PERSISTED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
LAST_ORIGINAL_OFFSET_PROCESSED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
LAST_RESUBMITTED_CONFIG_OFFSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
LAST_UPDATE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
LAST_VALIDATION_SEQ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
LASTBLOCKINSNAPSHOT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
LastConfig - Class in org.hyperledger.fabric.protos.common
LastConfig is the encoded value for the Metadata message which is encoded in the LAST_CONFIGURATION block metadata index
LastConfig.Builder - Class in org.hyperledger.fabric.protos.common
LastConfig is the encoded value for the Metadata message which is encoded in the LAST_CONFIGURATION block metadata index
LastConfigOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
Layout - Class in org.hyperledger.fabric.protos.discovery
Layout contains a mapping from a group name to number of peers that are needed for fulfilling an endorsement policy
Layout.Builder - Class in org.hyperledger.fabric.protos.discovery
Layout contains a mapping from a group name to number of peers that are needed for fulfilling an endorsement policy
LayoutOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
LAYOUTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
LEADERSHIP_MSG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
LeadershipMessage - Class in org.hyperledger.fabric.protos.gossip
Leadership Message is sent during leader election to inform remote peers about intent of peer to proclaim itself as leader
LeadershipMessage.Builder - Class in org.hyperledger.fabric.protos.gossip
Leadership Message is sent during leader election to inform remote peers about intent of peer to proclaim itself as leader
LeadershipMessageOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
LEDGER_HEIGHT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Properties
 
LedgerProto - Class in org.hyperledger.fabric.protos.common
 
LEFT_CHANNEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Properties
 
LifecycleEvent - Class in org.hyperledger.fabric.protos.peer
LifecycleEvent is used as the payload of the chaincode event emitted by LSCC
LifecycleEvent.Builder - Class in org.hyperledger.fabric.protos.peer
LifecycleEvent is used as the payload of the chaincode event emitted by LSCC
LifecycleEventOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
LifecycleProto - Class in org.hyperledger.fabric.protos.peer.lifecycle
 
LOCAL_PACKAGE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
LOCAL_PEERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Query
 
LocalPeerQuery - Class in org.hyperledger.fabric.protos.discovery
LocalPeerQuery queries for peers in a non channel context
LocalPeerQuery.Builder - Class in org.hyperledger.fabric.protos.discovery
LocalPeerQuery queries for peers in a non channel context
LocalPeerQueryOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 

M

MAJORITY_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
Requires a strict majority (greater than half) of the sub-policies be satisfied
MARSHAL_TX_ERROR_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
MARSHAL_TX_ERROR = 15;
MAX_COUNT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
MAX_DEGREE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
MAX_INFLIGHT_BLOCKS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
MAX_LEVEL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
MAX_LEVEL_HASHES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
MAX_MESSAGE_COUNT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BatchSize
 
MAXIMUM_PEER_COUNT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
MAXIMUM_PEER_COUNT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
MEM_REQ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
MEM_RES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
Member - Class in org.hyperledger.fabric.protos.gossip
Member holds membership-related information about a peer
Member.Builder - Class in org.hyperledger.fabric.protos.gossip
Member holds membership-related information about a peer
MEMBER_ONLY_READ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
MEMBER_ONLY_READ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
MEMBER_ONLY_WRITE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
MEMBER_ONLY_WRITE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
MEMBER_ORGS_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
MEMBER_ORGS_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
MEMBER_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
Represents an MSP Member
MemberOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
MEMBERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.QueryResult
 
MEMBERSHIP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
MEMBERSHIP_INFO_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Peer
 
MembershipRequest - Class in org.hyperledger.fabric.protos.gossip
MembershipRequest is used to ask membership information from a remote peer
MembershipRequest.Builder - Class in org.hyperledger.fabric.protos.gossip
MembershipRequest is used to ask membership information from a remote peer
MembershipRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
MembershipResponse - Class in org.hyperledger.fabric.protos.gossip
MembershipResponse is used for replying to MembershipRequests
MembershipResponse.Builder - Class in org.hyperledger.fabric.protos.gossip
MembershipResponse is used for replying to MembershipRequests
MembershipResponseOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
mergeAck(Acknowledgement) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
mergeAction(ChaincodeEndorsedAction) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
The list of actions to apply to the ledger
mergeAdminOuIdentifier(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the admins
mergeAliveMsg(AliveMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Membership
mergeAuthentication(AuthInfo) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
authentication contains information that the service uses to check the client's eligibility for the queries.
mergeBlock(Block) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
mergeBlock(Block) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
.common.Block block = 1 [json_name = "block"];
mergeBlock(Block) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
mergeBlockAndPrivateData(BlockAndPrivateData) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
mergeBlockAttestation(BlockAttestation) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
mergeBootstrappingSnapshotInfo(BootstrappingSnapshotInfo) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
mergeCcQuery(ChaincodeQuery) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ChaincodeQuery queries for chaincodes by their name and version.
mergeCcQueryRes(ChaincodeQueryResult) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
mergeChaincodeEvent(ChaincodeEvent) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
event emitted by chaincode.
mergeChaincodeEvent(ChaincodeEvent) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
mergeChaincodeId(ChaincodeID) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the ChaincodeID of executing this invocation.
mergeChaincodeId(ChaincodeID) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
The ID of the chaincode to target.
mergeChaincodeId(ChaincodeID) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
mergeChaincodeSpec(ChaincodeSpec) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
mergeChaincodeSpec(ChaincodeSpec) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
mergeChannelConfig(Config) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config channel_config = 1 [json_name = "channelConfig"];
mergeChannelGroup(ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
mergeClientOuIdentifier(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the clients
mergeCollectionConfigs(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
mergeCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
mergeCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
mergeCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
mergeCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
mergeCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
mergeCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
mergeConfig(Config) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
A marshaled Config structure
mergeConfigQuery(ConfigQuery) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
mergeConfigResult(ConfigResult) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
mergeConn(ConnEstablish) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
ConnEstablish, used for establishing a connection
mergeConnect(KafkaMessageConnect) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
mergeConsensusRequest(ConsensusRequest) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
consensus_request is a consensus specific message.
mergeCryptoConfig(FabricCryptoConfig) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
mergeData(BlockData) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockData data = 2 [json_name = "data"];
mergeDataDig(DataDigest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
mergeDataMsg(DataMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Contains a ledger block
mergeDataReq(DataRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
mergeDataUpdate(DataUpdate) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
mergeDigest(PvtDataDigest) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
mergeEmpty(Empty) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Empty message, used for pinging
mergeEndorsement(Endorsement) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The endorsement of the proposal, basically the endorser's signature over the payload
mergeEndorsementPolicy(ApplicationPolicy) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
mergeEndorsementPolicy(ApplicationPolicy) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
mergeEnvelope(Envelope) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
The transaction envelope.
mergeError(Error) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
Error indicates failure or refusal to process the query
mergeFabricNodeOus(FabricNodeOUs) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
mergeFilter(ChaincodeInterest) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
mergeFilteredBlock(FilteredBlock) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
mergeFrom(Message) - Method in class com.google.rpc.Status.Builder
 
mergeFrom(Status) - Method in class com.google.rpc.Status.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class com.google.rpc.Status.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
mergeFrom(ApplicationPolicy) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
mergeFrom(Block) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
mergeFrom(BlockchainInfo) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
mergeFrom(BlockData) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
mergeFrom(BlockDataHashingStructure) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
mergeFrom(BlockHeader) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
mergeFrom(BlockMetadata) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
mergeFrom(BootstrappingSnapshotInfo) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
mergeFrom(Capabilities) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
mergeFrom(Capability) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
mergeFrom(ChannelHeader) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
mergeFrom(CollectionConfig) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
mergeFrom(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
mergeFrom(CollectionPolicyConfig) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
mergeFrom(CombinedPrincipal) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
mergeFrom(Config) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
mergeFrom(ConfigEnvelope) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
mergeFrom(ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
mergeFrom(ConfigPolicy) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
mergeFrom(ConfigSignature) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
mergeFrom(ConfigUpdate) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
mergeFrom(ConfigUpdateEnvelope) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
mergeFrom(ConfigValue) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
mergeFrom(Consortium) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
mergeFrom(Envelope) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
mergeFrom(HashingAlgorithm) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
mergeFrom(Header) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
mergeFrom(ImplicitMetaPolicy) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
mergeFrom(LastConfig) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
mergeFrom(Metadata) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
mergeFrom(MetadataSignature) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
mergeFrom(MSPIdentityAnonymity) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
mergeFrom(MSPPrincipal) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
mergeFrom(MSPRole) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
mergeFrom(OrdererAddresses) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
mergeFrom(OrdererBlockMetadata) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
mergeFrom(OrganizationUnit) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
mergeFrom(Payload) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
mergeFrom(Policy) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
mergeFrom(SignatureHeader) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
mergeFrom(SignaturePolicy) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
mergeFrom(SignaturePolicy.NOutOf) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
mergeFrom(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
mergeFrom(StaticCollectionConfig) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
mergeFrom(AuthInfo) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
mergeFrom(ChaincodeQuery) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
mergeFrom(ChaincodeQueryResult) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
mergeFrom(ConfigQuery) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
mergeFrom(ConfigResult) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
mergeFrom(EndorsementDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
mergeFrom(Endpoint) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
mergeFrom(Endpoints) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
mergeFrom(Error) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
mergeFrom(Layout) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
mergeFrom(LocalPeerQuery) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
mergeFrom(Peer) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
mergeFrom(PeerMembershipQuery) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
mergeFrom(PeerMembershipResult) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
mergeFrom(Peers) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
mergeFrom(Query) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
mergeFrom(QueryResult) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
mergeFrom(Request) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
mergeFrom(Response) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
mergeFrom(SignedRequest) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
mergeFrom(ChaincodeEventsRequest) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
mergeFrom(ChaincodeEventsResponse) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
mergeFrom(CommitStatusRequest) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
mergeFrom(CommitStatusResponse) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
mergeFrom(EndorseRequest) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
mergeFrom(EndorseResponse) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
mergeFrom(ErrorDetail) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
mergeFrom(EvaluateRequest) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
mergeFrom(EvaluateResponse) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
mergeFrom(PreparedTransaction) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
mergeFrom(ProposedTransaction) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
mergeFrom(SignedChaincodeEventsRequest) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
mergeFrom(SignedCommitStatusRequest) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
mergeFrom(SubmitRequest) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
mergeFrom(SubmitResponse) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
mergeFrom(Acknowledgement) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
mergeFrom(AliveMessage) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
mergeFrom(Chaincode) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
mergeFrom(ConnEstablish) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
mergeFrom(DataDigest) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
mergeFrom(DataMessage) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
mergeFrom(DataRequest) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
mergeFrom(DataUpdate) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
mergeFrom(Empty) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
mergeFrom(Envelope) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
mergeFrom(GossipHello) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
mergeFrom(GossipMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
mergeFrom(LeadershipMessage) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
mergeFrom(Member) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
mergeFrom(MembershipRequest) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
mergeFrom(MembershipResponse) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
mergeFrom(Payload) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
mergeFrom(PeerIdentity) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
mergeFrom(PeerTime) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
mergeFrom(PrivateDataMessage) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
mergeFrom(PrivatePayload) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
mergeFrom(Properties) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
mergeFrom(PvtDataDigest) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
mergeFrom(PvtDataElement) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
mergeFrom(PvtDataPayload) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
mergeFrom(RemotePvtDataRequest) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
mergeFrom(RemotePvtDataResponse) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
mergeFrom(RemoteStateRequest) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
mergeFrom(RemoteStateResponse) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
mergeFrom(Secret) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
mergeFrom(SecretEnvelope) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
mergeFrom(StateInfo) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
mergeFrom(StateInfoPullRequest) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
mergeFrom(StateInfoSnapshot) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
mergeFrom(KeyModification) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
mergeFrom(KV) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
mergeFrom(CollectionHashedReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
mergeFrom(CollectionPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
mergeFrom(HashedRWSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
mergeFrom(KVMetadataEntry) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
mergeFrom(KVMetadataWrite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
mergeFrom(KVMetadataWriteHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
mergeFrom(KVRead) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
mergeFrom(KVReadHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
mergeFrom(KVRWSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
mergeFrom(KVWrite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
mergeFrom(KVWriteHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
mergeFrom(QueryReads) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
mergeFrom(QueryReadsMerkleSummary) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
mergeFrom(RangeQueryInfo) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
mergeFrom(Version) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
mergeFrom(NsPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
mergeFrom(NsReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
mergeFrom(TxPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
mergeFrom(TxReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
mergeFrom(FabricCryptoConfig) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
mergeFrom(FabricMSPConfig) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
mergeFrom(FabricNodeOUs) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
mergeFrom(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
mergeFrom(IdemixMSPConfig) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
mergeFrom(IdemixMSPSignerConfig) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
mergeFrom(KeyInfo) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
mergeFrom(MSPConfig) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
mergeFrom(SerializedIdemixIdentity) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
mergeFrom(SerializedIdentity) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
mergeFrom(SigningIdentityInfo) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
mergeFrom(BatchSize) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
mergeFrom(BatchTimeout) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
mergeFrom(BlockAttestation) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
mergeFrom(BlockAttestationResponse) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
mergeFrom(BroadcastResponse) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
mergeFrom(ChannelRestrictions) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
mergeFrom(ConsensusRequest) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
mergeFrom(ConsensusType) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
mergeFrom(DeliverResponse) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
mergeFrom(BlockMetadata) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
mergeFrom(ClusterMetadata) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
mergeFrom(ConfigMetadata) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
mergeFrom(Consenter) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
mergeFrom(Options) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
mergeFrom(KafkaBrokers) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
mergeFrom(KafkaMessage) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
mergeFrom(KafkaMessageConnect) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
mergeFrom(KafkaMessageRegular) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
mergeFrom(KafkaMessageTimeToCut) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
mergeFrom(KafkaMetadata) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
mergeFrom(SeekInfo) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
mergeFrom(SeekNewest) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
mergeFrom(SeekNextCommit) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
mergeFrom(SeekOldest) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
mergeFrom(SeekPosition) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
mergeFrom(SeekSpecified) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
mergeFrom(StepRequest) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
mergeFrom(StepResponse) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
mergeFrom(SubmitRequest) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
mergeFrom(SubmitResponse) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
mergeFrom(ACLs) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
mergeFrom(AnchorPeer) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
mergeFrom(AnchorPeers) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
mergeFrom(APIResource) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
mergeFrom(ApplicationPolicy) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
mergeFrom(BlockAndPrivateData) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
mergeFrom(CDSData) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
mergeFrom(ChaincodeAction) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
mergeFrom(ChaincodeActionPayload) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
mergeFrom(ChaincodeCall) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
mergeFrom(ChaincodeData) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
mergeFrom(ChaincodeDeploymentSpec) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
mergeFrom(ChaincodeEndorsedAction) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
mergeFrom(ChaincodeEndorsement) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
mergeFrom(ChaincodeEvent) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
mergeFrom(ChaincodeHeaderExtension) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
mergeFrom(ChaincodeID) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
mergeFrom(ChaincodeIdentifier) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
mergeFrom(ChaincodeInfo) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
mergeFrom(ChaincodeInput) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
mergeFrom(ChaincodeInterest) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
mergeFrom(ChaincodeInvocationSpec) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
mergeFrom(ChaincodeMessage) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
mergeFrom(ChaincodeProposalPayload) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
mergeFrom(ChaincodeQueryResponse) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
mergeFrom(ChaincodeSpec) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
mergeFrom(ChaincodeValidation) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
mergeFrom(ChannelInfo) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
mergeFrom(ChannelQueryResponse) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
mergeFrom(CollectionConfig) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
mergeFrom(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
mergeFrom(CollectionPolicyConfig) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
mergeFrom(ConfigTree) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
mergeFrom(DeliverResponse) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
mergeFrom(DelState) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
mergeFrom(Endorsement) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
mergeFrom(FilteredBlock) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
mergeFrom(FilteredChaincodeAction) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
mergeFrom(FilteredTransaction) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
mergeFrom(FilteredTransactionActions) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
mergeFrom(GetHistoryForKey) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
mergeFrom(GetQueryResult) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
mergeFrom(GetState) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
mergeFrom(GetStateByRange) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
mergeFrom(GetStateMetadata) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
mergeFrom(JoinBySnapshotStatus) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
mergeFrom(ApproveChaincodeDefinitionForMyOrgArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
mergeFrom(ApproveChaincodeDefinitionForMyOrgResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
mergeFrom(ChaincodeEndorsementInfo) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
mergeFrom(ChaincodeSource) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
mergeFrom(ChaincodeSource.Local) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
mergeFrom(ChaincodeSource.Unavailable) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
mergeFrom(ChaincodeValidationInfo) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
mergeFrom(CheckCommitReadinessArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
mergeFrom(CheckCommitReadinessResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
mergeFrom(CommitChaincodeDefinitionArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
mergeFrom(CommitChaincodeDefinitionResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
mergeFrom(GetInstalledChaincodePackageArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
mergeFrom(GetInstalledChaincodePackageResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
mergeFrom(InstallChaincodeArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
mergeFrom(InstallChaincodeResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
mergeFrom(QueryApprovedChaincodeDefinitionArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
mergeFrom(QueryApprovedChaincodeDefinitionResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
mergeFrom(QueryChaincodeDefinitionArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
mergeFrom(QueryChaincodeDefinitionResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
mergeFrom(QueryChaincodeDefinitionsArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
mergeFrom(QueryChaincodeDefinitionsResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
mergeFrom(QueryChaincodeDefinitionsResult.ChaincodeDefinition) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
mergeFrom(QueryInstalledChaincodeArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
mergeFrom(QueryInstalledChaincodeResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
mergeFrom(QueryInstalledChaincodeResult.Chaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
mergeFrom(QueryInstalledChaincodeResult.References) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
mergeFrom(QueryInstalledChaincodesArgs) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
mergeFrom(QueryInstalledChaincodesResult) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
mergeFrom(QueryInstalledChaincodesResult.Chaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
mergeFrom(QueryInstalledChaincodesResult.InstalledChaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
mergeFrom(QueryInstalledChaincodesResult.References) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
mergeFrom(StateData) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
mergeFrom(StateMetadata) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
mergeFrom(LifecycleEvent) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
mergeFrom(ProcessedTransaction) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
mergeFrom(Proposal) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
mergeFrom(ProposalResponse) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
mergeFrom(ProposalResponsePayload) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
mergeFrom(PurgePrivateState) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
mergeFrom(PutState) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
mergeFrom(PutStateMetadata) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
mergeFrom(QueryMetadata) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
mergeFrom(QueryPendingSnapshotsResponse) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
mergeFrom(QueryResponse) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
mergeFrom(QueryResponseMetadata) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
mergeFrom(QueryResultBytes) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
mergeFrom(QueryStateClose) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
mergeFrom(QueryStateNext) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
mergeFrom(Response) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
mergeFrom(SignedChaincodeDeploymentSpec) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
mergeFrom(SignedProposal) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
mergeFrom(SignedSnapshotRequest) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
mergeFrom(SnapshotQuery) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
mergeFrom(SnapshotRequest) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
mergeFrom(StateMetadata) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
mergeFrom(StateMetadataResult) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
mergeFrom(StaticCollectionConfig) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
mergeFrom(Transaction) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
mergeFrom(TransactionAction) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
mergeFrom(VSCCArgs) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
mergeFrom(Message) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
mergeFrom(TxPvtReadWriteSetWithConfigInfo) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
mergeHeader(BlockHeader) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockHeader header = 1 [json_name = "header"];
mergeHeader(Header) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Header is included to provide identity and prevent replay
mergeHeader(BlockHeader) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockHeader header = 1 [json_name = "header"];
mergeHello(GossipHello) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for push&pull
mergeInput(ChaincodeInput) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeInput input = 3 [json_name = "input"];
mergeInstantiationPolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
InstantiationPolicy for the chaincode
mergeInterest(ChaincodeInterest) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The chaincode interest derived from simulating the proposal.
mergeLastConfig(LastConfig) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
mergeLastUpdate(Envelope) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
The last CONFIG_UPDATE message which generated this current configuration
mergeLeadershipMsg(LeadershipMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to indicate intent of peer to become leader
mergeLocalPackage(ChaincodeSource.Local) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
mergeLocalPeers(LocalPeerQuery) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
mergeMemberOrgsPolicy(CollectionPolicyConfig) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
mergeMemberOrgsPolicy(CollectionPolicyConfig) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
mergeMembers(PeerMembershipResult) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
mergeMembership(Member) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.Member membership = 1 [json_name = "membership"];
mergeMembershipInfo(Envelope) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
mergeMemReq(MembershipRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
mergeMemRes(MembershipResponse) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
mergeMetadata(BlockMetadata) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
mergeMetadata(BlockMetadata) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
mergeMetadata(StateMetadata) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
mergeNewest(SeekNewest) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
mergeNextCommit(SeekNextCommit) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
mergeNOutOf(SignaturePolicy.NOutOf) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
mergeOldest(SeekOldest) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
mergeOptions(Options) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
.etcdraft.Options options = 2 [json_name = "options"];
mergeOrdererOuIdentifier(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the orderers
mergePayload(Payload) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
.gossip.Payload payload = 1 [json_name = "payload"];
mergePayload(PrivatePayload) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
mergePayload(Envelope) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
content is the fabric transaction that is forwarded to the cluster member.
mergePeerIdentity(PeerIdentity) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to learn of a peer's certificate
mergePeerOuIdentifier(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the peers
mergePeerQuery(PeerMembershipQuery) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
mergePolicy(Policy) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
.common.Policy policy = 2 [json_name = "policy"];
mergePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Policy endorsement policy for the chaincode instance
mergePreparedTransaction(Envelope) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
mergePreparedTransaction(Envelope) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
The signed set of endorsed transaction responses to submit.
mergePrivateData(PrivateDataMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Encapsulates private data used to distribute private rwset after the endorsement
mergePrivateReq(RemotePvtDataRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to request private data
mergePrivateRes(RemotePvtDataResponse) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to respond to private data requests
mergePrivateSigner(KeyInfo) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PrivateSigner denotes a reference to the private key of the peer's signing identity
mergeProperties(Properties) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.Properties properties = 5 [json_name = "properties"];
mergeProposal(SignedProposal) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The signed proposal.
mergeProposal(SignedProposal) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
mergeProposedTransaction(SignedProposal) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The signed proposal ready for endorsement.
mergeProposedTransaction(SignedProposal) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
The signed proposal ready for evaluation.
mergePvtRwset(TxPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
mergeRawReads(QueryReads) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
mergeReadSet(ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
mergeReadsMerkleHashes(QueryReadsMerkleSummary) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
mergeRegular(KafkaMessageRegular) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
mergeResourcesConfig(Config) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
mergeResponse(Response) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the result of executing this invocation.
mergeResponse(Response) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
A response message indicating whether the endorsement of the action was successful
mergeResult(Response) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
mergeRule(SignaturePolicy) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
mergeSecretEnvelope(SecretEnvelope) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
mergeSelfInformation(Envelope) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
mergeSignatureHeader(SignatureHeader) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The signature header that contains creator identity and nonce
mergeSignatureHeader(SignatureHeader) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The signature header that contains creator identity and nonce
mergeSignaturePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
mergeSignaturePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
Initially, only a signature policy is supported.
mergeSignaturePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
mergeSignaturePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
Initially, only a signature policy is supported.
mergeSigner(IdemixMSPSignerConfig) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
signer may contain crypto material to configure a default signer
mergeSigningIdentity(SigningIdentityInfo) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
mergeSource(ChaincodeSource) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
mergeSource(ChaincodeSource) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
mergeSpecified(SeekSpecified) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
mergeStart(SeekPosition) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to start the deliver from
mergeStartPosition(SeekPosition) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Position within the ledger at which to start reading events.
mergeStateInfo(Envelope) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
mergeStateInfo(StateInfo) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for relaying information about state
mergeStateInfoPullReq(StateInfoPullRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for asking for StateInfoSnapshots
mergeStateRequest(RemoteStateRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to ask from a remote peer a set of blocks
mergeStateResponse(RemoteStateResponse) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to send a set of blocks to a remote peer
mergeStateSnapshot(StateInfoSnapshot) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for sending sets of StateInfo messages
mergeStaticCollectionConfig(StaticCollectionConfig) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
mergeStaticCollectionConfig(StaticCollectionConfig) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
mergeStop(SeekPosition) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to stop the deliver
mergeSubmitRequest(SubmitRequest) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
submit_request is a relay of a transaction.
mergeSubmitRes(SubmitResponse) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
mergeTimestamp(Timestamp) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Timestamp is the local time when the message was created by the sender
mergeTimestamp(PeerTime) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
mergeTimestamp(PeerTime) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
mergeTimestamp(PeerTime) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
mergeTimestamp(Timestamp) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
mergeTimestamp(Timestamp) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
mergeTimestamp(Timestamp) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Timestamp is the time that the message was created as defined by the sender
mergeTimeToCut(KafkaMessageTimeToCut) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
mergeTransactionActions(FilteredTransactionActions) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
mergeTransactionEnvelope(Envelope) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An Envelope which includes a processed transaction
mergeUnavailable(ChaincodeSource.Unavailable) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
mergeUnknownFields(UnknownFieldSet) - Method in class com.google.rpc.Status.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
mergeVersion(Version) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
.kvrwset.Version version = 2 [json_name = "version"];
mergeVersion(Version) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
.kvrwset.Version version = 2 [json_name = "version"];
mergeWriteSet(ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
WriteSet lists the portion of the config which was written, this should included updated Versions
MESSAGE_FIELD_NUMBER - Static variable in class com.google.rpc.Status
 
MESSAGE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
MESSAGE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Response
 
MESSAGE_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.HeaderType
Used for messages which are signed but opaque
MessageProto - Class in org.hyperledger.fabric.protos.gossip
 
Metadata - Class in org.hyperledger.fabric.protos.common
Metadata is a common structure to be used to encode block metadata
Metadata.Builder - Class in org.hyperledger.fabric.protos.common
Metadata is a common structure to be used to encode block metadata
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Block
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockMetadata
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Chaincode
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipHello
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Member
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
METADATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryResponse
 
METADATA_WRITES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
METADATA_WRITES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
METADATAHASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.CDSData
 
MetaDataKeys - Enum in org.hyperledger.fabric.protos.peer
Reserved entries in the key-level metadata map
MetadataOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
MetadataProto - Class in org.hyperledger.fabric.protos.orderer.etcdraft
 
MetadataSignature - Class in org.hyperledger.fabric.protos.common
Protobuf type common.MetadataSignature
MetadataSignature.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.MetadataSignature
MetadataSignatureOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
METAKEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StateMetadata
 
MOD_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigGroup
 
MOD_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
MOD_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigValue
 
MSG_TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataDigest
 
MSG_TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataRequest
 
MSG_TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
MSG_TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipHello
 
MSP_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
MSP_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.MSPRole
 
MSP_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
MSP_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
MSP = 2;
MSPConfig - Class in org.hyperledger.fabric.protos.msp
MSPConfig collects all the configuration information for an MSP.
MSPConfig.Builder - Class in org.hyperledger.fabric.protos.msp
MSPConfig collects all the configuration information for an MSP.
MSPConfigOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
MSPConfigProto - Class in org.hyperledger.fabric.protos.msp
 
MSPID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
MSPIdentityAnonymity - Class in org.hyperledger.fabric.protos.common
MSPIdentityAnonymity can be used to enforce an identity to be anonymous or nominal.
MSPIdentityAnonymity.Builder - Class in org.hyperledger.fabric.protos.common
MSPIdentityAnonymity can be used to enforce an identity to be anonymous or nominal.
MSPIdentityAnonymity.MSPIdentityAnonymityType - Enum in org.hyperledger.fabric.protos.common
Protobuf enum common.MSPIdentityAnonymity.MSPIdentityAnonymityType
MSPIdentityAnonymityOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
MSPPrincipal - Class in org.hyperledger.fabric.protos.common
MSPPrincipal aims to represent an MSP-centric set of identities.
MSPPrincipal.Builder - Class in org.hyperledger.fabric.protos.common
MSPPrincipal aims to represent an MSP-centric set of identities.
MSPPrincipal.Classification - Enum in org.hyperledger.fabric.protos.common
Protobuf enum common.MSPPrincipal.Classification
MSPPrincipalOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
MSPPrincipalProto - Class in org.hyperledger.fabric.protos.common
 
MSPRole - Class in org.hyperledger.fabric.protos.common
MSPRole governs the organization of the Principal field of an MSPPrincipal when it aims to define one of the two dedicated roles within an MSP: Admin and Members.
MSPRole.Builder - Class in org.hyperledger.fabric.protos.common
MSPRole governs the organization of the Principal field of an MSPPrincipal when it aims to define one of the two dedicated roles within an MSP: Admin and Members.
MSPRole.MSPRoleType - Enum in org.hyperledger.fabric.protos.common
Protobuf enum common.MSPRole.MSPRoleType
MSPRoleOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
MSPS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
MVCC_READ_CONFLICT_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
MVCC_READ_CONFLICT = 11;

N

N_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
N_OUT_OF_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Consortium
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Chaincode
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
NAME_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
NAMESPACE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
NAMESPACE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
NAMESPACE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
NAMESPACE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
NAMESPACE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.gossip.GossipGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.ClusterGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.DeliverGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.EndorserGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBuilder() - Static method in class com.google.rpc.Status
 
newBuilder(Status) - Static method in class com.google.rpc.Status
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
newBuilder(ApplicationPolicy) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Block
 
newBuilder(Block) - Static method in class org.hyperledger.fabric.protos.common.Block
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
newBuilder(BlockchainInfo) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
newBuilder(BlockData) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
newBuilder(BlockDataHashingStructure) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
newBuilder(BlockHeader) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
newBuilder(BlockMetadata) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
newBuilder(BootstrappingSnapshotInfo) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
newBuilder(Capabilities) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Capability
 
newBuilder(Capability) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
newBuilder(ChannelHeader) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
newBuilder(CollectionConfig) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
newBuilder(CollectionConfigPackage) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
newBuilder(CollectionPolicyConfig) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
newBuilder(CombinedPrincipal) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Config
 
newBuilder(Config) - Static method in class org.hyperledger.fabric.protos.common.Config
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
newBuilder(ConfigEnvelope) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
newBuilder(ConfigGroup) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
newBuilder(ConfigPolicy) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
newBuilder(ConfigSignature) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
newBuilder(ConfigUpdate) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
newBuilder(ConfigUpdateEnvelope) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
newBuilder(ConfigValue) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
newBuilder(Consortium) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
newBuilder(Envelope) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
newBuilder(HashingAlgorithm) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Header
 
newBuilder(Header) - Static method in class org.hyperledger.fabric.protos.common.Header
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
newBuilder(ImplicitMetaPolicy) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
newBuilder(LastConfig) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
newBuilder(Metadata) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
newBuilder(MetadataSignature) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
newBuilder(MSPIdentityAnonymity) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
newBuilder(MSPPrincipal) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
newBuilder(MSPRole) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
newBuilder(OrdererAddresses) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
newBuilder(OrdererBlockMetadata) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
newBuilder(OrganizationUnit) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Payload
 
newBuilder(Payload) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.Policy
 
newBuilder(Policy) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
newBuilder(SignatureHeader) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
newBuilder(SignaturePolicy) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
newBuilder(SignaturePolicy.NOutOf) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
newBuilder(SignaturePolicyEnvelope) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
newBuilder(StaticCollectionConfig) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
newBuilder(AuthInfo) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
newBuilder(ChaincodeQuery) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
newBuilder(ChaincodeQueryResult) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
newBuilder(ConfigQuery) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
newBuilder(ConfigResult) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
newBuilder(EndorsementDescriptor) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
newBuilder(Endpoint) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
newBuilder(Endpoints) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
newBuilder(Error) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
newBuilder(Layout) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
newBuilder(LocalPeerQuery) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
newBuilder(Peer) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
newBuilder(PeerMembershipQuery) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
newBuilder(PeerMembershipResult) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
newBuilder(Peers) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
newBuilder(Query) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
newBuilder(QueryResult) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
newBuilder(Request) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
newBuilder(Response) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
newBuilder(SignedRequest) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
newBuilder(ChaincodeEventsRequest) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
newBuilder(ChaincodeEventsResponse) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
newBuilder(CommitStatusRequest) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
newBuilder(CommitStatusResponse) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
newBuilder(EndorseRequest) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
newBuilder(EndorseResponse) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
newBuilder(ErrorDetail) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
newBuilder(EvaluateRequest) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
newBuilder(EvaluateResponse) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
newBuilder(PreparedTransaction) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
newBuilder(ProposedTransaction) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
newBuilder(SignedChaincodeEventsRequest) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
newBuilder(SignedCommitStatusRequest) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
newBuilder(SubmitRequest) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
newBuilder(SubmitResponse) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
newBuilder(Acknowledgement) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
newBuilder(AliveMessage) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
newBuilder(Chaincode) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
newBuilder(ConnEstablish) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
newBuilder(DataDigest) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
newBuilder(DataMessage) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
newBuilder(DataRequest) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
newBuilder(DataUpdate) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
newBuilder(Empty) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
newBuilder(Envelope) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
newBuilder(GossipHello) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
newBuilder(GossipMessage) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
newBuilder(LeadershipMessage) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
newBuilder(Member) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
newBuilder(MembershipRequest) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
newBuilder(MembershipResponse) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
newBuilder(Payload) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
newBuilder(PeerIdentity) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
newBuilder(PeerTime) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
newBuilder(PrivateDataMessage) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
newBuilder(PrivatePayload) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
newBuilder(Properties) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
newBuilder(PvtDataDigest) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
newBuilder(PvtDataElement) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
newBuilder(PvtDataPayload) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
newBuilder(RemotePvtDataRequest) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
newBuilder(RemotePvtDataResponse) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
newBuilder(RemoteStateRequest) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
newBuilder(RemoteStateResponse) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
newBuilder(Secret) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
newBuilder(SecretEnvelope) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
newBuilder(StateInfo) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
newBuilder(StateInfoPullRequest) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
newBuilder(StateInfoSnapshot) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
newBuilder(KeyModification) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
newBuilder(KV) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
newBuilder(CollectionHashedReadWriteSet) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
newBuilder(CollectionPvtReadWriteSet) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
newBuilder(HashedRWSet) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
newBuilder(KVMetadataEntry) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
newBuilder(KVMetadataWrite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
newBuilder(KVMetadataWriteHash) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
newBuilder(KVRead) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
newBuilder(KVReadHash) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
newBuilder(KVRWSet) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
newBuilder(KVWrite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
newBuilder(KVWriteHash) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
newBuilder(QueryReads) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
newBuilder(QueryReadsMerkleSummary) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
newBuilder(RangeQueryInfo) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
newBuilder(Version) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
newBuilder(NsPvtReadWriteSet) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
newBuilder(NsReadWriteSet) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
newBuilder(TxPvtReadWriteSet) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
newBuilder(TxReadWriteSet) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
newBuilder(FabricCryptoConfig) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
newBuilder(FabricMSPConfig) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
newBuilder(FabricNodeOUs) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
newBuilder(FabricOUIdentifier) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
newBuilder(IdemixMSPConfig) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
newBuilder(IdemixMSPSignerConfig) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
newBuilder(KeyInfo) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
newBuilder(MSPConfig) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
newBuilder(SerializedIdemixIdentity) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
newBuilder(SerializedIdentity) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
newBuilder(SigningIdentityInfo) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
newBuilder(BatchSize) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
newBuilder(BatchTimeout) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
newBuilder(BlockAttestation) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
newBuilder(BlockAttestationResponse) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
newBuilder(BroadcastResponse) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
newBuilder(ChannelRestrictions) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
newBuilder(ConsensusRequest) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
newBuilder(ConsensusType) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
newBuilder(DeliverResponse) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
newBuilder(BlockMetadata) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
newBuilder(ClusterMetadata) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
newBuilder(ConfigMetadata) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
newBuilder(Consenter) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
newBuilder(Options) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
newBuilder(KafkaBrokers) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
newBuilder(KafkaMessage) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
newBuilder(KafkaMessageConnect) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
newBuilder(KafkaMessageRegular) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
newBuilder(KafkaMessageTimeToCut) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
newBuilder(KafkaMetadata) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
newBuilder(SeekInfo) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
newBuilder(SeekNewest) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
newBuilder(SeekNextCommit) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
newBuilder(SeekOldest) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
newBuilder(SeekPosition) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
newBuilder(SeekSpecified) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
newBuilder(StepRequest) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
newBuilder(StepResponse) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
newBuilder(SubmitRequest) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
newBuilder(SubmitResponse) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
newBuilder(ACLs) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
newBuilder(AnchorPeer) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
newBuilder(AnchorPeers) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
newBuilder(APIResource) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
newBuilder(ApplicationPolicy) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
newBuilder(BlockAndPrivateData) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
newBuilder(CDSData) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
newBuilder(ChaincodeAction) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
newBuilder(ChaincodeActionPayload) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
newBuilder(ChaincodeCall) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
newBuilder(ChaincodeData) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
newBuilder(ChaincodeDeploymentSpec) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
newBuilder(ChaincodeEndorsedAction) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
newBuilder(ChaincodeEndorsement) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
newBuilder(ChaincodeEvent) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
newBuilder(ChaincodeHeaderExtension) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
newBuilder(ChaincodeID) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
newBuilder(ChaincodeIdentifier) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
newBuilder(ChaincodeInfo) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
newBuilder(ChaincodeInput) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
newBuilder(ChaincodeInterest) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
newBuilder(ChaincodeInvocationSpec) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
newBuilder(ChaincodeMessage) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
newBuilder(ChaincodeProposalPayload) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
newBuilder(ChaincodeQueryResponse) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
newBuilder(ChaincodeSpec) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
newBuilder(ChaincodeValidation) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
newBuilder(ChannelInfo) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
newBuilder(ChannelQueryResponse) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
newBuilder(CollectionConfig) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
newBuilder(CollectionConfigPackage) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
newBuilder(CollectionPolicyConfig) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
newBuilder(ConfigTree) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
newBuilder(DeliverResponse) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
newBuilder(DelState) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
newBuilder(Endorsement) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
newBuilder(FilteredBlock) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
newBuilder(FilteredChaincodeAction) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
newBuilder(FilteredTransaction) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
newBuilder(FilteredTransactionActions) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
newBuilder(GetHistoryForKey) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
newBuilder(GetQueryResult) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
newBuilder(GetState) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
newBuilder(GetStateByRange) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
newBuilder(GetStateMetadata) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
newBuilder(JoinBySnapshotStatus) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
newBuilder(ApproveChaincodeDefinitionForMyOrgArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
newBuilder(ApproveChaincodeDefinitionForMyOrgResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
newBuilder(ChaincodeEndorsementInfo) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
newBuilder(ChaincodeSource.Local) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
newBuilder(ChaincodeSource) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
newBuilder(ChaincodeSource.Unavailable) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
newBuilder(ChaincodeValidationInfo) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
newBuilder(CheckCommitReadinessArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
newBuilder(CheckCommitReadinessResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
newBuilder(CommitChaincodeDefinitionArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
newBuilder(CommitChaincodeDefinitionResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
newBuilder(GetInstalledChaincodePackageArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
newBuilder(GetInstalledChaincodePackageResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
newBuilder(InstallChaincodeArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
newBuilder(InstallChaincodeResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
newBuilder(QueryApprovedChaincodeDefinitionArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
newBuilder(QueryApprovedChaincodeDefinitionResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
newBuilder(QueryChaincodeDefinitionArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
newBuilder(QueryChaincodeDefinitionResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
newBuilder(QueryChaincodeDefinitionsArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
newBuilder(QueryChaincodeDefinitionsResult.ChaincodeDefinition) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
newBuilder(QueryChaincodeDefinitionsResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
newBuilder(QueryInstalledChaincodeArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
newBuilder(QueryInstalledChaincodeResult.Chaincode) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
newBuilder(QueryInstalledChaincodeResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
newBuilder(QueryInstalledChaincodeResult.References) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
newBuilder(QueryInstalledChaincodesArgs) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
newBuilder(QueryInstalledChaincodesResult.Chaincode) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
newBuilder(QueryInstalledChaincodesResult.InstalledChaincode) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
newBuilder(QueryInstalledChaincodesResult) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
newBuilder(QueryInstalledChaincodesResult.References) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
newBuilder(StateData) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
newBuilder(StateMetadata) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
newBuilder(LifecycleEvent) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
newBuilder(ProcessedTransaction) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
newBuilder(Proposal) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
newBuilder(ProposalResponse) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
newBuilder(ProposalResponsePayload) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
newBuilder(PurgePrivateState) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
newBuilder(PutState) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
newBuilder(PutStateMetadata) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
newBuilder(QueryMetadata) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
newBuilder(QueryPendingSnapshotsResponse) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
newBuilder(QueryResponse) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
newBuilder(QueryResponseMetadata) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
newBuilder(QueryResultBytes) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
newBuilder(QueryStateClose) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
newBuilder(QueryStateNext) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.Response
 
newBuilder(Response) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
newBuilder(SignedChaincodeDeploymentSpec) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
newBuilder(SignedProposal) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
newBuilder(SignedSnapshotRequest) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
newBuilder(SnapshotQuery) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
newBuilder(SnapshotRequest) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
newBuilder(StateMetadata) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
newBuilder(StateMetadataResult) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
newBuilder(StaticCollectionConfig) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
newBuilder(Transaction) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
newBuilder(TransactionAction) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
newBuilder(VSCCArgs) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
newBuilder() - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
newBuilder(TxPvtReadWriteSetWithConfigInfo) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
newBuilderForType() - Method in class com.google.rpc.Status
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Block
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.BlockData
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Capability
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Config
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Consortium
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Envelope
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Header
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Metadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Payload
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.Policy
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Error
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Request
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.Response
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.Member
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.DelState
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.GetState
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.PutState
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.Response
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
newBuilderForType() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
NEWEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.gossip.GossipGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.ClusterGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.DeliverGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.EndorserGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.gossip.GossipGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.orderer.ClusterGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.DeliverGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.EndorserGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc
Creates a new async stub that supports all call types for the service
NEXT_COMMIT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
NEXT_CONSENTER_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
NIL_ENVELOPE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
NIL_ENVELOPE = 1;
NIL_TXACTION_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
NIL_TXACTION = 16;
NO_PRIVATE_READS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
NO_PUBLIC_WRITES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
NODE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
NODE = 2;
NOMINAL_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
Represents a nominal MSP Identity
NONCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignatureHeader
 
NONCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataDigest
 
NONCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataRequest
 
NONCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
NONCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipHello
 
NONCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
NORMAL_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
NORMAL = 1;
NOT_FOUND_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
NOT_FOUND = 404;
NOT_IMPLEMENTED_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
NOT_IMPLEMENTED = 501;
NOT_VALIDATED_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
NOT_VALIDATED = 254;
NS_PVT_RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
NS_RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
NsPvtReadWriteSet - Class in org.hyperledger.fabric.protos.ledger.rwset
NsPvtReadWriteSet encapsulates the private read-write set for a chaincode
NsPvtReadWriteSet.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset
NsPvtReadWriteSet encapsulates the private read-write set for a chaincode
NsPvtReadWriteSetOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset
 
NsReadWriteSet - Class in org.hyperledger.fabric.protos.ledger.rwset
NsReadWriteSet encapsulates the read-write set for a chaincode
NsReadWriteSet.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset
NsReadWriteSet encapsulates the read-write set for a chaincode
NsReadWriteSetOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset
 
NUMBER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockHeader
 
NUMBER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
NUMBER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
NYM_X_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
NYM_Y_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 

O

OLDEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
Options - Class in org.hyperledger.fabric.protos.orderer.etcdraft
Options to be specified for all the etcd/raft nodes.
Options.Builder - Class in org.hyperledger.fabric.protos.orderer.etcdraft
Options to be specified for all the etcd/raft nodes.
OPTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
OptionsOrBuilder - Interface in org.hyperledger.fabric.protos.orderer.etcdraft
 
ORDERER_OU_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
ORDERER_TRANSACTION_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.HeaderType
Used internally by the orderer for management
ORDERER_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
Deprecated.
ORDERER_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
Represents an MSP Orderer
OrdererAddresses - Class in org.hyperledger.fabric.protos.common
OrdererAddresses is encoded into the configuration transaction as a configuration item of type Chain with a Key of "OrdererAddresses" and a Value of OrdererAddresses as marshaled protobuf bytes
OrdererAddresses.Builder - Class in org.hyperledger.fabric.protos.common
OrdererAddresses is encoded into the configuration transaction as a configuration item of type Chain with a Key of "OrdererAddresses" and a Value of OrdererAddresses as marshaled protobuf bytes
OrdererAddressesOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
OrdererBlockMetadata - Class in org.hyperledger.fabric.protos.common
OrdererBlockMetadata defines metadata that is set by the ordering service.
OrdererBlockMetadata.Builder - Class in org.hyperledger.fabric.protos.common
OrdererBlockMetadata defines metadata that is set by the ordering service.
OrdererBlockMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ORDERERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
org.hyperledger.fabric.protos.common - package org.hyperledger.fabric.protos.common
 
org.hyperledger.fabric.protos.discovery - package org.hyperledger.fabric.protos.discovery
 
org.hyperledger.fabric.protos.gateway - package org.hyperledger.fabric.protos.gateway
 
org.hyperledger.fabric.protos.gossip - package org.hyperledger.fabric.protos.gossip
 
org.hyperledger.fabric.protos.ledger.queryresult - package org.hyperledger.fabric.protos.ledger.queryresult
 
org.hyperledger.fabric.protos.ledger.rwset - package org.hyperledger.fabric.protos.ledger.rwset
 
org.hyperledger.fabric.protos.ledger.rwset.kvrwset - package org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
org.hyperledger.fabric.protos.msp - package org.hyperledger.fabric.protos.msp
 
org.hyperledger.fabric.protos.orderer - package org.hyperledger.fabric.protos.orderer
 
org.hyperledger.fabric.protos.orderer.etcdraft - package org.hyperledger.fabric.protos.orderer.etcdraft
 
org.hyperledger.fabric.protos.peer - package org.hyperledger.fabric.protos.peer
 
org.hyperledger.fabric.protos.peer.lifecycle - package org.hyperledger.fabric.protos.peer.lifecycle
 
org.hyperledger.fabric.protos.transientstore - package org.hyperledger.fabric.protos.transientstore
 
ORG_ONLY_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
ORG_ONLY = 2;
ORGANIZATION_UNIT_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
one of a member of MSP network, and the one of an administrator of an MSP network
ORGANIZATIONAL_UNIT_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
ORGANIZATIONAL_UNIT_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
ORGANIZATIONAL_UNIT_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
ORGANIZATIONAL_UNIT_IDENTIFIERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
OrganizationUnit - Class in org.hyperledger.fabric.protos.common
OrganizationUnit governs the organization of the Principal field of a policy principal when a specific organization unity members are to be defined within a policy principal.
OrganizationUnit.Builder - Class in org.hyperledger.fabric.protos.common
OrganizationUnit governs the organization of the Principal field of a policy principal when a specific organization unity members are to be defined within a policy principal.
OrganizationUnitOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
ORIGINAL_OFFSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
OU_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
OWNER_ENDORSEMENTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 

P

PACKAGE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
PACKAGE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
PACKAGE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
PACKAGE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
PACKAGE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
PACKAGE_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
PAGESIZE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseDelimitedFrom(InputStream) - Static method in class com.google.rpc.Status
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class com.google.rpc.Status
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseDelimitedFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(ByteBuffer) - Static method in class com.google.rpc.Status
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class com.google.rpc.Status
 
parseFrom(ByteString) - Static method in class com.google.rpc.Status
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class com.google.rpc.Status
 
parseFrom(byte[]) - Static method in class com.google.rpc.Status
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class com.google.rpc.Status
 
parseFrom(InputStream) - Static method in class com.google.rpc.Status
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class com.google.rpc.Status
 
parseFrom(CodedInputStream) - Static method in class com.google.rpc.Status
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class com.google.rpc.Status
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Block
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Config
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Header
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parseFrom(ByteBuffer) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(ByteString) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(byte[]) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(InputStream) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(CodedInputStream) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
parser() - Static method in class com.google.rpc.Status
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Block
 
parser() - Static method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.common.BlockData
 
parser() - Static method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
parser() - Static method in class org.hyperledger.fabric.protos.common.BlockHeader
 
parser() - Static method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Capabilities
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Capability
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
parser() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
parser() - Static method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
parser() - Static method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
parser() - Static method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Config
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ConfigValue
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Consortium
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Envelope
 
parser() - Static method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Header
 
parser() - Static method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
parser() - Static method in class org.hyperledger.fabric.protos.common.LastConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Metadata
 
parser() - Static method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
parser() - Static method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
parser() - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
parser() - Static method in class org.hyperledger.fabric.protos.common.MSPRole
 
parser() - Static method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
parser() - Static method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Payload
 
parser() - Static method in class org.hyperledger.fabric.protos.common.Policy
 
parser() - Static method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
parser() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
parser() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
parser() - Static method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
parser() - Static method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Error
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Layout
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Peer
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Peers
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Query
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Request
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.Response
 
parser() - Static method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.Empty
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.Envelope
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.Member
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.Payload
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.Properties
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.Secret
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
parser() - Static method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
parser() - Static method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ACLs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.APIResource
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.CDSData
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.DelState
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.Endorsement
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.GetState
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.Proposal
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.PutState
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.Response
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.Transaction
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
parser() - Static method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
parser() - Static method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
PATH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
PATH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
Payload - Class in org.hyperledger.fabric.protos.common
Payload is the message contents (and header to allow for signing)
Payload - Class in org.hyperledger.fabric.protos.gossip
Payload contains a block
Payload.Builder - Class in org.hyperledger.fabric.protos.common
Payload is the message contents (and header to allow for signing)
Payload.Builder - Class in org.hyperledger.fabric.protos.gossip
Payload contains a block
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Envelope
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.DataMessage
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Envelope
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Proposal
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Response
 
PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.TransactionAction
 
PayloadOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
PayloadOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
PAYLOADS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
Peer - Class in org.hyperledger.fabric.protos.discovery
Peer contains information about the peer such as its channel specific state, and membership information.
Peer.Builder - Class in org.hyperledger.fabric.protos.discovery
Peer contains information about the peer such as its channel specific state, and membership information.
PEER_IDENTITY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
PEER_OU_IDENTIFIER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
PEER_QUERY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Query
 
PEER_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
Represents an MSP Peer
PeerIdentity - Class in org.hyperledger.fabric.protos.gossip
PeerIdentity defines the identity of the peer Used to make other peers learn of the identity of a certain peer
PeerIdentity.Builder - Class in org.hyperledger.fabric.protos.gossip
PeerIdentity defines the identity of the peer Used to make other peers learn of the identity of a certain peer
PeerIdentityOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
PeerMembershipQuery - Class in org.hyperledger.fabric.protos.discovery
PeerMembershipQuery requests PeerMembershipResult.
PeerMembershipQuery.Builder - Class in org.hyperledger.fabric.protos.discovery
PeerMembershipQuery requests PeerMembershipResult.
PeerMembershipQueryOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
PeerMembershipResult - Class in org.hyperledger.fabric.protos.discovery
PeerMembershipResult contains peers mapped by their organizations (MSP_ID)
PeerMembershipResult.Builder - Class in org.hyperledger.fabric.protos.discovery
PeerMembershipResult contains peers mapped by their organizations (MSP_ID)
PeerMembershipResultOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
PeerOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
PeerProto - Class in org.hyperledger.fabric.protos.peer
 
Peers - Class in org.hyperledger.fabric.protos.discovery
Peers contains a list of Peer(s)
Peers.Builder - Class in org.hyperledger.fabric.protos.discovery
Peers contains a list of Peer(s)
PEERS_BY_ORG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
PEERS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Peers
 
PeersOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
PeerTime - Class in org.hyperledger.fabric.protos.gossip
PeerTime defines the logical time of a peer's life
PeerTime.Builder - Class in org.hyperledger.fabric.protos.gossip
PeerTime defines the logical time of a peer's life
PeerTimeOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
PHANTOM_READ_CONFLICT_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
PHANTOM_READ_CONFLICT = 12;
ping(Empty) - Method in class org.hyperledger.fabric.protos.gossip.GossipGrpc.GossipBlockingStub
Ping is used to probe a remote peer's aliveness
ping(Empty) - Method in class org.hyperledger.fabric.protos.gossip.GossipGrpc.GossipFutureStub
Ping is used to probe a remote peer's aliveness
ping(Empty, StreamObserver<Empty>) - Method in class org.hyperledger.fabric.protos.gossip.GossipGrpc.GossipImplBase
Ping is used to probe a remote peer's aliveness
ping(Empty, StreamObserver<Empty>) - Method in class org.hyperledger.fabric.protos.gossip.GossipGrpc.GossipStub
Ping is used to probe a remote peer's aliveness
PKI_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
PKI_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
PKI_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Member
 
PKI_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
PKI_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.StateInfo
 
POLICIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigGroup
 
PoliciesProto - Class in org.hyperledger.fabric.protos.common
 
Policy - Class in org.hyperledger.fabric.protos.common
Policy expresses a policy which the orderer can evaluate, because there has been some desire expressed to support multiple policy engines, this is typed as a oneof for now
Policy.Builder - Class in org.hyperledger.fabric.protos.common
Policy expresses a policy which the orderer can evaluate, because there has been some desire expressed to support multiple policy engines, this is typed as a oneof for now
Policy.PolicyType - Enum in org.hyperledger.fabric.protos.common
Protobuf enum common.Policy.PolicyType
POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
POLICY_REF_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.APIResource
 
PolicyOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
PolicyProto - Class in org.hyperledger.fabric.protos.peer
 
PORT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Endpoint
 
PORT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
PORT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
PREFERRED_MAX_BYTES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BatchSize
 
PREPARED_TRANSACTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
PREPARED_TRANSACTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
PreparedTransaction - Class in org.hyperledger.fabric.protos.gateway
PreparedTransaction contains the details required for offline signing prior to submitting a transaction.
PreparedTransaction.Builder - Class in org.hyperledger.fabric.protos.gateway
PreparedTransaction contains the details required for offline signing prior to submitting a transaction.
PreparedTransactionOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
PREVIOUS_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockHeader
 
PREVIOUSBLOCKHASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
PRINCIPAL_CLASSIFICATION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
PRINCIPAL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
PRINCIPALS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
PRIVATE_DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
PRIVATE_DATA_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Payload
 
PRIVATE_DATA_MAP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
PRIVATE_RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
PRIVATE_SIGNER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
PRIVATE_SIM_HEIGHT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
PrivateDataMessage - Class in org.hyperledger.fabric.protos.gossip
PrivateDataMessage message which includes private data information to distributed once transaction has been endorsed
PrivateDataMessage.Builder - Class in org.hyperledger.fabric.protos.gossip
PrivateDataMessage message which includes private data information to distributed once transaction has been endorsed
PrivateDataMessageOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
PrivatePayload - Class in org.hyperledger.fabric.protos.gossip
PrivatePayload payload to encapsulate private data with collection name to enable routing based on collection partitioning
PrivatePayload.Builder - Class in org.hyperledger.fabric.protos.gossip
PrivatePayload payload to encapsulate private data with collection name to enable routing based on collection partitioning
PrivatePayloadOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
PRIVATEREQ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
PRIVATERES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
PROBE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
ProcessedTransaction - Class in org.hyperledger.fabric.protos.peer
ProcessedTransaction wraps an Envelope that includes a transaction along with an indication of whether the transaction was validated or invalidated by committing peer.
ProcessedTransaction.Builder - Class in org.hyperledger.fabric.protos.peer
ProcessedTransaction wraps an Envelope that includes a transaction along with an indication of whether the transaction was validated or invalidated by committing peer.
ProcessedTransactionOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
processProposal(SignedProposal) - Method in class org.hyperledger.fabric.protos.peer.EndorserGrpc.EndorserBlockingStub
 
processProposal(SignedProposal) - Method in class org.hyperledger.fabric.protos.peer.EndorserGrpc.EndorserFutureStub
 
processProposal(SignedProposal, StreamObserver<ProposalResponse>) - Method in class org.hyperledger.fabric.protos.peer.EndorserGrpc.EndorserImplBase
 
processProposal(SignedProposal, StreamObserver<ProposalResponse>) - Method in class org.hyperledger.fabric.protos.peer.EndorserGrpc.EndorserStub
 
PROOF_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
Properties - Class in org.hyperledger.fabric.protos.gossip
Protobuf type gossip.Properties
Properties.Builder - Class in org.hyperledger.fabric.protos.gossip
Protobuf type gossip.Properties
PROPERTIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.StateInfo
 
PropertiesOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
Proposal - Class in org.hyperledger.fabric.protos.peer
A Proposal is sent to an endorser for endorsement.
Proposal.Builder - Class in org.hyperledger.fabric.protos.peer
A Proposal is sent to an endorser for endorsement.
PROPOSAL_BYTES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SignedProposal
 
PROPOSAL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
PROPOSAL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
PROPOSAL_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
PROPOSAL_RESPONSE_PAYLOAD_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
ProposalOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ProposalProto - Class in org.hyperledger.fabric.protos.peer
 
ProposalResponse - Class in org.hyperledger.fabric.protos.peer
A ProposalResponse is returned from an endorser to the proposal submitter.
ProposalResponse.Builder - Class in org.hyperledger.fabric.protos.peer
A ProposalResponse is returned from an endorser to the proposal submitter.
ProposalResponseOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ProposalResponsePayload - Class in org.hyperledger.fabric.protos.peer
ProposalResponsePayload is the payload of a proposal response.
ProposalResponsePayload.Builder - Class in org.hyperledger.fabric.protos.peer
ProposalResponsePayload is the payload of a proposal response.
ProposalResponsePayloadOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
ProposalResponseProto - Class in org.hyperledger.fabric.protos.peer
 
PROPOSED_TRANSACTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
PROPOSED_TRANSACTION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
ProposedTransaction - Class in org.hyperledger.fabric.protos.gateway
ProposedTransaction contains the details required for offline signing prior to evaluating or endorsing a transaction.
ProposedTransaction.Builder - Class in org.hyperledger.fabric.protos.gateway
ProposedTransaction contains the details required for offline signing prior to evaluating or endorsing a transaction.
ProposedTransactionOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
ProtocolProto - Class in org.hyperledger.fabric.protos.discovery
 
PUBLIC_SIGNER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
PullMsgType - Enum in org.hyperledger.fabric.protos.gossip
Protobuf enum gossip.PullMsgType
PURGE_PRIVATE_DATA_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
PURGE_PRIVATE_DATA = 23;
PurgePrivateState - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.PurgePrivateState
PurgePrivateState.Builder - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.PurgePrivateState
PurgePrivateStateOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
PUT_STATE_METADATA_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
PUT_STATE_METADATA = 21;
PUT_STATE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
PUT_STATE = 9;
putAcls(String, APIResource) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
putAllAcls(Map<String, APIResource>) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
putAllApprovals(Map<String, Boolean>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
map<string, bool> approvals = 1 [json_name = "approvals"];
putAllApprovals(Map<String, Boolean>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
map<string, bool> approvals = 8 [json_name = "approvals"];
putAllCapabilities(Map<String, Capability>) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
putAllCollectionConfigs(Map<String, CollectionConfigPackage>) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
putAllDecorations(Map<String, ByteString>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
map<string, bytes> decorations = 2 [json_name = "decorations"];
putAllEndorsersByGroups(Map<String, Peers>) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies the endorsers, separated to groups.
putAllGroups(Map<String, ConfigGroup>) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
putAllIsolatedData(Map<String, ByteString>) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
putAllMsps(Map<String, FabricMSPConfig>) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
msps is a map from MSP_ID to FabricMSPConfig
putAllOrderers(Map<String, Endpoints>) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
orderers is a map from MSP_ID to endpoint lists of orderers
putAllPeersByOrg(Map<String, Peers>) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
putAllPolicies(Map<String, ConfigPolicy>) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
putAllPrivateDataMap(Map<Long, TxPvtReadWriteSet>) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
putAllQuantitiesByGroup(Map<String, Integer>) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Specifies how many non repeated signatures of each group are needed for endorsement
putAllReferences(Map<String, QueryInstalledChaincodeResult.References>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
putAllReferences(Map<String, QueryInstalledChaincodesResult.References>) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
putAllTransientMap(Map<String, ByteString>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
TransientMap contains data (e.g.
putAllValues(Map<String, ConfigValue>) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
putApprovals(String, boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
map<string, bool> approvals = 1 [json_name = "approvals"];
putApprovals(String, boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
map<string, bool> approvals = 8 [json_name = "approvals"];
putCapabilities(String, Capability) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
putCollectionConfigs(String, CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
putDecorations(String, ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
map<string, bytes> decorations = 2 [json_name = "decorations"];
putEndorsersByGroups(String, Peers) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies the endorsers, separated to groups.
putGroups(String, ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
putIsolatedData(String, ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
putMsps(String, FabricMSPConfig) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
msps is a map from MSP_ID to FabricMSPConfig
putOrderers(String, Endpoints) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
orderers is a map from MSP_ID to endpoint lists of orderers
putPeersByOrg(String, Peers) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
putPolicies(String, ConfigPolicy) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
putPrivateDataMap(long, TxPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
putQuantitiesByGroup(String, int) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Specifies how many non repeated signatures of each group are needed for endorsement
putReferences(String, QueryInstalledChaincodeResult.References) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
putReferences(String, QueryInstalledChaincodesResult.References) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
PutState - Class in org.hyperledger.fabric.protos.peer
PutState is the payload of a ChaincodeMessage.
PutState.Builder - Class in org.hyperledger.fabric.protos.peer
PutState is the payload of a ChaincodeMessage.
PutStateMetadata - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.PutStateMetadata
PutStateMetadata.Builder - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.PutStateMetadata
PutStateMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
PutStateOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
putTransientMap(String, ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
TransientMap contains data (e.g.
putValues(String, ConfigValue) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
PVT_RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
PVT_RWSET_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
PvtDataDigest - Class in org.hyperledger.fabric.protos.gossip
PvtDataDigest defines a digest of private data
PvtDataDigest.Builder - Class in org.hyperledger.fabric.protos.gossip
PvtDataDigest defines a digest of private data
PvtDataDigestOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
PvtDataElement - Class in org.hyperledger.fabric.protos.gossip
Protobuf type gossip.PvtDataElement
PvtDataElement.Builder - Class in org.hyperledger.fabric.protos.gossip
Protobuf type gossip.PvtDataElement
PvtDataElementOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
PvtDataPayload - Class in org.hyperledger.fabric.protos.gossip
PvtPayload augments private rwset data and tx index inside the block
PvtDataPayload.Builder - Class in org.hyperledger.fabric.protos.gossip
PvtPayload augments private rwset data and tx index inside the block
PvtDataPayloadOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 

Q

QUANTITIES_BY_GROUP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Layout
 
QUERIES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Request
 
Query - Class in org.hyperledger.fabric.protos.discovery
Query asks for information in the context of a specific channel
Query.Builder - Class in org.hyperledger.fabric.protos.discovery
Query asks for information in the context of a specific channel
Query.QueryCase - Enum in org.hyperledger.fabric.protos.discovery
 
QUERY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
QUERY_STATE_CLOSE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
QUERY_STATE_CLOSE = 17;
QUERY_STATE_NEXT_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
QUERY_STATE_NEXT = 16;
QueryApprovedChaincodeDefinitionArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryApprovedChaincodeDefinitionArgs is the message used as arguments to `_lifecycle.QueryApprovedChaincodeDefinition`.
QueryApprovedChaincodeDefinitionArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryApprovedChaincodeDefinitionArgs is the message used as arguments to `_lifecycle.QueryApprovedChaincodeDefinition`.
QueryApprovedChaincodeDefinitionArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryApprovedChaincodeDefinitionResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryApprovedChaincodeDefinitionResult is the message returned by `_lifecycle.QueryApprovedChaincodeDefinition`.
QueryApprovedChaincodeDefinitionResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryApprovedChaincodeDefinitionResult is the message returned by `_lifecycle.QueryApprovedChaincodeDefinition`.
QueryApprovedChaincodeDefinitionResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryChaincodeDefinitionArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryChaincodeDefinitionArgs is the message used as arguments to `_lifecycle.QueryChaincodeDefinition`.
QueryChaincodeDefinitionArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryChaincodeDefinitionArgs is the message used as arguments to `_lifecycle.QueryChaincodeDefinition`.
QueryChaincodeDefinitionArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryChaincodeDefinitionResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryChaincodeDefinitionResult is the message returned by `_lifecycle.QueryChaincodeDefinition`.
QueryChaincodeDefinitionResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryChaincodeDefinitionResult is the message returned by `_lifecycle.QueryChaincodeDefinition`.
QueryChaincodeDefinitionResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryChaincodeDefinitionsArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryChaincodeDefinitionsArgs is the message used as arguments to `_lifecycle.QueryChaincodeDefinitions`.
QueryChaincodeDefinitionsArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryChaincodeDefinitionsArgs is the message used as arguments to `_lifecycle.QueryChaincodeDefinitions`.
QueryChaincodeDefinitionsArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryChaincodeDefinitionsResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryChaincodeDefinitionsResult is the message returned by `_lifecycle.QueryChaincodeDefinitions`.
QueryChaincodeDefinitionsResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryChaincodeDefinitionsResult is the message returned by `_lifecycle.QueryChaincodeDefinitions`.
QueryChaincodeDefinitionsResult.ChaincodeDefinition - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
QueryChaincodeDefinitionsResult.ChaincodeDefinitionOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryChaincodeDefinitionsResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodeArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryInstalledChaincodeArgs is the message used as arguments '_lifecycle.QueryInstalledChaincode'
QueryInstalledChaincodeArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryInstalledChaincodeArgs is the message used as arguments '_lifecycle.QueryInstalledChaincode'
QueryInstalledChaincodeArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodeResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryInstalledChaincodeResult is the message returned by '_lifecycle.QueryInstalledChaincode'
QueryInstalledChaincodeResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryInstalledChaincodeResult is the message returned by '_lifecycle.QueryInstalledChaincode'
QueryInstalledChaincodeResult.Chaincode - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodeResult.Chaincode
QueryInstalledChaincodeResult.Chaincode.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodeResult.Chaincode
QueryInstalledChaincodeResult.ChaincodeOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodeResult.References - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodeResult.References
QueryInstalledChaincodeResult.References.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodeResult.References
QueryInstalledChaincodeResult.ReferencesOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodeResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodesArgs - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryInstalledChaincodesArgs currently is an empty argument to '_lifecycle.QueryInstalledChaincodes'.
QueryInstalledChaincodesArgs.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryInstalledChaincodesArgs currently is an empty argument to '_lifecycle.QueryInstalledChaincodes'.
QueryInstalledChaincodesArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodesResult - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryInstalledChaincodesResult is the message returned by '_lifecycle.QueryInstalledChaincodes'.
QueryInstalledChaincodesResult.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
QueryInstalledChaincodesResult is the message returned by '_lifecycle.QueryInstalledChaincodes'.
QueryInstalledChaincodesResult.Chaincode - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodesResult.Chaincode
QueryInstalledChaincodesResult.Chaincode.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodesResult.Chaincode
QueryInstalledChaincodesResult.ChaincodeOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodesResult.InstalledChaincode - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
QueryInstalledChaincodesResult.InstalledChaincode.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
QueryInstalledChaincodesResult.InstalledChaincodeOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodesResult.References - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodesResult.References
QueryInstalledChaincodesResult.References.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
Protobuf type lifecycle.QueryInstalledChaincodesResult.References
QueryInstalledChaincodesResult.ReferencesOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryInstalledChaincodesResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
QueryMetadata - Class in org.hyperledger.fabric.protos.peer
QueryMetadata is the metadata of a GetStateByRange and GetQueryResult.
QueryMetadata.Builder - Class in org.hyperledger.fabric.protos.peer
QueryMetadata is the metadata of a GetStateByRange and GetQueryResult.
QueryMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
QueryOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
queryPendings(SignedSnapshotRequest) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotBlockingStub
Query pending snapshots query.
queryPendings(SignedSnapshotRequest) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotFutureStub
Query pending snapshots query.
queryPendings(SignedSnapshotRequest, StreamObserver<QueryPendingSnapshotsResponse>) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotImplBase
Query pending snapshots query.
queryPendings(SignedSnapshotRequest, StreamObserver<QueryPendingSnapshotsResponse>) - Method in class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotStub
Query pending snapshots query.
QueryPendingSnapshotsResponse - Class in org.hyperledger.fabric.protos.peer
QueryPendingSnapshotsResponse specifies the response payload of a query pending snapshots request
QueryPendingSnapshotsResponse.Builder - Class in org.hyperledger.fabric.protos.peer
QueryPendingSnapshotsResponse specifies the response payload of a query pending snapshots request
QueryPendingSnapshotsResponseOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
QueryProto - Class in org.hyperledger.fabric.protos.peer
 
QueryReads - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
QueryReads encapsulates the KVReads for the items read by a transaction as a result of a query execution
QueryReads.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
QueryReads encapsulates the KVReads for the items read by a transaction as a result of a query execution
QueryReadsMerkleSummary - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
QueryReadsMerkleSummary encapsulates the Merkle-tree hashes for the QueryReads This allows to reduce the size of RWSet in the presence of query results by storing certain hashes instead of actual results.
QueryReadsMerkleSummary.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
QueryReadsMerkleSummary encapsulates the Merkle-tree hashes for the QueryReads This allows to reduce the size of RWSet in the presence of query results by storing certain hashes instead of actual results.
QueryReadsMerkleSummaryOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
QueryReadsOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
QueryResponse - Class in org.hyperledger.fabric.protos.peer
QueryResponse is returned by the peer as a result of a GetStateByRange, GetQueryResult, and GetHistoryForKey.
QueryResponse.Builder - Class in org.hyperledger.fabric.protos.peer
QueryResponse is returned by the peer as a result of a GetStateByRange, GetQueryResult, and GetHistoryForKey.
QueryResponseMetadata - Class in org.hyperledger.fabric.protos.peer
QueryResponseMetadata is the metadata of a QueryResponse.
QueryResponseMetadata.Builder - Class in org.hyperledger.fabric.protos.peer
QueryResponseMetadata is the metadata of a QueryResponse.
QueryResponseMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
QueryResponseOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
QueryResult - Class in org.hyperledger.fabric.protos.discovery
QueryResult contains a result for a given Query.
QueryResult.Builder - Class in org.hyperledger.fabric.protos.discovery
QueryResult contains a result for a given Query.
QueryResult.ResultCase - Enum in org.hyperledger.fabric.protos.discovery
 
QueryResultBytes - Class in org.hyperledger.fabric.protos.peer
QueryResultBytes hold the byte representation of a record returned by the peer.
QueryResultBytes.Builder - Class in org.hyperledger.fabric.protos.peer
QueryResultBytes hold the byte representation of a record returned by the peer.
QueryResultBytesOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
QueryResultOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
QueryStateClose - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.QueryStateClose
QueryStateClose.Builder - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.QueryStateClose
QueryStateCloseOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
QueryStateNext - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.QueryStateNext
QueryStateNext.Builder - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.QueryStateNext
QueryStateNextOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 

R

RAFT_INDEX_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
RANGE_QUERIES_INFO_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
RangeQueryInfo - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
RangeQueryInfo encapsulates the details of a range query performed by a transaction during simulation.
RangeQueryInfo.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
RangeQueryInfo encapsulates the details of a range query performed by a transaction during simulation.
RangeQueryInfo.ReadsInfoCase - Enum in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
RangeQueryInfoOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
RAW_READS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
READ_SET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
READS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
READS_MERKLE_HASHES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
READY_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
READY = 4;
REFERENCES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
REFERENCES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
register(StreamObserver<ChaincodeMessage>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc.ChaincodeSupportImplBase
 
register(StreamObserver<ChaincodeMessage>) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc.ChaincodeSupportStub
 
REGISTER_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
REGISTER = 1;
registerAllExtensions(ExtensionRegistryLite) - Static method in class com.google.rpc.StatusProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class com.google.rpc.StatusProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CollectionProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.common.CollectionProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.CommonProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.common.CommonProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigTxProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.common.ConfigTxProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.ConfigurationProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.common.ConfigurationProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.LedgerProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.common.LedgerProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipalProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.common.MSPPrincipalProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.common.PoliciesProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.common.PoliciesProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.discovery.ProtocolProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.discovery.ProtocolProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gateway.GatewayProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.gateway.GatewayProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.gossip.MessageProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.gossip.MessageProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KVQueryResultProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.ledger.queryresult.KVQueryResultProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSetProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.RWSetProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.ledger.rwset.RWSetProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.IdentitiesProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.msp.IdentitiesProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfigProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.msp.MSPConfigProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.AbProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.orderer.AbProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.BlockattestationProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.orderer.BlockattestationProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ClusterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.orderer.ClusterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.ConfigurationProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.orderer.ConfigurationProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigurationProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigurationProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.MetadataProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.orderer.etcdraft.MetadataProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.orderer.KafkaProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEventProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeEventProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeShimProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.ChaincodeShimProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.CollectionProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.CollectionProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ConfigurationProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.ConfigurationProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.EventsProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.EventsProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeDefinitionProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeDefinitionProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.DbProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.DbProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.LifecycleProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.lifecycle.LifecycleProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PeerProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.PeerProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.PolicyProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.PolicyProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.ProposalProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponseProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.ProposalResponseProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.QueryProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.QueryProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.ResourcesProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.ResourcesProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SignedCcDepSpecProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.SignedCcDepSpecProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.SnapshotProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.peer.TransactionProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.peer.TransactionProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.hyperledger.fabric.protos.transientstore.TransientstoreProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.hyperledger.fabric.protos.transientstore.TransientstoreProto
 
REGISTERED_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
REGISTERED = 2;
REGULAR_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
RemotePvtDataRequest - Class in org.hyperledger.fabric.protos.gossip
RemotePrivateDataRequest message used to request missing private rwset
RemotePvtDataRequest.Builder - Class in org.hyperledger.fabric.protos.gossip
RemotePrivateDataRequest message used to request missing private rwset
RemotePvtDataRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
RemotePvtDataResponse - Class in org.hyperledger.fabric.protos.gossip
RemotePrivateData message to response on private data replication request
RemotePvtDataResponse.Builder - Class in org.hyperledger.fabric.protos.gossip
RemotePrivateData message to response on private data replication request
RemotePvtDataResponseOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
RemoteStateRequest - Class in org.hyperledger.fabric.protos.gossip
RemoteStateRequest is used to ask a set of blocks from a remote peer
RemoteStateRequest.Builder - Class in org.hyperledger.fabric.protos.gossip
RemoteStateRequest is used to ask a set of blocks from a remote peer
RemoteStateRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
RemoteStateResponse - Class in org.hyperledger.fabric.protos.gossip
RemoteStateResponse is used to send a set of blocks to a remote peer
RemoteStateResponse.Builder - Class in org.hyperledger.fabric.protos.gossip
RemoteStateResponse is used to send a set of blocks to a remote peer
RemoteStateResponseOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
removeAcls(String) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
map<string, .protos.APIResource> acls = 1 [json_name = "acls"];
removeActions(int) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
removeAlive(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
removeAnchorPeers(int) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
removeApprovals(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
map<string, bool> approvals = 1 [json_name = "approvals"];
removeApprovals(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
map<string, bool> approvals = 8 [json_name = "approvals"];
removeCapabilities(String) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
map<string, .common.Capability> capabilities = 1 [json_name = "capabilities"];
removeChaincodeActions(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
removeChaincodeDefinitions(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
removeChaincodes(int) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
removeChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
removeChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
removeChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
removeChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
removeChannels(int) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
removeCollectionConfigs(String) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
map<string, .protos.CollectionConfigPackage> collection_configs = 3 [json_name = "collectionConfigs"];
removeCollectionHashedRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
removeCollectionPvtRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
removeConfig(int) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
removeConfig(int) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
removeConsenters(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
removeContent(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
removeData(int) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
removeDead(int) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
removeDecorations(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
map<string, bytes> decorations = 2 [json_name = "decorations"];
removeDetails(int) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
removeDigests(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
removeElements(int) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
removeElements(int) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
removeEndorsements(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
removeEndorsersByGroups(String) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies the endorsers, separated to groups.
removeEndpoint(int) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
removeEntries(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
removeEntries(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
removeEntries(int) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
removeEvents(int) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
removeFilteredTransactions(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
removeGroups(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigGroup> groups = 2 [json_name = "groups"];
removeHashedReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
removeHashedWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
removeIdentities(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
removeInstalledChaincodes(int) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
removeInterests(int) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
removeIsolatedData(String) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Data which is not to be reflected in the resulting Config, but is still needed for some other purpose.
removeKeyPolicies(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
removeKvReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
removeLayouts(int) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
removeMetadataWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
removeMetadataWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
removeMsps(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
msps is a map from MSP_ID to FabricMSPConfig
removeNsPvtRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
removeNsRwset(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
removeOrderers(String) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
orderers is a map from MSP_ID to endpoint lists of orderers
removeOrganizationalUnitIdentifiers(int) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
removeOwnerEndorsements(int) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
removePayloads(int) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
removePeers(int) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
removePeersByOrg(String) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
map<string, .discovery.Peers> peers_by_org = 1 [json_name = "peersByOrg"];
removePolicies(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigPolicy> policies = 4 [json_name = "policies"];
removePrincipals(int) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
removePrivateDataMap(long) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
map from tx_seq_in_block to rwset.TxPvtReadWriteSet
removeQuantitiesByGroup(String) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
Specifies how many non repeated signatures of each group are needed for endorsement
removeQueries(int) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
removeRangeQueriesInfo(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
removeReads(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
removeReferences(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
map<string, .lifecycle.QueryInstalledChaincodeResult.References> references = 3 [json_name = "references"];
removeReferences(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
map<string, .lifecycle.QueryInstalledChaincodesResult.References> references = 3 [json_name = "references"];
removeResults(int) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
removeResults(int) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
removeRules(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
removeSignatures(int) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
removeSignatures(int) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
removeTransientMap(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
TransientMap contains data (e.g.
removeValues(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
map<string, .common.ConfigValue> values = 3 [json_name = "values"];
removeWrites(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
Request - Class in org.hyperledger.fabric.protos.discovery
Request contains authentication info about the client that sent the request and the queries it wishes to query the service
Request.Builder - Class in org.hyperledger.fabric.protos.discovery
Request contains authentication info about the client that sent the request and the queries it wishes to query the service
REQUEST_ENTITY_TOO_LARGE_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
REQUEST_ENTITY_TOO_LARGE = 413;
REQUEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
REQUEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
REQUEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
RequestOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
REQUIRED_PEER_COUNT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
REQUIRED_PEER_COUNT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
RESOURCES_CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ConfigTree
 
ResourcesProto - Class in org.hyperledger.fabric.protos.peer
 
Response - Class in org.hyperledger.fabric.protos.discovery
Protobuf type discovery.Response
Response - Class in org.hyperledger.fabric.protos.peer
A response with a representation similar to an HTTP response that can be used within another message.
Response.Builder - Class in org.hyperledger.fabric.protos.discovery
Protobuf type discovery.Response
Response.Builder - Class in org.hyperledger.fabric.protos.peer
A response with a representation similar to an HTTP response that can be used within another message.
RESPONSE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
RESPONSE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
RESPONSE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
RESPONSE = 13;
ResponseOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
ResponseOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
RESULT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
RESULT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
RESULTBYTES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
RESULTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Response
 
RESULTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
RESULTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.QueryResponse
 
REVOCATION_LIST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
REVOCATION_PK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
ROLE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.MSPRole
 
ROLE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
ROLE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
ROLE_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
Represents the one of the dedicated MSP roles, the
ROOT_CERTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
RULE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
RULE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
RULES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
RWSET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
RWSetProto - Class in org.hyperledger.fabric.protos.ledger.rwset
 

S

Secret - Class in org.hyperledger.fabric.protos.gossip
Secret is an entity that might be omitted from an Envelope when the remote peer that is receiving the Envelope shouldn't know the secret's content.
Secret.Builder - Class in org.hyperledger.fabric.protos.gossip
Secret is an entity that might be omitted from an Envelope when the remote peer that is receiving the Envelope shouldn't know the secret's content.
Secret.ContentCase - Enum in org.hyperledger.fabric.protos.gossip
 
SECRET_ENVELOPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Envelope
 
SecretEnvelope - Class in org.hyperledger.fabric.protos.gossip
SecretEnvelope is a marshalled Secret and a signature over it.
SecretEnvelope.Builder - Class in org.hyperledger.fabric.protos.gossip
SecretEnvelope is a marshalled Secret and a signature over it.
SecretEnvelopeOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
SecretOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
SeekInfo - Class in org.hyperledger.fabric.protos.orderer
SeekInfo specifies the range of requested blocks to return If the start position is not found, an error is immediately returned Otherwise, blocks are returned until a missing block is encountered, then behavior is dictated by the SeekBehavior specified.
SeekInfo.Builder - Class in org.hyperledger.fabric.protos.orderer
SeekInfo specifies the range of requested blocks to return If the start position is not found, an error is immediately returned Otherwise, blocks are returned until a missing block is encountered, then behavior is dictated by the SeekBehavior specified.
SeekInfo.SeekBehavior - Enum in org.hyperledger.fabric.protos.orderer
If BLOCK_UNTIL_READY is specified, the reply will block until the requested blocks are available, if FAIL_IF_NOT_READY is specified, the reply will return an error indicating that the block is not found.
SeekInfo.SeekErrorResponse - Enum in org.hyperledger.fabric.protos.orderer
SeekErrorTolerance indicates to the server how block provider errors should be tolerated.
SeekInfoOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
SeekNewest - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.SeekNewest
SeekNewest.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.SeekNewest
SeekNewestOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
SeekNextCommit - Class in org.hyperledger.fabric.protos.orderer
SeekNextCommit refers to the next block that will be committed
SeekNextCommit.Builder - Class in org.hyperledger.fabric.protos.orderer
SeekNextCommit refers to the next block that will be committed
SeekNextCommitOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
SeekOldest - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.SeekOldest
SeekOldest.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.SeekOldest
SeekOldestOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
SeekPosition - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.SeekPosition
SeekPosition.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.SeekPosition
SeekPosition.TypeCase - Enum in org.hyperledger.fabric.protos.orderer
 
SeekPositionOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
SeekSpecified - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.SeekSpecified
SeekSpecified.Builder - Class in org.hyperledger.fabric.protos.orderer
Protobuf type orderer.SeekSpecified
SeekSpecifiedOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
SELF_INFORMATION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
SEQ_IN_BLOCK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
SEQ_NUM_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Payload
 
SEQ_NUM_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PeerTime
 
SEQUENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Config
 
SEQUENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
SEQUENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
SEQUENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
SEQUENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
SEQUENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
SEQUENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
SEQUENCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
SerializedIdemixIdentity - Class in org.hyperledger.fabric.protos.msp
This struct represents an Idemix Identity to be used to serialize it and deserialize it.
SerializedIdemixIdentity.Builder - Class in org.hyperledger.fabric.protos.msp
This struct represents an Idemix Identity to be used to serialize it and deserialize it.
SerializedIdemixIdentityOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
SerializedIdentity - Class in org.hyperledger.fabric.protos.msp
This struct represents an Identity (with its MSP identifier) to be used to serialize it and deserialize it
SerializedIdentity.Builder - Class in org.hyperledger.fabric.protos.msp
This struct represents an Identity (with its MSP identifier) to be used to serialize it and deserialize it
SerializedIdentityOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
SERVER_TLS_CERT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.discovery.DiscoveryGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.gateway.GatewayGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.gossip.GossipGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.orderer.AtomicBroadcastGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.orderer.BlockAttestationsGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.orderer.ClusterGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeSupportGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.peer.DeliverGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.peer.EndorserGrpc
 
SERVICE_NAME - Static variable in class org.hyperledger.fabric.protos.peer.SnapshotGrpc
 
SERVICE_UNAVAILABLE_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
SERVICE_UNAVAILABLE = 503;
setAbsoluteMaxBytes(int) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
The byte count of the serialized messages in a batch cannot exceed this value.
setAck(Acknowledgement) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
setAck(Acknowledgement.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.Acknowledgement ack = 22 [json_name = "ack"];
setAction(ChaincodeEndorsedAction) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
The list of actions to apply to the ledger
setAction(ChaincodeEndorsedAction.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
The list of actions to apply to the ledger
setActions(int, TransactionAction) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
setActions(int, TransactionAction.Builder) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
The payload is an array of TransactionAction.
setActiveNodes(int, long) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
Indicates active nodes in cluster that are reacheable by Raft leader
setAddress(String) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The address of the endorsing peer or ordering node that returned an error.
setAddressBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The address of the endorsing peer or ordering node that returned an error.
setAddresses(int, String) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
repeated string addresses = 1 [json_name = "addresses"];
setAdminOuIdentifier(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the admins
setAdminOuIdentifier(FabricOUIdentifier.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the admins
setAdmins(int, ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity denoting the administrator of this MSP
setAfterTransactionId(String) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Only returns events after this transaction ID.
setAfterTransactionIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Only returns events after this transaction ID.
setAlive(int, Envelope) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
setAlive(int, Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope alive = 1 [json_name = "alive"];
setAliveMsg(AliveMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Membership
setAliveMsg(AliveMessage.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Membership
setAnchorPeers(int, AnchorPeer) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
setAnchorPeers(int, AnchorPeer.Builder) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
repeated .protos.AnchorPeer anchor_peers = 1 [json_name = "anchorPeers"];
setAnonymityType(MSPIdentityAnonymity.MSPIdentityAnonymityType) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
setAnonymityTypeValue(int) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
.common.MSPIdentityAnonymity.MSPIdentityAnonymityType anonymity_type = 1 [json_name = "anonymityType"];
setArgs(int, ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
repeated bytes args = 1 [json_name = "args"];
setArgument(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
When 'vscc' a marshaled VSCCArgs
setAuthentication(AuthInfo) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
authentication contains information that the service uses to check the client's eligibility for the queries.
setAuthentication(AuthInfo.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
authentication contains information that the service uses to check the client's eligibility for the queries.
setBehavior(SeekInfo.SeekBehavior) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The behavior when a missing block is encountered
setBehaviorValue(int) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The behavior when a missing block is encountered
setBlock(Block) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
setBlock(Block.Builder) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
setBlock(Block) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
.common.Block block = 1 [json_name = "block"];
setBlock(Block.Builder) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
.common.Block block = 1 [json_name = "block"];
setBlock(Block) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
setBlock(Block.Builder) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Block block = 2 [json_name = "block"];
setBlockAndPrivateData(BlockAndPrivateData) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
setBlockAndPrivateData(BlockAndPrivateData.Builder) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.BlockAndPrivateData block_and_private_data = 4 [json_name = "blockAndPrivateData"];
setBlockAttestation(BlockAttestation) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
setBlockAttestation(BlockAttestation.Builder) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.orderer.BlockAttestation block_attestation = 2 [json_name = "blockAttestation"];
setBlockNum(long) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
uint64 block_num = 1 [json_name = "blockNum"];
setBlockNumber(long) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Block number in which the chaincode events were emitted.
setBlockNumber(long) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
Block number that contains the transaction.
setBlockNumber(long) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
uint64 block_number = 1 [json_name = "blockNumber"];
setBlockNumber(long) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The block number to generate a snapshot
setBlockNumbers(int, long) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
repeated uint64 block_numbers = 1 [json_name = "blockNumbers"];
setBlockSeq(long) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
uint64 block_seq = 4 [json_name = "blockSeq"];
setBlockToLive(long) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The number of blocks after which the collection data expires.
setBlockToLive(long) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The number of blocks after which the collection data expires.
setBookmark(String) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
setBookmark(String) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
setBookmarkBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
setBookmarkBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
string bookmark = 2 [json_name = "bookmark"];
setBootstrappingSnapshotDir(String) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
setBootstrappingSnapshotDirBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
string bootstrapping_snapshot_dir = 2 [json_name = "bootstrappingSnapshotDir"];
setBootstrappingSnapshotInfo(BootstrappingSnapshotInfo) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
setBootstrappingSnapshotInfo(BootstrappingSnapshotInfo.Builder) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
Specifies bootstrapping snapshot info if the channel is bootstrapped from a snapshot.
setBrokers(int, String) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
Each broker here should be identified using the (IP|host):port notation, e.g.
setBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
bytes Bytes = 2 [json_name = "Bytes"];
setCcQuery(ChaincodeQuery) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ChaincodeQuery queries for chaincodes by their name and version.
setCcQuery(ChaincodeQuery.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ChaincodeQuery queries for chaincodes by their name and version.
setCcQueryRes(ChaincodeQueryResult) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
setCcQueryRes(ChaincodeQueryResult.Builder) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ChaincodeQueryResult contains information about chaincodes, and their corresponding endorsers
setCert(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes cert = 2 [json_name = "cert"];
setCertificate(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
Certificate represents the second certificate in a certification chain.
setCertifiersIdentifier(ByteString) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
CertifiersIdentifier is the hash of certificates chain of trust related to this organizational unit
setChaincode(String) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
string chaincode = 1 [json_name = "chaincode"];
setChaincodeActions(int, FilteredChaincodeAction) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
setChaincodeActions(int, FilteredChaincodeAction.Builder) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
repeated .protos.FilteredChaincodeAction chaincode_actions = 1 [json_name = "chaincodeActions"];
setChaincodeBytes(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
string chaincode = 1 [json_name = "chaincode"];
setChaincodeDefinitions(int, QueryChaincodeDefinitionsResult.ChaincodeDefinition) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
setChaincodeDefinitions(int, QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
repeated .lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition chaincode_definitions = 1 [json_name = "chaincodeDefinitions"];
setChaincodeDeploymentSpec(ByteString) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
This is the bytes of the ChaincodeDeploymentSpec
setChaincodeEvent(ChaincodeEvent) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
event emitted by chaincode.
setChaincodeEvent(ChaincodeEvent.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
event emitted by chaincode.
setChaincodeEvent(ChaincodeEvent) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
setChaincodeEvent(ChaincodeEvent.Builder) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
.protos.ChaincodeEvent chaincode_event = 1 [json_name = "chaincodeEvent"];
setChaincodeId(String) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Name of the chaincode for which events are requested.
setChaincodeId(ChaincodeID) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the ChaincodeID of executing this invocation.
setChaincodeId(ChaincodeID.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the ChaincodeID of executing this invocation.
setChaincodeId(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string chaincode_id = 1 [json_name = "chaincodeId"];
setChaincodeId(ChaincodeID) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
The ID of the chaincode to target.
setChaincodeId(ChaincodeID.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
The ID of the chaincode to target.
setChaincodeId(ChaincodeID) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
setChaincodeId(ChaincodeID.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeID chaincode_id = 2 [json_name = "chaincodeId"];
setChaincodeIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Name of the chaincode for which events are requested.
setChaincodeIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string chaincode_id = 1 [json_name = "chaincodeId"];
setChaincodeInstallPackage(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
bytes chaincode_install_package = 1 [json_name = "chaincodeInstallPackage"];
setChaincodeInstallPackage(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
This should be a marshaled lifecycle.ChaincodePackage
setChaincodeName(String) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
string chaincode_name = 1 [json_name = "chaincodeName"];
setChaincodeNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
string chaincode_name = 1 [json_name = "chaincodeName"];
setChaincodeProposalPayload(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
This field contains the bytes of the ChaincodeProposalPayload message from the original invocation (essentially the arguments) after the application of the visibility function.
setChaincodes(int, Chaincode) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
setChaincodes(int, Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
repeated .gossip.Chaincode chaincodes = 3 [json_name = "chaincodes"];
setChaincodes(int, ChaincodeCall) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
setChaincodes(int, ChaincodeCall.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
repeated .protos.ChaincodeCall chaincodes = 1 [json_name = "chaincodes"];
setChaincodes(int, ChaincodeInfo) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
setChaincodes(int, ChaincodeInfo.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
repeated .protos.ChaincodeInfo chaincodes = 1 [json_name = "chaincodes"];
setChaincodes(int, QueryInstalledChaincodeResult.Chaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
setChaincodes(int, QueryInstalledChaincodeResult.Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodeResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
setChaincodes(int, QueryInstalledChaincodesResult.Chaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
setChaincodes(int, QueryInstalledChaincodesResult.Chaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.Chaincode chaincodes = 1 [json_name = "chaincodes"];
setChaincodeSpec(ChaincodeSpec) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
setChaincodeSpec(ChaincodeSpec.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
setChaincodeSpec(ChaincodeSpec) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
setChaincodeSpec(ChaincodeSpec.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
.protos.ChaincodeSpec chaincode_spec = 1 [json_name = "chaincodeSpec"];
setChannel(String) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
string channel = 1 [json_name = "channel"];
setChannel(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
The channel of the message.
setChannel(String) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
string channel = 1 [json_name = "channel"];
setChannel(String) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
string channel = 1 [json_name = "channel"];
setChannel(String) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
string channel = 1 [json_name = "channel"];
setChannelBytes(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
string channel = 1 [json_name = "channel"];
setChannelBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
string channel = 1 [json_name = "channel"];
setChannelBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
string channel = 1 [json_name = "channel"];
setChannelBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
string channel = 1 [json_name = "channel"];
setChannelConfig(Config) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config channel_config = 1 [json_name = "channelConfig"];
setChannelConfig(Config.Builder) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config channel_config = 1 [json_name = "channelConfig"];
setChannelConfigPolicyReference(String) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
setChannelConfigPolicyReference(String) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
setChannelConfigPolicyReferenceBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
setChannelConfigPolicyReferenceBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
ChannelConfigPolicyReference is used when the policy is specified as a string that references a policy defined in the configuration of the channel
setChannelGroup(ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
setChannelGroup(ConfigGroup.Builder) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
channel_group is a bad name for this, it should be changed to root when API breakage is allowed
setChannelHeader(ByteString) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
bytes channel_header = 1 [json_name = "channelHeader"];
setChannelId(String) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Identifier of the channel this message is bound for
setChannelId(String) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Which channel this config update is for
setChannelId(String) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Identifier of the channel this request is bound for.
setChannelId(String) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the channel this request is bound for.
setChannelId(String) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
Identifier of the channel this request is bound for.
setChannelId(String) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the channel this request is bound for.
setChannelId(String) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the channel this request is bound for.
setChannelId(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
channel id
setChannelId(String) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
string channel_id = 1 [json_name = "channelId"];
setChannelId(String) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
string channel_id = 1 [json_name = "channelId"];
setChannelId(String) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The channel ID
setChannelId(String) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The channel ID
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Identifier of the channel this message is bound for
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
Which channel this config update is for
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Identifier of the channel this request is bound for.
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the channel this request is bound for.
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
Identifier of the channel this request is bound for.
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the channel this request is bound for.
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the channel this request is bound for.
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
channel id
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
string channel_id = 1 [json_name = "channelId"];
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
string channel_id = 1 [json_name = "channelId"];
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The channel ID
setChannelIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The channel ID
setChannelMAC(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
setChannelMAC(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
channel_MAC is an authentication code that proves that the peer that sent this message knows the name of the channel.
setChannels(int, ChannelInfo) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
setChannels(int, ChannelInfo.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
repeated .protos.ChannelInfo channels = 1 [json_name = "channels"];
setClass_(KafkaMessageRegular.Class) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
setClass_Value(int) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
.orderer.KafkaMessageRegular.Class class = 3 [json_name = "class"];
setClientIdentity(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
This is the identity of the client that is used to verify the signature on the SignedRequest's payload.
setClientOuIdentifier(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the clients
setClientOuIdentifier(FabricOUIdentifier.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the clients
setClientTlsCert(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
bytes client_tls_cert = 3 [json_name = "clientTlsCert"];
setClientTlsCertHash(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
This is the hash of the client's TLS cert.
setCode(int) - Method in class com.google.rpc.Status.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
setCodePackage(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
bytes code_package = 3 [json_name = "codePackage"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string collection = 3 [json_name = "collection"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string collection = 2 [json_name = "collection"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string collection = 2 [json_name = "collection"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string collection = 2 [json_name = "collection"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string collection = 3 [json_name = "collection"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string collection = 2 [json_name = "collection"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string collection = 2 [json_name = "collection"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string collection = 3 [json_name = "collection"];
setCollection(String) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string collection = 3 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string collection = 3 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string collection = 2 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string collection = 2 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string collection = 2 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string collection = 3 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string collection = 2 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string collection = 2 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string collection = 3 [json_name = "collection"];
setCollectionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string collection = 3 [json_name = "collection"];
setCollectionConfigs(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
setCollectionConfigs(CollectionConfigPackage.Builder) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
.protos.CollectionConfigPackage collection_configs = 6 [json_name = "collectionConfigs"];
setCollectionHashedRwset(int, CollectionHashedReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
setCollectionHashedRwset(int, CollectionHashedReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
repeated .rwset.CollectionHashedReadWriteSet collection_hashed_rwset = 3 [json_name = "collectionHashedRwset"];
setCollectionName(String) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string collection_name = 1 [json_name = "collectionName"];
setCollectionName(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
setCollectionName(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
setCollectionNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string collection_name = 1 [json_name = "collectionName"];
setCollectionNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
setCollectionNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
string collection_name = 1 [json_name = "collectionName"];
setCollectionNames(int, String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
repeated string collection_names = 2 [json_name = "collectionNames"];
setCollectionPvtRwset(int, CollectionPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
setCollectionPvtRwset(int, CollectionPvtReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
repeated .rwset.CollectionPvtReadWriteSet collection_pvt_rwset = 2 [json_name = "collectionPvtRwset"];
setCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
setCollections(CollectionConfigPackage.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
setCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
setCollections(CollectionConfigPackage.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
setCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
setCollections(CollectionConfigPackage.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
setCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
setCollections(CollectionConfigPackage.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
setCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
setCollections(CollectionConfigPackage.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
.protos.CollectionConfigPackage collections = 6 [json_name = "collections"];
setCollections(CollectionConfigPackage) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
setCollections(CollectionConfigPackage.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
.protos.CollectionConfigPackage collections = 7 [json_name = "collections"];
setConfig(int, CollectionConfig) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
setConfig(int, CollectionConfig.Builder) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
repeated .common.CollectionConfig config = 1 [json_name = "config"];
setConfig(Config) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
A marshaled Config structure
setConfig(Config.Builder) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
A marshaled Config structure
setConfig(ByteString) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
Config is MSP dependent configuration info
setConfig(int, CollectionConfig) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
setConfig(int, CollectionConfig.Builder) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
repeated .protos.CollectionConfig config = 1 [json_name = "config"];
setConfigQuery(ConfigQuery) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
setConfigQuery(ConfigQuery.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
ConfigQuery is used to query for the configuration of the channel, such as FabricMSPConfig, and rorderer endpoints.
setConfigResult(ConfigResult) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
setConfigResult(ConfigResult.Builder) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
ConfigResult contains the configuration of the channel, such as FabricMSPConfig and orderer endpoints
setConfigSeq(long) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
uint64 config_seq = 2 [json_name = "configSeq"];
setConfigUpdate(ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
A marshaled ConfigUpdate structure
setConn(ConnEstablish) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
ConnEstablish, used for establishing a connection
setConn(ConnEstablish.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
ConnEstablish, used for establishing a connection
setConnect(KafkaMessageConnect) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
setConnect(KafkaMessageConnect.Builder) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageConnect connect = 3 [json_name = "connect"];
setConsensusRequest(ConsensusRequest) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
consensus_request is a consensus specific message.
setConsensusRequest(ConsensusRequest.Builder) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
consensus_request is a consensus specific message.
setConsenterIds(int, long) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Maintains a mapping between the cluster's OSNs and their Raft IDs.
setConsenterMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
bytes consenter_metadata = 2 [json_name = "consenterMetadata"];
setConsenters(int, Consenter) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
setConsenters(int, Consenter.Builder) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
repeated .etcdraft.Consenter consenters = 1 [json_name = "consenters"];
setContent(int, EndorsementDescriptor) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
setContent(int, EndorsementDescriptor.Builder) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
repeated .discovery.EndorsementDescriptor content = 1 [json_name = "content"];
setContent(String) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
string content = 1 [json_name = "content"];
setContentBytes(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
string content = 1 [json_name = "content"];
setCreator(ByteString) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
Creator of the message, a marshaled msp.SerializedIdentity
setCred(ByteString) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
cred represents the serialized idemix credential of the default signer
setCredentialRevocationInformation(ByteString) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
credential_revocation_information contains a serialized CredentialRevocationInformation
setCryptoConfig(FabricCryptoConfig) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
setCryptoConfig(FabricCryptoConfig.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
FabricCryptoConfig contains the configuration parameters for the cryptographic algorithms used by this MSP
setCurrentBlockHash(ByteString) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
bytes currentBlockHash = 2 [json_name = "currentBlockHash"];
setData(BlockData) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockData data = 2 [json_name = "data"];
setData(BlockData.Builder) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockData data = 2 [json_name = "data"];
setData(int, ByteString) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
repeated bytes data = 1 [json_name = "data"];
setData(ByteString) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Data, the encoding of which is defined by the type in the header
setData(int, Envelope) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
setData(int, Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
repeated .gossip.Envelope data = 2 [json_name = "data"];
setData(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
bytes data = 2 [json_name = "data"];
setData(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Data data specific to the package
setDataDig(DataDigest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
setDataDig(DataDigest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataDigest data_dig = 10 [json_name = "dataDig"];
setDataHash(ByteString) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The hash of the BlockData, by MerkleTree
setDataModel(TxReadWriteSet.DataModel) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
setDataModel(TxReadWriteSet.DataModel) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
setDataModelValue(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
setDataModelValue(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
.rwset.TxReadWriteSet.DataModel data_model = 1 [json_name = "dataModel"];
setDataMsg(DataMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Contains a ledger block
setDataMsg(DataMessage.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Contains a ledger block
setDataReq(DataRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
setDataReq(DataRequest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataRequest data_req = 11 [json_name = "dataReq"];
setDatatype(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
string datatype = 1 [json_name = "datatype"];
setDatatypeBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
string datatype = 1 [json_name = "datatype"];
setDataUpdate(DataUpdate) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
setDataUpdate(DataUpdate.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.DataUpdate data_update = 12 [json_name = "dataUpdate"];
setDead(int, Envelope) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
setDead(int, Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
repeated .gossip.Envelope dead = 2 [json_name = "dead"];
setDetails(int, Any) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
setDetails(int, Any.Builder) - Method in class com.google.rpc.Status.Builder
A list of messages that carry the error details.
setDigest(PvtDataDigest) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
setDigest(PvtDataDigest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
.gossip.PvtDataDigest digest = 1 [json_name = "digest"];
setDigests(int, ByteString) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
Maybe change this to bitmap later on
setDigests(int, ByteString) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
repeated bytes digests = 2 [json_name = "digests"];
setDigests(int, PvtDataDigest) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
setDigests(int, PvtDataDigest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
repeated .gossip.PvtDataDigest digests = 1 [json_name = "digests"];
setDisregardNamespacePolicy(boolean) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we wish to ignore the namespace endorsement policy
setElectionTick(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 election_tick = 2 [json_name = "electionTick"];
setElements(int, PvtDataElement) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
setElements(int, PvtDataElement.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
repeated .gossip.PvtDataElement elements = 1 [json_name = "elements"];
setElements(int, Envelope) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
setElements(int, Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
repeated .gossip.Envelope elements = 1 [json_name = "elements"];
setEmpty(Empty) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Empty message, used for pinging
setEmpty(Empty.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Empty message, used for pinging
setEnable(boolean) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
If true then an msp identity that does not contain any of the specified OU will be considered invalid.
setEndKey(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string end_key = 2 [json_name = "endKey"];
setEndKey(String) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string endKey = 2 [json_name = "endKey"];
setEndKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string end_key = 2 [json_name = "endKey"];
setEndKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string endKey = 2 [json_name = "endKey"];
setEndorsedAt(long) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
uint64 endorsed_at = 1 [json_name = "endorsedAt"];
setEndorsement(Endorsement) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The endorsement of the proposal, basically the endorser's signature over the payload
setEndorsement(Endorsement.Builder) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The endorsement of the proposal, basically the endorser's signature over the payload
setEndorsementPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
setEndorsementPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
setEndorsementPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
setEndorsementPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
setEndorsementPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
setEndorsementPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
setEndorsementPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
setEndorsementPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
setEndorsementPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
setEndorsementPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
setEndorsementPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
setEndorsementPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
setEndorsementPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string endorsement_plugin = 3 [json_name = "endorsementPlugin"];
setEndorsementPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string endorsement_plugin = 4 [json_name = "endorsementPlugin"];
setEndorsementPolicy(ApplicationPolicy) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
setEndorsementPolicy(ApplicationPolicy.Builder) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
setEndorsementPolicy(ApplicationPolicy) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
setEndorsementPolicy(ApplicationPolicy.Builder) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define the endorsement policy for this collection
setEndorsementPolicyRef(String) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
A named reference to an endorsement policy,
setEndorsementPolicyRefBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
A named reference to an endorsement policy,
setEndorsements(int, Endorsement) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
setEndorsements(int, Endorsement.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
The endorsement of the proposal, basically the endorser's signature over proposalResponsePayload
setEndorser(ByteString) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
Identity of the endorser (e.g.
setEndorsingOrganizations(int, String) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
If targeting the peers of specific organizations (e.g.
setEndorsingOrganizations(int, String) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The list of endorsing organizations.
setEndpoint(int, Endpoint) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
setEndpoint(int, Endpoint.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
repeated .discovery.Endpoint endpoint = 1 [json_name = "endpoint"];
setEndpoint(String) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
string endpoint = 1 [json_name = "endpoint"];
setEndpointBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
string endpoint = 1 [json_name = "endpoint"];
setEndSeqNum(long) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
uint64 end_seq_num = 2 [json_name = "endSeqNum"];
setEnrollmentId(String) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
enrollment_id contains the enrollment id of this signer
setEnrollmentIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
enrollment_id contains the enrollment id of this signer
setEntries(int, KVMetadataEntry) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
setEntries(int, KVMetadataEntry.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
setEntries(int, KVMetadataEntry) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
setEntries(int, KVMetadataEntry.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
repeated .kvrwset.KVMetadataEntry entries = 2 [json_name = "entries"];
setEntries(int, StateMetadata) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
setEntries(int, StateMetadata.Builder) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
repeated .protos.StateMetadata entries = 1 [json_name = "entries"];
setEnvelope(Envelope) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
The transaction envelope.
setEnvelope(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
The transaction envelope.
setEpoch(long) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
The epoch in which this header was generated, where epoch is defined based on block height Epoch in which the response has been generated.
setEpoch(long) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
epoch represents the current epoch (time interval) used for revocation
setError(Error) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
Error indicates failure or refusal to process the query
setError(Error.Builder) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
Error indicates failure or refusal to process the query
setError(String) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
string error = 1 [json_name = "error"];
setErrorBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
string error = 1 [json_name = "error"];
setErrorResponse(SeekInfo.SeekErrorResponse) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
How to respond to errors reported to the deliver service
setErrorResponseValue(int) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
How to respond to errors reported to the deliver service
setEscc(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Escc for the chaincode instance
setEscc(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the ESCC for this chaincode.
setEsccBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Escc for the chaincode instance
setEsccBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the ESCC for this chaincode.
setEventName(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string event_name = 3 [json_name = "eventName"];
setEventNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string event_name = 3 [json_name = "eventName"];
setEvents(int, ChaincodeEvent) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
setEvents(int, ChaincodeEvent.Builder) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
Chaincode events emitted by the requested chaincode.
setEvents(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the event generated by the chaincode.
setExtension(ByteString) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Extension that may be attached based on the header type
setExtension(ByteString) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
Optional extensions to the proposal.
setExtension(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
Extension should be unmarshaled to a type-specific message.
setFabricNodeOus(FabricNodeOUs) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
setFabricNodeOus(FabricNodeOUs.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
fabric_node_ous contains the configuration to distinguish clients from peers from orderers based on the OUs.
setFetchedRecordsCount(int) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
int32 fetched_records_count = 1 [json_name = "fetchedRecordsCount"];
setField(Descriptors.FieldDescriptor, Object) - Method in class com.google.rpc.Status.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
setFields(int, String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
repeated string fields = 2 [json_name = "fields"];
setFilter(ChaincodeInterest) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
setFilter(ChaincodeInterest.Builder) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
.protos.ChaincodeInterest filter = 1 [json_name = "filter"];
setFilteredBlock(FilteredBlock) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
setFilteredBlock(FilteredBlock.Builder) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.protos.FilteredBlock filtered_block = 3 [json_name = "filteredBlock"];
setFilteredTransactions(int, FilteredTransaction) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
setFilteredTransactions(int, FilteredTransaction.Builder) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
repeated .protos.FilteredTransaction filtered_transactions = 4 [json_name = "filteredTransactions"];
setHash(ByteString) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
hash of ChaincodeDeploymentSpec.code_package
setHash(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
The hash of the chaincode bytes
setHashedReads(int, KVReadHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
setHashedReads(int, KVReadHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVReadHash hashed_reads = 1 [json_name = "hashedReads"];
setHashedRwset(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.HashedRWSet for KV and Document data models)
setHashedWrites(int, KVWriteHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
setHashedWrites(int, KVWriteHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVWriteHash hashed_writes = 2 [json_name = "hashedWrites"];
setHasMore(boolean) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
bool has_more = 2 [json_name = "hasMore"];
setHeader(BlockHeader) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockHeader header = 1 [json_name = "header"];
setHeader(BlockHeader.Builder) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockHeader header = 1 [json_name = "header"];
setHeader(Header) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Header is included to provide identity and prevent replay
setHeader(Header.Builder) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
Header is included to provide identity and prevent replay
setHeader(BlockHeader) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockHeader header = 1 [json_name = "header"];
setHeader(BlockHeader.Builder) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockHeader header = 1 [json_name = "header"];
setHeader(ByteString) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
The header of the proposal.
setHeader(ByteString) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
The header of the proposal action, which is the proposal header
setHeartbeatTick(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 heartbeat_tick = 3 [json_name = "heartbeatTick"];
setHeight(long) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
uint64 height = 1 [json_name = "height"];
setHello(GossipHello) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for push&pull
setHello(GossipHello.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for push&pull
setHost(String) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
string host = 1 [json_name = "host"];
setHost(String) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
string host = 1 [json_name = "host"];
setHost(String) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
DNS host name of the anchor peer
setHostBytes(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
string host = 1 [json_name = "host"];
setHostBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
string host = 1 [json_name = "host"];
setHostBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
DNS host name of the anchor peer
setId(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Id of the chaincode that's the unique fingerprint for the CC This is not currently used anywhere but serves as a good eyecatcher
setId(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the chaincode unique id.
setId(String) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
string id = 3 [json_name = "id"];
setId(String) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
string id = 1 [json_name = "id"];
setId(String) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
string id = 1 [json_name = "id"];
setIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
the Identity, serialized according to the rules of its MPS
setIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
string id = 3 [json_name = "id"];
setIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
string id = 1 [json_name = "id"];
setIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
string id = 1 [json_name = "id"];
setIdentities(int, MSPPrincipal) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
setIdentities(int, MSPPrincipal.Builder) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
repeated .common.MSPPrincipal identities = 3 [json_name = "identities"];
setIdentity(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is the msp.SerializedIdentity of the peer, represented in bytes.
setIdentity(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Client requestor identity.
setIdentity(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Client requestor identity.
setIdentity(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
bytes identity = 4 [json_name = "identity"];
setIdentity(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes identity = 2 [json_name = "identity"];
setIdentityIdentifierHashFunction(String) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
setIdentityIdentifierHashFunctionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
IdentityIdentifierHashFunction is a string representing the hash function to be used during the computation of the identity identifier of an MSP identity.
setIncNum(long) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
uint64 inc_num = 1 [json_name = "incNum"];
setIndex(long) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
uint64 index = 1 [json_name = "index"];
setInfo(String) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Info string which may contain additional information about the status returned
setInfo(String) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Info string which may contain additional information about the returned status.
setInfoBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Info string which may contain additional information about the status returned
setInfoBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Info string which may contain additional information about the returned status.
setInitRequired(boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
setInitRequired(boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
bool init_required = 2 [json_name = "initRequired"];
setInitRequired(boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
setInitRequired(boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
bool init_required = 8 [json_name = "initRequired"];
setInitRequired(boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
bool init_required = 7 [json_name = "initRequired"];
setInitRequired(boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
bool init_required = 7 [json_name = "initRequired"];
setInitRequired(boolean) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
bool init_required = 8 [json_name = "initRequired"];
setInProgress(boolean) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
bool in_progress = 1 [json_name = "inProgress"];
setInput(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the chaincode function upon instantiation and its arguments.
setInput(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
Input contains the arguments for this invocation.
setInput(ChaincodeInput) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeInput input = 3 [json_name = "input"];
setInput(ChaincodeInput.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeInput input = 3 [json_name = "input"];
setInputBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the chaincode function upon instantiation and its arguments.
setInstalledChaincodes(int, QueryInstalledChaincodesResult.InstalledChaincode) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
setInstalledChaincodes(int, QueryInstalledChaincodesResult.InstalledChaincode.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
repeated .lifecycle.QueryInstalledChaincodesResult.InstalledChaincode installed_chaincodes = 1 [json_name = "installedChaincodes"];
setInstantiationPolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
InstantiationPolicy for the chaincode
setInstantiationPolicy(SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
InstantiationPolicy for the chaincode
setInstantiationPolicy(ByteString) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
This is the instantiation policy which is identical in structure to endorsement policy.
setInt64(long) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
int64 Int64 = 1 [json_name = "Int64"];
setInterest(ChaincodeInterest) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The chaincode interest derived from simulating the proposal.
setInterest(ChaincodeInterest.Builder) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The chaincode interest derived from simulating the proposal.
setInterests(int, ChaincodeInterest) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
setInterests(int, ChaincodeInterest.Builder) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
repeated .protos.ChaincodeInterest interests = 1 [json_name = "interests"];
setIntermediateCerts(int, ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of intermediate certificates trusted by this MSP; they are used upon certificate validation as follows: validation attempts to build a path from the certificate to be validated (which is at one end of the path) and one of the certs in the RootCerts field (which is at the other end of the path).
setInternalEndpoint(String) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
setInternalEndpointBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
string internalEndpoint = 1 [json_name = "internalEndpoint"];
setIpk(ByteString) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
ipk represents the (serialized) issuer public key
setIsDeclaration(boolean) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
bool is_declaration = 3 [json_name = "isDeclaration"];
setIsDelete(boolean) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
bool is_delete = 4 [json_name = "isDelete"];
setIsDelete(boolean) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
bool is_delete = 2 [json_name = "isDelete"];
setIsDelete(boolean) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bool is_delete = 2 [json_name = "isDelete"];
setIsInit(boolean) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
is_init is used for the application to signal that an invocation is to be routed to the legacy 'Init' function for compatibility with chaincodes which handled Init in the old way.
setIsPurge(boolean) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bool is_purge = 4 [json_name = "isPurge"];
setItrExhausted(boolean) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
bool itr_exhausted = 3 [json_name = "itrExhausted"];
setKey(String) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string key = 2 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string key = 1 [json_name = "key"];
setKey(String) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string key = 2 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
string key = 1 [json_name = "key"];
setKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
string key = 1 [json_name = "key"];
setKeyHash(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
setKeyHash(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
setKeyHash(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bytes key_hash = 1 [json_name = "keyHash"];
setKeyIdentifier(String) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
setKeyIdentifierBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
Identifier of the key inside the default keystore; this for the case of Software BCCSP as well as the HSM BCCSP would be the SKI of the key
setKeyMaterial(ByteString) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
KeyMaterial (optional) for the key to be imported; this is properly encoded key bytes, prefixed by the type of the key
setKeyPolicies(int, SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
setKeyPolicies(int, SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
The set of signature policies associated with states in the write-set that have state-based endorsement policies.
setKnown(int, ByteString) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
repeated bytes known = 2 [json_name = "known"];
setKvReads(int, KVRead) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
setKvReads(int, KVRead.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
repeated .kvrwset.KVRead kv_reads = 1 [json_name = "kvReads"];
setLabel(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string label = 2 [json_name = "label"];
setLabel(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string label = 2 [json_name = "label"];
setLabel(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string label = 2 [json_name = "label"];
setLabelBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string label = 2 [json_name = "label"];
setLabelBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string label = 2 [json_name = "label"];
setLabelBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string label = 2 [json_name = "label"];
setLastBlockInSnapshot(long) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
uint64 lastBlockInSnapshot = 1 [json_name = "lastBlockInSnapshot"];
setLastConfig(LastConfig) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
setLastConfig(LastConfig.Builder) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
.common.LastConfig last_config = 1 [json_name = "lastConfig"];
setLastOffsetPersisted(long) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastOffsetPersisted is the encoded value for the Metadata message which is encoded in the ORDERER block metadata index for the case of the Kafka-based orderer.
setLastOriginalOffsetProcessed(long) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastOriginalOffsetProcessed is used to keep track of the newest offset processed if a message is re-validated and re-ordered.
setLastResubmittedConfigOffset(long) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
LastResubmittedConfigOffset is used to capture the newest offset of CONFIG kafka message, which is revalidated and resubmitted.
setLastUpdate(Envelope) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
The last CONFIG_UPDATE message which generated this current configuration
setLastUpdate(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
The last CONFIG_UPDATE message which generated this current configuration
setLastValidationSeq(long) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
last_validation_seq denotes the last configuration sequence at which the sender validated this message.
setLayouts(int, Layout) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
setLayouts(int, Layout.Builder) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
Specifies options of fulfulling the endorsement policy.
setLeadershipMsg(LeadershipMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to indicate intent of peer to become leader
setLeadershipMsg(LeadershipMessage.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to indicate intent of peer to become leader
setLedgerHeight(long) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
uint64 ledger_height = 1 [json_name = "ledgerHeight"];
setLeftChannel(boolean) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
bool left_channel = 2 [json_name = "leftChannel"];
setLocalPackage(ChaincodeSource.Local) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
setLocalPackage(ChaincodeSource.Local.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Local local_package = 2 [json_name = "localPackage"];
setLocalPeers(LocalPeerQuery) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
setLocalPeers(LocalPeerQuery.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
LocalPeerQuery queries for peers in a non channel context, and returns PeerMembershipResult
setMaxCount(long) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
The max count of channels to allow to be created, a value of 0 indicates no limit
setMaxDegree(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
uint32 max_degree = 1 [json_name = "maxDegree"];
setMaximumPeerCount(int) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The maximum number of peers that private data will be sent to upon endorsement.
setMaximumPeerCount(int) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The maximum number of peers that private data will be sent to upon endorsement.
setMaxInflightBlocks(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
uint32 max_inflight_blocks = 4 [json_name = "maxInflightBlocks"];
setMaxLevel(int) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
uint32 max_level = 2 [json_name = "maxLevel"];
setMaxLevelHashes(int, ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
repeated bytes max_level_hashes = 3 [json_name = "maxLevelHashes"];
setMaxMessageCount(int) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
Simply specified as number of messages for now, in the future we may want to allow this to be specified by size in bytes
setMemberOnlyRead(boolean) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
setMemberOnlyRead(boolean) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The member only read access denotes whether only collection member clients can read the private data (if set to true), or even non members can read the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
setMemberOnlyWrite(boolean) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
setMemberOnlyWrite(boolean) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The member only write access denotes whether only collection member clients can write the private data (if set to true), or even non members can write the data (if set to false, for example if you want to implement more granular access logic in the chaincode)
setMemberOrgsPolicy(CollectionPolicyConfig) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
setMemberOrgsPolicy(CollectionPolicyConfig.Builder) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
setMemberOrgsPolicy(CollectionPolicyConfig) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
setMemberOrgsPolicy(CollectionPolicyConfig.Builder) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
a reference to a policy residing / managed in the config block to define which orgs have access to this collection’s private data
setMembers(PeerMembershipResult) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
setMembers(PeerMembershipResult.Builder) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
PeerMembershipResult contains information about peers, such as their identity, endpoints, and channel related state.
setMembership(Member) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.Member membership = 1 [json_name = "membership"];
setMembership(Member.Builder) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.Member membership = 1 [json_name = "membership"];
setMembershipInfo(Envelope) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
setMembershipInfo(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.AliveMessage message
setMemReq(MembershipRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
setMemReq(MembershipRequest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipRequest mem_req = 6 [json_name = "memReq"];
setMemRes(MembershipResponse) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
setMemRes(MembershipResponse.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
.gossip.MembershipResponse mem_res = 7 [json_name = "memRes"];
setMessage(String) - Method in class com.google.rpc.Status.Builder
A developer-facing error message, which should be in English.
setMessage(String) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The error message returned by this node.
setMessage(String) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A message associated with the response code.
setMessageBytes(ByteString) - Method in class com.google.rpc.Status.Builder
A developer-facing error message, which should be in English.
setMessageBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The error message returned by this node.
setMessageBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A message associated with the response code.
setMetadata(BlockMetadata) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
setMetadata(BlockMetadata.Builder) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
.common.BlockMetadata metadata = 3 [json_name = "metadata"];
setMetadata(int, ByteString) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
repeated bytes metadata = 1 [json_name = "metadata"];
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
bytes metadata = 3 [json_name = "metadata"];
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
bytes metadata = 2 [json_name = "metadata"];
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
bytes metadata = 2 [json_name = "metadata"];
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes metadata = 3 [json_name = "metadata"];
setMetadata(BlockMetadata) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
setMetadata(BlockMetadata.Builder) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
.common.BlockMetadata metadata = 2 [json_name = "metadata"];
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
bytes metadata = 3 [json_name = "metadata"];
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
Opaque metadata, dependent on the consensus type.
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
bytes metadata = 3 [json_name = "metadata"];
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
bytes metadata = 4 [json_name = "metadata"];
setMetadata(StateMetadata) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
setMetadata(StateMetadata.Builder) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
.protos.StateMetadata metadata = 4 [json_name = "metadata"];
setMetadata(ByteString) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
bytes metadata = 4 [json_name = "metadata"];
setMetadatahash(ByteString) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
hash of ChaincodeID.name + ChaincodeID.version
setMetadataWrites(int, KVMetadataWriteHash) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
setMetadataWrites(int, KVMetadataWriteHash.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
repeated .kvrwset.KVMetadataWriteHash metadata_writes = 3 [json_name = "metadataWrites"];
setMetadataWrites(int, KVMetadataWrite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
setMetadataWrites(int, KVMetadataWrite.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVMetadataWrite metadata_writes = 4 [json_name = "metadataWrites"];
setMetakey(String) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
string metakey = 1 [json_name = "metakey"];
setMetakeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
string metakey = 1 [json_name = "metakey"];
setModPolicy(String) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
string mod_policy = 5 [json_name = "modPolicy"];
setModPolicy(String) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
string mod_policy = 3 [json_name = "modPolicy"];
setModPolicy(String) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
string mod_policy = 3 [json_name = "modPolicy"];
setModPolicyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
string mod_policy = 5 [json_name = "modPolicy"];
setModPolicyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
string mod_policy = 3 [json_name = "modPolicy"];
setModPolicyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
string mod_policy = 3 [json_name = "modPolicy"];
setMsgType(PullMsgType) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
setMsgType(PullMsgType) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
setMsgType(PullMsgType) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
setMsgType(PullMsgType) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
setMsgTypeValue(int) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
setMsgTypeValue(int) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
setMsgTypeValue(int) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
setMsgTypeValue(int) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
.gossip.PullMsgType msg_type = 3 [json_name = "msgType"];
setMspId(String) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The MSP Identifier of this node.
setMspid(String) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
The identifier of the associated membership service provider
setMspIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
The MSP Identifier of this node.
setMspidBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
The identifier of the associated membership service provider
setMspIdentifier(String) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPIdentifier represents the identifier of the MSP this principal refers to
setMspIdentifier(String) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
MSPIdentifier represents the identifier of the MSP this organization unit refers to
setMspIdentifierBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPIdentifier represents the identifier of the MSP this principal refers to
setMspIdentifierBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
MSPIdentifier represents the identifier of the MSP this organization unit refers to
setN(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
int32 n = 1 [json_name = "n"];
setName(String) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
SHA256 is currently the only supported and tested algorithm.
setName(String) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
the name of the collection inside the denoted chaincode
setName(String) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
setName(String) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
Name holds the identifier of the MSP
setName(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Name of the chaincode
setName(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
Specifies what code to run for endorsements, defaults 'escc'
setName(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
all other requests will use the name (really a hashcode) generated by the deploy transaction
setName(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
Specifies which code to run to validate transactions, defaults to 'vscc'
setName(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string name = 2 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string name = 2 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string name = 2 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string name = 1 [json_name = "name"];
setName(String) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
the name of the collection inside the denoted chaincode
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
SHA256 is currently the only supported and tested algorithm.
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
the name of the collection inside the denoted chaincode
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Name holds the identifier of the MSP; MSP identifier is chosen by the application that governs this MSP.
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
Name holds the identifier of the MSP
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Name of the chaincode
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
Specifies what code to run for endorsements, defaults 'escc'
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
all other requests will use the name (really a hashcode) generated by the deploy transaction
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
Specifies which code to run to validate transactions, defaults to 'vscc'
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string name = 2 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string name = 2 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string name = 2 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string name = 1 [json_name = "name"];
setNameBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
the name of the collection inside the denoted chaincode
setNamespace(String) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string namespace = 2 [json_name = "namespace"];
setNamespace(String) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string namespace = 2 [json_name = "namespace"];
setNamespace(String) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string namespace = 1 [json_name = "namespace"];
setNamespace(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
setNamespace(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
setNamespaceBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string namespace = 2 [json_name = "namespace"];
setNamespaceBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string namespace = 2 [json_name = "namespace"];
setNamespaceBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
string namespace = 1 [json_name = "namespace"];
setNamespaceBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
setNamespaceBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
string namespace = 1 [json_name = "namespace"];
setNewest(SeekNewest) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
setNewest(SeekNewest.Builder) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNewest newest = 1 [json_name = "newest"];
setNextCommit(SeekNextCommit) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
setNextCommit(SeekNextCommit.Builder) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekNextCommit next_commit = 4 [json_name = "nextCommit"];
setNextConsenterId(long) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Carries the Raft ID value that will be assigned to the next OSN that will join this cluster.
setNonce(ByteString) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
Arbitrary number that may only be used once.
setNonce(long) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
uint64 nonce = 1 [json_name = "nonce"];
setNonce(long) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
uint64 nonce = 1 [json_name = "nonce"];
setNonce(long) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
uint64 nonce = 1 [json_name = "nonce"];
setNonce(long) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
uint64 nonce = 1 [json_name = "nonce"];
setNonce(long) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
used mainly for testing, but will might be used in the future for ensuring message delivery by acking
setNoPrivateReads(boolean) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we do not need to read from private data
setNoPublicWrites(boolean) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
Indicates we do not need to write to the chaincode namespace
setNOutOf(SignaturePolicy.NOutOf) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
setNOutOf(SignaturePolicy.NOutOf.Builder) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
.common.SignaturePolicy.NOutOf n_out_of = 2 [json_name = "nOutOf"];
setNsPvtRwset(int, NsPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
setNsPvtRwset(int, NsPvtReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
repeated .rwset.NsPvtReadWriteSet ns_pvt_rwset = 2 [json_name = "nsPvtRwset"];
setNsRwset(int, NsReadWriteSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
setNsRwset(int, NsReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
repeated .rwset.NsReadWriteSet ns_rwset = 2 [json_name = "nsRwset"];
setNumber(long) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The position in the blockchain
setNumber(long) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
uint64 number = 1 [json_name = "number"];
setNumber(long) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
The position in the blockchain
setNymX(ByteString) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
nym_x is the X-component of the pseudonym elliptic curve point.
setNymY(ByteString) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
nym_y is the Y-component of the pseudonym elliptic curve point.
setOldest(SeekOldest) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
setOldest(SeekOldest.Builder) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekOldest oldest = 2 [json_name = "oldest"];
setOptions(Options) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
.etcdraft.Options options = 2 [json_name = "options"];
setOptions(Options.Builder) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
.etcdraft.Options options = 2 [json_name = "options"];
setOrdererOuIdentifier(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the orderers
setOrdererOuIdentifier(FabricOUIdentifier.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the orderers
setOrganizationalUnitIdentifier(String) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
setOrganizationalUnitIdentifier(String) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
setOrganizationalUnitIdentifier(String) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
organizational_unit_identifier defines the organizational unit the default signer is in
setOrganizationalUnitIdentifierBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
setOrganizationalUnitIdentifierBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
OrganizationUnitIdentifier defines the organizational unit under the MSP identified with MSPIdentifier
setOrganizationalUnitIdentifierBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
organizational_unit_identifier defines the organizational unit the default signer is in
setOrganizationalUnitIdentifiers(int, FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
setOrganizationalUnitIdentifiers(int, FabricOUIdentifier.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
OrganizationalUnitIdentifiers holds one or more fabric organizational unit identifiers that belong to this MSP configuration
setOriginalOffset(long) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
int64 original_offset = 4 [json_name = "originalOffset"];
setOu(ByteString) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
ou contains the organizational unit of the idemix identity
setOwnerEndorsements(int, Endorsement) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
setOwnerEndorsements(int, Endorsement.Builder) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
The endorsements of the above deployment spec, the owner's signature over chaincode_deployment_spec and Endorsement.endorser.
setPackageId(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
string package_id = 1 [json_name = "packageId"];
setPackageId(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
string package_id = 1 [json_name = "packageId"];
setPackageId(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
setPackageId(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
string package_id = 1 [json_name = "packageId"];
setPackageId(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
setPackageId(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string package_id = 1 [json_name = "packageId"];
setPackageIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
string package_id = 1 [json_name = "packageId"];
setPackageIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
string package_id = 1 [json_name = "packageId"];
setPackageIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
setPackageIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
string package_id = 1 [json_name = "packageId"];
setPackageIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
string package_id = 1 [json_name = "packageId"];
setPackageIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
string package_id = 1 [json_name = "packageId"];
setPageSize(int) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
int32 pageSize = 1 [json_name = "pageSize"];
setPath(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
deploy transaction will use the path
setPath(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the path as specified by the install/instantiate transaction
setPathBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
deploy transaction will use the path
setPathBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the path as specified by the install/instantiate transaction
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
A marshaled Payload
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
bytes payload = 1 [json_name = "payload"];
setPayload(Payload) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
.gossip.Payload payload = 1 [json_name = "payload"];
setPayload(Payload.Builder) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
.gossip.Payload payload = 1 [json_name = "payload"];
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
bytes payload = 1 [json_name = "payload"];
setPayload(PrivatePayload) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
setPayload(PrivatePayload.Builder) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
.gossip.PrivatePayload payload = 1 [json_name = "payload"];
setPayload(int, ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
the payload is a marshaled kvrwset.KVRWSet
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
Encodes marhslaed bytes of rwset.TxPvtReadWriteSet defined in rwset.proto
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
bytes payload = 1 [json_name = "payload"];
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
bytes payload = 2 [json_name = "payload"];
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
bytes payload = 1 [json_name = "payload"];
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
bytes payload = 1 [json_name = "payload"];
setPayload(Envelope) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
content is the fabric transaction that is forwarded to the cluster member.
setPayload(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
content is the fabric transaction that is forwarded to the cluster member.
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
bytes payload = 4 [json_name = "payload"];
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
bytes payload = 3 [json_name = "payload"];
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
The payload of the proposal as defined by the type in the proposal header.
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
The payload of response.
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A payload that can be used to include metadata with this response.
setPayload(ByteString) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
The payload of the action as defined by the type in the header For chaincode, it's the bytes of ChaincodeActionPayload
setPayloads(int, Payload) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
setPayloads(int, Payload.Builder) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
repeated .gossip.Payload payloads = 1 [json_name = "payloads"];
setPeerIdentity(PeerIdentity) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to learn of a peer's certificate
setPeerIdentity(PeerIdentity.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to learn of a peer's certificate
setPeerOuIdentifier(FabricOUIdentifier) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the peers
setPeerOuIdentifier(FabricOUIdentifier.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
OU Identifier of the peers
setPeerQuery(PeerMembershipQuery) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
setPeerQuery(PeerMembershipQuery.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
PeerMembershipQuery queries for peers in a channel context, and returns PeerMembershipResult
setPeers(int, Peer) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
setPeers(int, Peer.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
repeated .discovery.Peer peers = 1 [json_name = "peers"];
setPkiId(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes pki_id = 1 [json_name = "pkiId"];
setPkiId(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
bytes pki_id = 1 [json_name = "pkiId"];
setPkiId(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
bytes pki_id = 3 [json_name = "pkiId"];
setPkiId(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
bytes pki_id = 1 [json_name = "pkiId"];
setPkiId(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
bytes pki_id = 3 [json_name = "pkiId"];
setPolicy(Policy) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
.common.Policy policy = 2 [json_name = "policy"];
setPolicy(Policy.Builder) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
.common.Policy policy = 2 [json_name = "policy"];
setPolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Policy endorsement policy for the chaincode instance
setPolicy(SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Policy endorsement policy for the chaincode instance
setPolicyRef(String) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
The policy name to use for this API
setPolicyRefBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
The policy name to use for this API
setPort(int) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
uint32 port = 2 [json_name = "port"];
setPort(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
uint32 port = 2 [json_name = "port"];
setPort(int) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
The port number
setPreferredMaxBytes(int) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
The byte count of the serialized messages in a batch should not exceed this value.
setPreparedTransaction(Envelope) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
setPreparedTransaction(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
The unsigned set of transaction responses from the endorsing peers for signing by the client before submitting to ordering service (via gateway).
setPreparedTransaction(Envelope) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
The signed set of endorsed transaction responses to submit.
setPreparedTransaction(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
The signed set of endorsed transaction responses to submit.
setPreviousBlockHash(ByteString) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
bytes previousBlockHash = 3 [json_name = "previousBlockHash"];
setPreviousHash(ByteString) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
The hash of the previous block header
setPrincipal(ByteString) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
Principal completes the policy principal definition.
setPrincipalClassification(MSPPrincipal.Classification) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
Classification describes the way that one should process Principal.
setPrincipalClassificationValue(int) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
Classification describes the way that one should process Principal.
setPrincipals(int, MSPPrincipal) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
setPrincipals(int, MSPPrincipal.Builder) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
Principals refer to combined principals
setPrivateData(PrivateDataMessage) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Encapsulates private data used to distribute private rwset after the endorsement
setPrivateData(PrivateDataMessage.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Encapsulates private data used to distribute private rwset after the endorsement
setPrivateData(int, ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
repeated bytes private_data = 3 [json_name = "privateData"];
setPrivateReq(RemotePvtDataRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to request private data
setPrivateReq(RemotePvtDataRequest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to request private data
setPrivateRes(RemotePvtDataResponse) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to respond to private data requests
setPrivateRes(RemotePvtDataResponse.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to respond to private data requests
setPrivateRwset(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
bytes private_rwset = 4 [json_name = "privateRwset"];
setPrivateSigner(KeyInfo) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PrivateSigner denotes a reference to the private key of the peer's signing identity
setPrivateSigner(KeyInfo.Builder) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PrivateSigner denotes a reference to the private key of the peer's signing identity
setPrivateSimHeight(long) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
uint64 private_sim_height = 5 [json_name = "privateSimHeight"];
setProbe(boolean) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bool probe = 4 [json_name = "probe"];
setProof(ByteString) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
proof contains the cryptographic evidence that this identity is valid
setProperties(Properties) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.Properties properties = 5 [json_name = "properties"];
setProperties(Properties.Builder) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.Properties properties = 5 [json_name = "properties"];
setProposal(SignedProposal) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The signed proposal.
setProposal(SignedProposal.Builder) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
The signed proposal.
setProposal(SignedProposal) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
setProposal(SignedProposal.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.SignedProposal proposal = 5 [json_name = "proposal"];
setProposalBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
The bytes of Proposal
setProposalHash(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
Hash of the proposal that triggered this response.
setProposalResponsePayload(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
This is the bytes of the ProposalResponsePayload message signed by the endorsers.
setProposedTransaction(SignedProposal) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The signed proposal ready for endorsement.
setProposedTransaction(SignedProposal.Builder) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The signed proposal ready for endorsement.
setProposedTransaction(SignedProposal) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
The signed proposal ready for evaluation.
setProposedTransaction(SignedProposal.Builder) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
The signed proposal ready for evaluation.
setPublicSigner(ByteString) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
PublicSigner carries the public information of the signing identity.
setPvtRwset(TxPvtReadWriteSet) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
setPvtRwset(TxPvtReadWriteSet.Builder) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
.rwset.TxPvtReadWriteSet pvt_rwset = 2 [json_name = "pvtRwset"];
setPvtRwsetHash(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
Hash of entire private read-write set for a specific collection.
setQueries(int, Query) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
setQueries(int, Query.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
queries
setQuery(String) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string query = 1 [json_name = "query"];
setQueryBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
string query = 1 [json_name = "query"];
setRaftIndex(long) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
Index of etcd/raft entry for current block.
setRangeQueriesInfo(int, RangeQueryInfo) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
setRangeQueriesInfo(int, RangeQueryInfo.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.RangeQueryInfo range_queries_info = 2 [json_name = "rangeQueriesInfo"];
setRawReads(QueryReads) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
setRawReads(QueryReads.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReads raw_reads = 4 [json_name = "rawReads"];
setReads(int, KVRead) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
setReads(int, KVRead.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVRead reads = 1 [json_name = "reads"];
setReadSet(ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
setReadSet(ConfigGroup.Builder) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
ReadSet explicitly lists the portion of the config which was read, this should be sparse with only Version set
setReadsMerkleHashes(QueryReadsMerkleSummary) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
setReadsMerkleHashes(QueryReadsMerkleSummary.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
.kvrwset.QueryReadsMerkleSummary reads_merkle_hashes = 5 [json_name = "readsMerkleHashes"];
setRegular(KafkaMessageRegular) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
setRegular(KafkaMessageRegular.Builder) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageRegular regular = 1 [json_name = "regular"];
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class com.google.rpc.Status.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
setRequest(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
Serialized ChaincodeEventsRequest message.
setRequest(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
Serialized CommitStatusRequest message.
setRequest(ByteString) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
The bytes of SnapshotRequest or SnapshotQuery
setRequiredPeerCount(int) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
The minimum number of peers private data will be sent to upon endorsement.
setRequiredPeerCount(int) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
The minimum number of peers private data will be sent to upon endorsement.
setResourcesConfig(Config) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
setResourcesConfig(Config.Builder) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
.common.Config resources_config = 2 [json_name = "resourcesConfig"];
setResponse(Response) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the result of executing this invocation.
setResponse(Response.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the result of executing this invocation.
setResponse(Response) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
A response message indicating whether the endorsement of the action was successful
setResponse(Response.Builder) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
A response message indicating whether the endorsement of the action was successful
setResult(TxValidationCode) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
The result of the transaction commit, as defined in peer/transaction.proto.
setResult(Response) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
setResult(Response.Builder) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
The response that is returned by the transaction function, as defined in peer/proposal_response.proto.
setResultBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
bytes resultBytes = 1 [json_name = "resultBytes"];
setResults(int, QueryResult) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
setResults(int, QueryResult.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
The results are returned in the same order of the queries
setResults(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
This field contains the read set and the write set produced by the chaincode executing this invocation.
setResults(int, QueryResultBytes) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
setResults(int, QueryResultBytes.Builder) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
repeated .protos.QueryResultBytes results = 1 [json_name = "results"];
setResultValue(int) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
The result of the transaction commit, as defined in peer/transaction.proto.
setRevocationList(int, ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
Identity revocation list
setRevocationPk(ByteString) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
revocation_pk is the public key used for revocation of credentials
setRole(MSPRole.MSPRoleType) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
setRole(int) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
role defines whether the default signer is admin, peer, member or client
setRole(ByteString) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
role contains the role of this identity (e.g., ADMIN or MEMBER)
setRoleValue(int) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
MSPRoleType defines which of the available, pre-defined MSP-roles an identiy should posess inside the MSP with identifier MSPidentifier
setRootCerts(int, ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of root certificates trusted by this MSP they are used upon certificate validation (see comment for IntermediateCerts below)
setRule(ImplicitMetaPolicy.Rule) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
setRule(SignaturePolicy) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
setRule(SignaturePolicy.Builder) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
.common.SignaturePolicy rule = 2 [json_name = "rule"];
setRules(int, SignaturePolicy) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
setRules(int, SignaturePolicy.Builder) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
repeated .common.SignaturePolicy rules = 2 [json_name = "rules"];
setRuleValue(int) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
.common.ImplicitMetaPolicy.Rule rule = 2 [json_name = "rule"];
setRwset(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
setRwset(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
Data model specific serialized proto message (e.g., kvrwset.KVRWSet for KV and Document data models)
setSecretEnvelope(SecretEnvelope) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
setSecretEnvelope(SecretEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
.gossip.SecretEnvelope secret_envelope = 3 [json_name = "secretEnvelope"];
setSelfInformation(Envelope) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
setSelfInformation(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
.gossip.Envelope self_information = 1 [json_name = "selfInformation"];
setSeqInBlock(long) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
uint64 seq_in_block = 5 [json_name = "seqInBlock"];
setSeqNum(long) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
uint64 seq_num = 1 [json_name = "seqNum"];
setSeqNum(long) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
uint64 seq_num = 2 [json_name = "seqNum"];
setSequence(long) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
uint64 sequence = 1 [json_name = "sequence"];
setSequence(long) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
setSequence(long) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
setSequence(long) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
int64 sequence = 1 [json_name = "sequence"];
setSequence(long) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
int64 sequence = 2 [json_name = "sequence"];
setSequence(long) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
int64 sequence = 1 [json_name = "sequence"];
setSequence(long) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
int64 sequence = 1 [json_name = "sequence"];
setSequence(long) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
int64 sequence = 2 [json_name = "sequence"];
setServerTlsCert(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
bytes server_tls_cert = 4 [json_name = "serverTlsCert"];
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
Signature over the concatenation signatureHeader bytes and config bytes
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
A signature by the creator specified in the Payload header
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
The signature over the concatenation of the Metadata value bytes, signatureHeader, and block header
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
bytes signature = 2 [json_name = "signature"];
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
Signature for request message.
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
Signature for request message.
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
bytes signature = 2 [json_name = "signature"];
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
bytes signature = 2 [json_name = "signature"];
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
Signature of the payload included in ProposalResponse concatenated with the endorser's certificate; ie, sign(ProposalResponse.payload + endorser)
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
Signaure over proposalBytes; this signature is to be verified against the creator identity contained in the header of the Proposal message marshaled as proposalBytes
setSignature(ByteString) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
Signaure over request bytes; this signature is to be verified against the client identity
setSignatureHashFamily(String) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
setSignatureHashFamilyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
SignatureHashFamily is a string representing the hash family to be used during sign and verify operations.
setSignatureHeader(ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
A marshaled SignatureHeader
setSignatureHeader(ByteString) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
bytes signature_header = 2 [json_name = "signatureHeader"];
setSignatureHeader(ByteString) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
An encoded SignatureHeader
setSignatureHeader(SignatureHeader) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The signature header that contains creator identity and nonce
setSignatureHeader(SignatureHeader.Builder) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
The signature header that contains creator identity and nonce
setSignatureHeader(SignatureHeader) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The signature header that contains creator identity and nonce
setSignatureHeader(SignatureHeader.Builder) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
The signature header that contains creator identity and nonce
setSignaturePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
setSignaturePolicy(SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
setSignaturePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
Initially, only a signature policy is supported.
setSignaturePolicy(SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
Initially, only a signature policy is supported.
setSignaturePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
setSignaturePolicy(SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
SignaturePolicy type is used if the policy is specified as a combination (using threshold gates) of signatures from MSP principals
setSignaturePolicy(SignaturePolicyEnvelope) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
Initially, only a signature policy is supported.
setSignaturePolicy(SignaturePolicyEnvelope.Builder) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
Initially, only a signature policy is supported.
setSignatures(int, ConfigSignature) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
setSignatures(int, ConfigSignature.Builder) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
Signatures over the config_update
setSignatures(int, MetadataSignature) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
setSignatures(int, MetadataSignature.Builder) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
repeated .common.MetadataSignature signatures = 2 [json_name = "signatures"];
setSignedBy(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
int32 signed_by = 1 [json_name = "signedBy"];
setSigner(IdemixMSPSignerConfig) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
signer may contain crypto material to configure a default signer
setSigner(IdemixMSPSignerConfig.Builder) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
signer may contain crypto material to configure a default signer
setSigningIdentity(SigningIdentityInfo) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
setSigningIdentity(SigningIdentityInfo.Builder) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
SigningIdentity holds information on the signing identity this peer is to use, and which is to be imported by the MSP defined before
setSk(ByteString) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
sk is the secret key of the default signer, corresponding to credential Cred
setSnapshotIntervalSize(int) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
Take snapshot when cumulative data exceeds certain size in bytes.
setSource(ChaincodeSource) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
setSource(ChaincodeSource.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
.lifecycle.ChaincodeSource source = 9 [json_name = "source"];
setSource(ChaincodeSource) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
setSource(ChaincodeSource.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
.lifecycle.ChaincodeSource source = 8 [json_name = "source"];
setSpecified(SeekSpecified) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
setSpecified(SeekSpecified.Builder) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
.orderer.SeekSpecified specified = 3 [json_name = "specified"];
setStart(SeekPosition) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to start the deliver from
setStart(SeekPosition.Builder) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to start the deliver from
setStartKey(String) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string start_key = 1 [json_name = "startKey"];
setStartKey(String) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string startKey = 1 [json_name = "startKey"];
setStartKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
string start_key = 1 [json_name = "startKey"];
setStartKeyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
string startKey = 1 [json_name = "startKey"];
setStartPosition(SeekPosition) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Position within the ledger at which to start reading events.
setStartPosition(SeekPosition.Builder) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
Position within the ledger at which to start reading events.
setStartSeqNum(long) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
uint64 start_seq_num = 1 [json_name = "startSeqNum"];
setState(ConsensusType.State) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
setStateInfo(Envelope) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
setStateInfo(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
This is an Envelope of a GossipMessage with a gossip.StateInfo message
setStateInfo(StateInfo) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for relaying information about state
setStateInfo(StateInfo.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for relaying information about state
setStateInfoPullReq(StateInfoPullRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for asking for StateInfoSnapshots
setStateInfoPullReq(StateInfoPullRequest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for asking for StateInfoSnapshots
setStateRequest(RemoteStateRequest) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to ask from a remote peer a set of blocks
setStateRequest(RemoteStateRequest.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to ask from a remote peer a set of blocks
setStateResponse(RemoteStateResponse) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to send a set of blocks to a remote peer
setStateResponse(RemoteStateResponse.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used to send a set of blocks to a remote peer
setStateSnapshot(StateInfoSnapshot) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for sending sets of StateInfo messages
setStateSnapshot(StateInfoSnapshot.Builder) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
Used for sending sets of StateInfo messages
setStateValue(int) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The state signals the ordering service to go into maintenance mode, typically for consensus-type migration.
setStaticCollectionConfig(StaticCollectionConfig) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
setStaticCollectionConfig(StaticCollectionConfig.Builder) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
.common.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
setStaticCollectionConfig(StaticCollectionConfig) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
setStaticCollectionConfig(StaticCollectionConfig.Builder) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
.protos.StaticCollectionConfig static_collection_config = 1 [json_name = "staticCollectionConfig"];
setStatus(Status) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.common.Status status = 1 [json_name = "status"];
setStatus(Status) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Status code, which may be used to programatically respond to success/failure
setStatus(Status) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
setStatus(Status) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Status code, which may be used to programatically respond to success/failure.
setStatus(Status) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
setStatus(int) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
A status code that should follow the HTTP status codes.
setStatusValue(int) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
.common.Status status = 1 [json_name = "status"];
setStatusValue(int) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
Status code, which may be used to programatically respond to success/failure
setStatusValue(int) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
setStatusValue(int) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
Status code, which may be used to programatically respond to success/failure.
setStatusValue(int) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
.common.Status status = 1 [json_name = "status"];
setStop(SeekPosition) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to stop the deliver
setStop(SeekPosition.Builder) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
The position to stop the deliver
setString(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
string String = 3 [json_name = "String"];
setStringBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
string String = 3 [json_name = "String"];
setSubmitRequest(SubmitRequest) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
submit_request is a relay of a transaction.
setSubmitRequest(SubmitRequest.Builder) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
submit_request is a relay of a transaction.
setSubmitRes(SubmitResponse) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
setSubmitRes(SubmitResponse.Builder) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
.orderer.SubmitResponse submit_res = 1 [json_name = "submitRes"];
setSubPolicy(String) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
string sub_policy = 1 [json_name = "subPolicy"];
setSubPolicyBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
string sub_policy = 1 [json_name = "subPolicy"];
setTag(GossipMessage.Tag) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
determines to which peers it is allowed to forward the message
setTagValue(int) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
determines to which peers it is allowed to forward the message
setTargetOrganizations(int, String) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
If targeting the peers of specific organizations (e.g.
setTickInterval(String) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
time duration format, e.g.
setTickIntervalBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
time duration format, e.g.
setTimeout(String) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
setTimeout(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
int32 timeout = 4 [json_name = "timeout"];
setTimeoutBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
Any duration string parseable by ParseDuration(): https://golang.org/pkg/time/#ParseDuration
setTimestamp(Timestamp) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Timestamp is the local time when the message was created by the sender
setTimestamp(Timestamp.Builder) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Timestamp is the local time when the message was created by the sender
setTimestamp(PeerTime) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
setTimestamp(PeerTime.Builder) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
setTimestamp(PeerTime) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
setTimestamp(PeerTime.Builder) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
setTimestamp(PeerTime) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
setTimestamp(PeerTime.Builder) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
.gossip.PeerTime timestamp = 2 [json_name = "timestamp"];
setTimestamp(Timestamp) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
setTimestamp(Timestamp.Builder) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
.google.protobuf.Timestamp timestamp = 3 [json_name = "timestamp"];
setTimestamp(Timestamp) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
setTimestamp(Timestamp.Builder) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.google.protobuf.Timestamp timestamp = 2 [json_name = "timestamp"];
setTimestamp(Timestamp) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Timestamp is the time that the message was created as defined by the sender
setTimestamp(Timestamp.Builder) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Timestamp is the time that the message was created as defined by the sender
setTimeToCut(KafkaMessageTimeToCut) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
setTimeToCut(KafkaMessageTimeToCut.Builder) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
.orderer.KafkaMessageTimeToCut time_to_cut = 2 [json_name = "timeToCut"];
setTlsCertHash(ByteString) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
If mutual TLS is employed, this represents the hash of the client's TLS certificate
setTlsCertHash(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
bytes tls_cert_hash = 3 [json_name = "tlsCertHash"];
setTlsIntermediateCerts(int, ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS intermediate certificates trusted by this MSP; They are returned by GetTLSIntermediateCerts.
setTlsRootCerts(int, ByteString) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
List of TLS root certificates trusted by this MSP.
setTransactionActions(FilteredTransactionActions) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
setTransactionActions(FilteredTransactionActions.Builder) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.FilteredTransactionActions transaction_actions = 4 [json_name = "transactionActions"];
setTransactionEnvelope(Envelope) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An Envelope which includes a processed transaction
setTransactionEnvelope(Envelope.Builder) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An Envelope which includes a processed transaction
setTransactionId(String) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the transaction to check.
setTransactionId(String) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The unique identifier for the transaction.
setTransactionId(String) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the transaction to evaluate.
setTransactionId(String) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
Identifier of the prepared transaction.
setTransactionId(String) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
Identifier of the proposed transaction.
setTransactionId(String) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the transaction to submit.
setTransactionIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
Identifier of the transaction to check.
setTransactionIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
The unique identifier for the transaction.
setTransactionIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
Identifier of the transaction to evaluate.
setTransactionIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
Identifier of the prepared transaction.
setTransactionIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
Identifier of the proposed transaction.
setTransactionIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
Identifier of the transaction to submit.
setTxId(String) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
An unique identifier that is used end-to-end.
setTxId(String) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string tx_id = 3 [json_name = "txId"];
setTxId(String) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string tx_id = 1 [json_name = "txId"];
setTxId(String) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
string tx_id = 1 [json_name = "txId"];
setTxId(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string tx_id = 2 [json_name = "txId"];
setTxid(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
string txid = 4 [json_name = "txid"];
setTxid(String) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
string txid = 1 [json_name = "txid"];
setTxIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
An unique identifier that is used end-to-end.
setTxIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
string tx_id = 3 [json_name = "txId"];
setTxIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
string tx_id = 1 [json_name = "txId"];
setTxIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
string tx_id = 1 [json_name = "txId"];
setTxIdBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
string tx_id = 2 [json_name = "txId"];
setTxidBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
string txid = 4 [json_name = "txid"];
setTxidBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
string txid = 1 [json_name = "txid"];
setTxNum(long) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
uint64 tx_num = 2 [json_name = "txNum"];
setTxSeqInBlock(long) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
uint64 tx_seq_in_block = 1 [json_name = "txSeqInBlock"];
setTxValidationCode(TxValidationCode) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
setTxValidationCodeValue(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.protos.TxValidationCode tx_validation_code = 3 [json_name = "txValidationCode"];
setType(int) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Header types 0-10000 are reserved and defined by HeaderType
setType(int) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
For outside implementors, consider the first 1000 types reserved, otherwise one of PolicyType
setType(int) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
Type holds the type of the MSP; the default one would be of type FABRIC implementing an X.509 based provider
setType(String) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The consensus type: "solo", "kafka" or "etcdraft".
setType(ChaincodeMessage.Type) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
setType(ChaincodeSpec.Type) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
setType(HeaderType) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.common.HeaderType type = 2 [json_name = "type"];
setTypeBytes(ByteString) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
The consensus type: "solo", "kafka" or "etcdraft".
setTypeValue(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
.protos.ChaincodeMessage.Type type = 1 [json_name = "type"];
setTypeValue(int) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
.protos.ChaincodeSpec.Type type = 1 [json_name = "type"];
setTypeValue(int) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
.common.HeaderType type = 2 [json_name = "type"];
setUnavailable(ChaincodeSource.Unavailable) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
setUnavailable(ChaincodeSource.Unavailable.Builder) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
.lifecycle.ChaincodeSource.Unavailable unavailable = 1 [json_name = "unavailable"];
setUnknownFields(UnknownFieldSet) - Method in class com.google.rpc.Status.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Block.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockHeader.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Capabilities.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Capability.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Config.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Consortium.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Envelope.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Header.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.LastConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.MSPRole.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Payload.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Error.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Layout.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Peer.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Peers.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Query.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Request.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.Response.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Empty.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Envelope.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Member.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Payload.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Properties.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.Secret.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ACLs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.APIResource.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.CDSData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.DelState.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.Endorsement.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetState.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.Proposal.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.Response.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.Transaction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo.Builder
 
setValidationCode(int) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction.Builder
An indication of whether the transaction was validated or invalidated by committing peer
setValidationParameter(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
setValidationParameter(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
bytes validation_parameter = 2 [json_name = "validationParameter"];
setValidationParameter(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
setValidationParameter(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
setValidationParameter(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
bytes validation_parameter = 5 [json_name = "validationParameter"];
setValidationParameter(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
bytes validation_parameter = 5 [json_name = "validationParameter"];
setValidationParameter(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
bytes validation_parameter = 6 [json_name = "validationParameter"];
setValidationPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
setValidationPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
string validation_plugin = 1 [json_name = "validationPlugin"];
setValidationPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
setValidationPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
setValidationPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
setValidationPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
setValidationPlugin(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
setValidationPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
setValidationPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo.Builder
string validation_plugin = 1 [json_name = "validationPlugin"];
setValidationPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
setValidationPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
setValidationPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
setValidationPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string validation_plugin = 4 [json_name = "validationPlugin"];
setValidationPluginBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string validation_plugin = 5 [json_name = "validationPlugin"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
bytes value = 2 [json_name = "value"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.common.Metadata.Builder
bytes value = 1 [json_name = "value"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.common.Policy.Builder
bytes value = 2 [json_name = "value"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification.Builder
bytes value = 2 [json_name = "value"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV.Builder
bytes value = 3 [json_name = "value"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry.Builder
bytes value = 2 [json_name = "value"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite.Builder
bytes value = 3 [json_name = "value"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.peer.PutState.Builder
bytes value = 2 [json_name = "value"];
setValue(ByteString) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata.Builder
bytes value = 2 [json_name = "value"];
setValueHash(ByteString) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash.Builder
bytes value_hash = 3 [json_name = "valueHash"];
setVersion(int) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader.Builder
Version indicates message protocol version
setVersion(long) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup.Builder
uint64 version = 1 [json_name = "version"];
setVersion(long) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy.Builder
uint64 version = 1 [json_name = "version"];
setVersion(long) - Method in class org.hyperledger.fabric.protos.common.ConfigValue.Builder
uint64 version = 1 [json_name = "version"];
setVersion(int) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope.Builder
int32 version = 1 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string version = 2 [json_name = "version"];
setVersion(Version) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
.kvrwset.Version version = 2 [json_name = "version"];
setVersion(Version.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead.Builder
.kvrwset.Version version = 2 [json_name = "version"];
setVersion(Version) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
.kvrwset.Version version = 2 [json_name = "version"];
setVersion(Version.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash.Builder
.kvrwset.Version version = 2 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Version of the chaincode
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
user friendly version name for the chaincode
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
A user friendly human readable name corresponding to the ID
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string version = 2 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string version = 3 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string version = 1 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string version = 3 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string version = 3 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string version = 3 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string version = 2 [json_name = "version"];
setVersion(String) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string version = 2 [json_name = "version"];
setVersion(int) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse.Builder
Version indicates message protocol version
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode.Builder
string version = 2 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Version of the chaincode
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID.Builder
user friendly version name for the chaincode
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier.Builder
A user friendly human readable name corresponding to the ID
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
string version = 2 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs.Builder
string version = 3 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo.Builder
string version = 1 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs.Builder
string version = 3 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs.Builder
string version = 3 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult.Builder
string version = 2 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition.Builder
string version = 3 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode.Builder
string version = 2 [json_name = "version"];
setVersionBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode.Builder
string version = 2 [json_name = "version"];
setVscc(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Vscc for the chaincode instance
setVscc(String) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the VSCC for this chaincode.
setVsccBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData.Builder
Vscc for the chaincode instance
setVsccBytes(ByteString) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo.Builder
the name of the VSCC for this chaincode.
setWidth(int) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure.Builder
width specifies the width of the Merkle tree to use when computing the BlockDataHash in order to replicate flat hashing, set this width to MAX_UINT32
setWrites(int, KVWrite) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
setWrites(int, KVWrite.Builder) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet.Builder
repeated .kvrwset.KVWrite writes = 3 [json_name = "writes"];
setWriteSet(ConfigGroup) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
WriteSet lists the portion of the config which was written, this should included updated Versions
setWriteSet(ConfigGroup.Builder) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate.Builder
WriteSet lists the portion of the config which was written, this should included updated Versions
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigSignature
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Envelope
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.MetadataSignature
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Envelope
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Endorsement
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SignedProposal
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
SIGNATURE_HASH_FAMILY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
SIGNATURE_HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigSignature
 
SIGNATURE_HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Header
 
SIGNATURE_HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.MetadataSignature
 
SIGNATURE_HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
SIGNATURE_HEADER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
SIGNATURE_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
SIGNATURE_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
SIGNATURE_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
SIGNATURE_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
SIGNATURE_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
SIGNATURE = 1;
SignatureHeader - Class in org.hyperledger.fabric.protos.common
Protobuf type common.SignatureHeader
SignatureHeader.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.SignatureHeader
SignatureHeaderOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
SignaturePolicy - Class in org.hyperledger.fabric.protos.common
SignaturePolicy is a recursive message structure which defines a featherweight DSL for describing policies which are more complicated than 'exactly this signature'.
SignaturePolicy.Builder - Class in org.hyperledger.fabric.protos.common
SignaturePolicy is a recursive message structure which defines a featherweight DSL for describing policies which are more complicated than 'exactly this signature'.
SignaturePolicy.NOutOf - Class in org.hyperledger.fabric.protos.common
Protobuf type common.SignaturePolicy.NOutOf
SignaturePolicy.NOutOf.Builder - Class in org.hyperledger.fabric.protos.common
Protobuf type common.SignaturePolicy.NOutOf
SignaturePolicy.NOutOfOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
SignaturePolicy.TypeCase - Enum in org.hyperledger.fabric.protos.common
 
SignaturePolicyEnvelope - Class in org.hyperledger.fabric.protos.common
SignaturePolicyEnvelope wraps a SignaturePolicy and includes a version for future enhancements
SignaturePolicyEnvelope.Builder - Class in org.hyperledger.fabric.protos.common
SignaturePolicyEnvelope wraps a SignaturePolicy and includes a version for future enhancements
SignaturePolicyEnvelopeOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
SignaturePolicyOrBuilder - Interface in org.hyperledger.fabric.protos.common
 
SIGNATURES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
SIGNATURES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Metadata
 
SIGNATURES_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
Block metadata array position for block signatures
SIGNED_BY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
SignedCcDepSpecProto - Class in org.hyperledger.fabric.protos.peer
 
SignedChaincodeDeploymentSpec - Class in org.hyperledger.fabric.protos.peer
SignedChaincodeDeploymentSpec carries the CDS along with endorsements
SignedChaincodeDeploymentSpec.Builder - Class in org.hyperledger.fabric.protos.peer
SignedChaincodeDeploymentSpec carries the CDS along with endorsements
SignedChaincodeDeploymentSpecOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
SignedChaincodeEventsRequest - Class in org.hyperledger.fabric.protos.gateway
SignedChaincodeEventsRequest contains a serialized ChaincodeEventsRequest message, and a digital signature for the serialized request message.
SignedChaincodeEventsRequest.Builder - Class in org.hyperledger.fabric.protos.gateway
SignedChaincodeEventsRequest contains a serialized ChaincodeEventsRequest message, and a digital signature for the serialized request message.
SignedChaincodeEventsRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
SignedCommitStatusRequest - Class in org.hyperledger.fabric.protos.gateway
SignedCommitStatusRequest contains a serialized CommitStatusRequest message, and a digital signature for the serialized request message.
SignedCommitStatusRequest.Builder - Class in org.hyperledger.fabric.protos.gateway
SignedCommitStatusRequest contains a serialized CommitStatusRequest message, and a digital signature for the serialized request message.
SignedCommitStatusRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
SignedProposal - Class in org.hyperledger.fabric.protos.peer
This structure is necessary to sign the proposal which contains the header and the payload.
SignedProposal.Builder - Class in org.hyperledger.fabric.protos.peer
This structure is necessary to sign the proposal which contains the header and the payload.
SignedProposalOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
SignedRequest - Class in org.hyperledger.fabric.protos.discovery
SignedRequest contains a serialized Request in the payload field and a signature.
SignedRequest.Builder - Class in org.hyperledger.fabric.protos.discovery
SignedRequest contains a serialized Request in the payload field and a signature.
SignedRequestOrBuilder - Interface in org.hyperledger.fabric.protos.discovery
 
SignedSnapshotRequest - Class in org.hyperledger.fabric.protos.peer
SignedSnapshotRequest contains marshalled request bytes and signature
SignedSnapshotRequest.Builder - Class in org.hyperledger.fabric.protos.peer
SignedSnapshotRequest contains marshalled request bytes and signature
SignedSnapshotRequestOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
SIGNER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
SIGNING_IDENTITY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
SigningIdentityInfo - Class in org.hyperledger.fabric.protos.msp
SigningIdentityInfo represents the configuration information related to the signing identity the peer is to use for generating endorsements
SigningIdentityInfo.Builder - Class in org.hyperledger.fabric.protos.msp
SigningIdentityInfo represents the configuration information related to the signing identity the peer is to use for generating endorsements
SigningIdentityInfoOrBuilder - Interface in org.hyperledger.fabric.protos.msp
 
SK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
SNAPSHOT_INTERVAL_SIZE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
SnapshotGrpc - Class in org.hyperledger.fabric.protos.peer
 
SnapshotGrpc.SnapshotBlockingStub - Class in org.hyperledger.fabric.protos.peer
 
SnapshotGrpc.SnapshotFutureStub - Class in org.hyperledger.fabric.protos.peer
 
SnapshotGrpc.SnapshotImplBase - Class in org.hyperledger.fabric.protos.peer
 
SnapshotGrpc.SnapshotStub - Class in org.hyperledger.fabric.protos.peer
 
SnapshotImplBase() - Constructor for class org.hyperledger.fabric.protos.peer.SnapshotGrpc.SnapshotImplBase
 
SnapshotProto - Class in org.hyperledger.fabric.protos.peer
 
SnapshotQuery - Class in org.hyperledger.fabric.protos.peer
SnapshotQuery contains information for a query snapshot request
SnapshotQuery.Builder - Class in org.hyperledger.fabric.protos.peer
SnapshotQuery contains information for a query snapshot request
SnapshotQueryOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
SnapshotRequest - Class in org.hyperledger.fabric.protos.peer
SnapshotRequest contains information for a generate/cancel snapshot request
SnapshotRequest.Builder - Class in org.hyperledger.fabric.protos.peer
SnapshotRequest contains information for a generate/cancel snapshot request
SnapshotRequestOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
SOURCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
SOURCE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
SPECIFIED_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
START_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
START_KEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
START_POSITION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
START_SEQ_NUM_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
STARTKEY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
STATE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
STATE_INFO_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.discovery.Peer
 
STATE_INFO_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
STATE_INFO_PULL_REQ_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
STATE_MAINTENANCE_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
STATE_MAINTENANCE = 1;
STATE_NORMAL_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
STATE_NORMAL = 0;
STATE_REQUEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
STATE_RESPONSE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
STATE_SNAPSHOT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
StateData - Class in org.hyperledger.fabric.protos.peer.lifecycle
StateData encodes a particular field of a datatype
StateData.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
StateData encodes a particular field of a datatype
StateData.TypeCase - Enum in org.hyperledger.fabric.protos.peer.lifecycle
 
StateDataOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
StateInfo - Class in org.hyperledger.fabric.protos.gossip
StateInfo is used for a peer to relay its state information to other peers
StateInfo.Builder - Class in org.hyperledger.fabric.protos.gossip
StateInfo is used for a peer to relay its state information to other peers
StateInfoOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
StateInfoPullRequest - Class in org.hyperledger.fabric.protos.gossip
StateInfoPullRequest is used to fetch a StateInfoSnapshot from a remote peer
StateInfoPullRequest.Builder - Class in org.hyperledger.fabric.protos.gossip
StateInfoPullRequest is used to fetch a StateInfoSnapshot from a remote peer
StateInfoPullRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
StateInfoSnapshot - Class in org.hyperledger.fabric.protos.gossip
StateInfoSnapshot is an aggregation of StateInfo messages
StateInfoSnapshot.Builder - Class in org.hyperledger.fabric.protos.gossip
StateInfoSnapshot is an aggregation of StateInfo messages
StateInfoSnapshotOrBuilder - Interface in org.hyperledger.fabric.protos.gossip
 
StateMetadata - Class in org.hyperledger.fabric.protos.peer.lifecycle
StateMetadata describes the keys in a namespace.
StateMetadata - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.StateMetadata
StateMetadata.Builder - Class in org.hyperledger.fabric.protos.peer.lifecycle
StateMetadata describes the keys in a namespace.
StateMetadata.Builder - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.StateMetadata
StateMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.peer.lifecycle
 
StateMetadataOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
StateMetadataResult - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.StateMetadataResult
StateMetadataResult.Builder - Class in org.hyperledger.fabric.protos.peer
Protobuf type protos.StateMetadataResult
StateMetadataResultOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
STATIC_COLLECTION_CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
STATIC_COLLECTION_CONFIG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
StaticCollectionConfig - Class in org.hyperledger.fabric.protos.common
Deprecated.
StaticCollectionConfig - Class in org.hyperledger.fabric.protos.peer
StaticCollectionConfig constitutes the configuration parameters of a static collection object.
StaticCollectionConfig.Builder - Class in org.hyperledger.fabric.protos.common
Deprecated.
StaticCollectionConfig constitutes the configuration parameters of a static collection object.
StaticCollectionConfig.Builder - Class in org.hyperledger.fabric.protos.peer
StaticCollectionConfig constitutes the configuration parameters of a static collection object.
StaticCollectionConfigOrBuilder - Interface in org.hyperledger.fabric.protos.common
Deprecated.
StaticCollectionConfigOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
Status - Class in com.google.rpc
The `Status` type defines a logical error model that is suitable for different programming environments, including REST APIs and RPC APIs.
Status - Enum in org.hyperledger.fabric.protos.common
These status codes are intended to resemble selected HTTP status codes
Status.Builder - Class in com.google.rpc
The `Status` type defines a logical error model that is suitable for different programming environments, including REST APIs and RPC APIs.
STATUS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
STATUS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.Response
 
StatusOrBuilder - Interface in com.google.rpc
 
StatusProto - Class in com.google.rpc
 
step(StreamObserver<StepResponse>) - Method in class org.hyperledger.fabric.protos.orderer.ClusterGrpc.ClusterImplBase
Step passes an implementation-specific message to another cluster member.
step(StreamObserver<StepResponse>) - Method in class org.hyperledger.fabric.protos.orderer.ClusterGrpc.ClusterStub
Step passes an implementation-specific message to another cluster member.
StepRequest - Class in org.hyperledger.fabric.protos.orderer
StepRequest wraps a message that is sent to a cluster member.
StepRequest.Builder - Class in org.hyperledger.fabric.protos.orderer
StepRequest wraps a message that is sent to a cluster member.
StepRequest.PayloadCase - Enum in org.hyperledger.fabric.protos.orderer
 
StepRequestOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
StepResponse - Class in org.hyperledger.fabric.protos.orderer
StepResponse is a message received from a cluster member.
StepResponse.Builder - Class in org.hyperledger.fabric.protos.orderer
StepResponse is a message received from a cluster member.
StepResponse.PayloadCase - Enum in org.hyperledger.fabric.protos.orderer
 
StepResponseOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
STOP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
STRICT_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
STRICT = 0;
STRING_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
SUB_POLICY_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
submit(SubmitRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayBlockingStub
The Submit service will process the prepared transaction returned from Endorse service once it has been signed by the client.
submit(SubmitRequest) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayFutureStub
The Submit service will process the prepared transaction returned from Endorse service once it has been signed by the client.
submit(SubmitRequest, StreamObserver<SubmitResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayImplBase
The Submit service will process the prepared transaction returned from Endorse service once it has been signed by the client.
submit(SubmitRequest, StreamObserver<SubmitResponse>) - Method in class org.hyperledger.fabric.protos.gateway.GatewayGrpc.GatewayStub
The Submit service will process the prepared transaction returned from Endorse service once it has been signed by the client.
SUBMIT_REQUEST_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.StepRequest
 
SUBMIT_RES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.StepResponse
 
SubmitRequest - Class in org.hyperledger.fabric.protos.gateway
SubmitRequest contains the details required to submit a transaction (update the ledger).
SubmitRequest - Class in org.hyperledger.fabric.protos.orderer
SubmitRequest wraps a transaction to be sent for ordering.
SubmitRequest.Builder - Class in org.hyperledger.fabric.protos.gateway
SubmitRequest contains the details required to submit a transaction (update the ledger).
SubmitRequest.Builder - Class in org.hyperledger.fabric.protos.orderer
SubmitRequest wraps a transaction to be sent for ordering.
SubmitRequestOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
SubmitRequestOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
SubmitResponse - Class in org.hyperledger.fabric.protos.gateway
SubmitResponse returns the result of submitting a transaction.
SubmitResponse - Class in org.hyperledger.fabric.protos.orderer
SubmitResponse returns a success or failure status to the sender.
SubmitResponse.Builder - Class in org.hyperledger.fabric.protos.gateway
SubmitResponse returns the result of submitting a transaction.
SubmitResponse.Builder - Class in org.hyperledger.fabric.protos.orderer
SubmitResponse returns a success or failure status to the sender.
SubmitResponseOrBuilder - Interface in org.hyperledger.fabric.protos.gateway
 
SubmitResponseOrBuilder - Interface in org.hyperledger.fabric.protos.orderer
 
SUCCESS_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
SUCCESS = 200;

T

TAG_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
TARGET_CHAIN_NOT_FOUND_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
TARGET_CHAIN_NOT_FOUND = 14;
TARGET_ORGANIZATIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
TICK_INTERVAL_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
TIME_TO_CUT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
TIMEOUT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
TIMEOUT_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ChannelHeader
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.StateInfo
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
TIMESTAMP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
TLS_CERT_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ChannelHeader
 
TLS_CERT_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
TLS_INTERMEDIATE_CERTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
TLS_ROOT_CERTS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
toBuilder() - Method in class com.google.rpc.Status
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Block
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.BlockData
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Capability
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Config
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Consortium
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Envelope
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Header
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Metadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Payload
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.Policy
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
toBuilder() - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Error
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Query
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Request
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.Response
 
toBuilder() - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Member
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
toBuilder() - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
toBuilder() - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.DelState
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.GetState
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.PutState
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.Response
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
toBuilder() - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
toBuilder() - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
Transaction - Class in org.hyperledger.fabric.protos.peer
The transaction to be sent to the ordering service.
Transaction.Builder - Class in org.hyperledger.fabric.protos.peer
The transaction to be sent to the ordering service.
TRANSACTION_ACTIONS_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
TRANSACTION_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
TRANSACTION_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
TRANSACTION = 5;
TransactionAction - Class in org.hyperledger.fabric.protos.peer
TransactionAction binds a proposal to its action.
TransactionAction.Builder - Class in org.hyperledger.fabric.protos.peer
TransactionAction binds a proposal to its action.
TransactionActionOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
TRANSACTIONENVELOPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
TransactionOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 
TransactionProto - Class in org.hyperledger.fabric.protos.peer
 
TRANSACTIONS_FILTER_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
Block metadata array position to store serialized bit array filter of invalid transactions
TRANSIENTMAP_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
TransientstoreProto - Class in org.hyperledger.fabric.protos.transientstore
 
TX_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ChannelHeader
 
TX_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
TX_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
TX_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
TX_ID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
TX_NUM_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
TX_SEQ_IN_BLOCK_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
TX_VALIDATION_CODE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
TXID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
TXID_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
TxPvtReadWriteSet - Class in org.hyperledger.fabric.protos.ledger.rwset
TxPvtReadWriteSet encapsulate the private read-write set for a transaction
TxPvtReadWriteSet.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset
TxPvtReadWriteSet encapsulate the private read-write set for a transaction
TxPvtReadWriteSetOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset
 
TxPvtReadWriteSetWithConfigInfo - Class in org.hyperledger.fabric.protos.transientstore
TxPvtReadWriteSetWithConfigInfo encapsulates the transaction's private read-write set and additional information about the configurations such as the latest collection config when the transaction is simulated
TxPvtReadWriteSetWithConfigInfo.Builder - Class in org.hyperledger.fabric.protos.transientstore
TxPvtReadWriteSetWithConfigInfo encapsulates the transaction's private read-write set and additional information about the configurations such as the latest collection config when the transaction is simulated
TxPvtReadWriteSetWithConfigInfoOrBuilder - Interface in org.hyperledger.fabric.protos.transientstore
 
TxReadWriteSet - Class in org.hyperledger.fabric.protos.ledger.rwset
TxReadWriteSet encapsulates a read-write set for a transaction DataModel specifies the enum value of the data model ns_rwset field specifies a list of chaincode specific read-write set (one for each chaincode)
TxReadWriteSet.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset
TxReadWriteSet encapsulates a read-write set for a transaction DataModel specifies the enum value of the data model ns_rwset field specifies a list of chaincode specific read-write set (one for each chaincode)
TxReadWriteSet.DataModel - Enum in org.hyperledger.fabric.protos.ledger.rwset
Protobuf enum rwset.TxReadWriteSet.DataModel
TxReadWriteSetOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset
 
TxValidationCode - Enum in org.hyperledger.fabric.protos.peer
Protobuf enum protos.TxValidationCode
TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ChannelHeader
 
TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Policy
 
TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.msp.MSPConfig
 
TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
TYPE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 

U

UNAVAILABLE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
UNDEFINED_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
UNDEFINED = 0;
UNDEFINED_VALUE - Static variable in enum org.hyperledger.fabric.protos.gossip.PullMsgType
UNDEFINED = 0;
UNDEFINED_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
UNDEFINED = 0;
UNDEFINED_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
UNDEFINED = 0;
UNKNOWN_TX_TYPE_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
UNKNOWN_TX_TYPE = 13;
UNKNOWN_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
Reserved to check for proper initialization
UNKNOWN_VALUE - Static variable in enum org.hyperledger.fabric.protos.common.Status
UNKNOWN = 0;
UNKNOWN_VALUE - Static variable in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
UNKNOWN = 0;
UNSUPPORTED_TX_PAYLOAD_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
UNSUPPORTED_TX_PAYLOAD = 7;

V

VALID_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.TxValidationCode
VALID = 0;
VALIDATION_PARAMETER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
VALIDATION_PARAMETER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
VALIDATION_PARAMETER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
VALIDATION_PARAMETER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
VALIDATION_PARAMETER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
VALIDATION_PARAMETER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
VALIDATION_PARAMETER_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
VALIDATION_PARAMETER_V2_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
VALIDATION_PARAMETER_V2 = 1;
VALIDATION_PARAMETER_VALUE - Static variable in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
VALIDATION_PARAMETER = 0;
VALIDATION_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
VALIDATION_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
VALIDATION_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
VALIDATION_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
VALIDATION_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
VALIDATION_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
VALIDATION_PLUGIN_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
VALIDATIONCODE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigValue
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Metadata
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.Policy
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.PutState
 
VALUE_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.StateMetadata
 
VALUE_HASH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.ApplicationPolicy.TypeCase
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.ApplicationPolicy.TypeCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.CollectionConfig.PayloadCase
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.CollectionConfig.PayloadCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.CollectionPolicyConfig.PayloadCase
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.CollectionPolicyConfig.PayloadCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.HeaderType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.HeaderType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.common.HeaderType
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.SignaturePolicy.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.SignaturePolicy.TypeCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.common.Status
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.common.Status
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.common.Status
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.discovery.Query.QueryCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.discovery.Query.QueryCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.discovery.QueryResult.ResultCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.discovery.QueryResult.ResultCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.ContentCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.ContentCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.gossip.Secret.ContentCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.gossip.Secret.ContentCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.ReadsInfoCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.ReadsInfoCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.TypeCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.DeliverResponse.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.DeliverResponse.TypeCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessage.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessage.TypeCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekPosition.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.SeekPosition.TypeCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.StepRequest.PayloadCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.StepRequest.PayloadCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.orderer.StepResponse.PayloadCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.orderer.StepResponse.PayloadCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.ApplicationPolicy.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.ApplicationPolicy.TypeCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.CollectionConfig.PayloadCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.CollectionConfig.PayloadCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.PayloadCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.PayloadCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.DeliverResponse.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.DeliverResponse.TypeCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.FilteredTransaction.DataCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.FilteredTransaction.DataCase
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.TypeCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.lifecycle.StateData.TypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.lifecycle.StateData.TypeCase
Deprecated.
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
 
valueOf(String) - Static method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
 
values() - Static method in enum org.hyperledger.fabric.protos.common.ApplicationPolicy.TypeCase
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.BlockMetadataIndex
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.CollectionConfig.PayloadCase
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.CollectionPolicyConfig.PayloadCase
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.HeaderType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.ImplicitMetaPolicy.Rule
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.MSPIdentityAnonymity.MSPIdentityAnonymityType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.MSPPrincipal.Classification
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.MSPRole.MSPRoleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.Policy.PolicyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.SignaturePolicy.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.common.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.discovery.Query.QueryCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.discovery.QueryResult.ResultCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.ContentCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.gossip.GossipMessage.Tag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.gossip.PullMsgType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.gossip.Secret.ContentCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo.ReadsInfoCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet.DataModel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.BlockAttestationResponse.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.ConsensusType.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.DeliverResponse.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessage.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.KafkaMessageRegular.Class
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.SeekInfo.SeekErrorResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.SeekPosition.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.StepRequest.PayloadCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.orderer.StepResponse.PayloadCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.ApplicationPolicy.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeMessage.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.ChaincodeSpec.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.CollectionConfig.PayloadCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.CollectionPolicyConfig.PayloadCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.DeliverResponse.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.FilteredTransaction.DataCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.lifecycle.StateData.TypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.MetaDataKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hyperledger.fabric.protos.peer.TxValidationCode
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigGroup
 
Version - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
Version encapsulates the version of a Key A version of a committed key is maintained as the height of the transaction that committed the key.
Version.Builder - Class in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
Version encapsulates the version of a Key A version of a committed key is maintained as the height of the transaction that committed the key.
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ChannelHeader
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigGroup
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigValue
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.gossip.Chaincode
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
VERSION_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
VersionOrBuilder - Interface in org.hyperledger.fabric.protos.ledger.rwset.kvrwset
 
VSCC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
VSCC_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
VSCCArgs - Class in org.hyperledger.fabric.protos.peer
VSCCArgs is passed (marshaled) as a parameter to the VSCC imlementation via the argument field of the ChaincodeValidation message.
VSCCArgs.Builder - Class in org.hyperledger.fabric.protos.peer
VSCCArgs is passed (marshaled) as a parameter to the VSCC imlementation via the argument field of the ChaincodeValidation message.
VSCCArgsOrBuilder - Interface in org.hyperledger.fabric.protos.peer
 

W

WIDTH_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
WRITE_SET_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
WRITES_FIELD_NUMBER - Static variable in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
writeTo(CodedOutputStream) - Method in class com.google.rpc.Status
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ApplicationPolicy
Deprecated.
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Block
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.BlockchainInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.BlockData
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.BlockDataHashingStructure
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.BlockHeader
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.BlockMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.BootstrappingSnapshotInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Capabilities
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Capability
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ChannelHeader
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.CollectionConfig
Deprecated.
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.CollectionConfigPackage
Deprecated.
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.CollectionPolicyConfig
Deprecated.
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.CombinedPrincipal
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Config
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ConfigEnvelope
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ConfigGroup
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ConfigPolicy
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ConfigSignature
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdate
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ConfigUpdateEnvelope
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ConfigValue
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Consortium
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Envelope
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.HashingAlgorithm
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Header
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.ImplicitMetaPolicy
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.LastConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Metadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.MetadataSignature
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.MSPIdentityAnonymity
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.MSPPrincipal
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.MSPRole
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.OrdererAddresses
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.OrdererBlockMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.OrganizationUnit
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Payload
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.Policy
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.SignatureHeader
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy.NOutOf
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicy
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.SignaturePolicyEnvelope
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.common.StaticCollectionConfig
Deprecated.
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.AuthInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQuery
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.ChaincodeQueryResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.ConfigQuery
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.ConfigResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.EndorsementDescriptor
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Endpoint
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Endpoints
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Error
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Layout
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.LocalPeerQuery
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Peer
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipQuery
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.PeerMembershipResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Peers
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Query
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.QueryResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Request
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.Response
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.discovery.SignedRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.ChaincodeEventsResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.CommitStatusResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.EndorseRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.EndorseResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.ErrorDetail
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.EvaluateResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.PreparedTransaction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.ProposedTransaction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.SignedChaincodeEventsRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.SignedCommitStatusRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.SubmitRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gateway.SubmitResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.Acknowledgement
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.AliveMessage
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.Chaincode
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.ConnEstablish
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.DataDigest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.DataMessage
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.DataRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.DataUpdate
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.Empty
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.Envelope
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.GossipHello
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.GossipMessage
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.LeadershipMessage
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.Member
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.MembershipRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.MembershipResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.Payload
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.PeerIdentity
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.PeerTime
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.PrivateDataMessage
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.PrivatePayload
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.Properties
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataDigest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataElement
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.PvtDataPayload
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.RemotePvtDataResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.RemoteStateResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.Secret
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.SecretEnvelope
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.StateInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoPullRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.gossip.StateInfoSnapshot
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KeyModification
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.queryresult.KV
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionHashedReadWriteSet
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.CollectionPvtReadWriteSet
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.HashedRWSet
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataEntry
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWrite
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVMetadataWriteHash
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRead
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVReadHash
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVRWSet
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWrite
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.KVWriteHash
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReads
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.QueryReadsMerkleSummary
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.RangeQueryInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.kvrwset.Version
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsPvtReadWriteSet
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.NsReadWriteSet
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxPvtReadWriteSet
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.ledger.rwset.TxReadWriteSet
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.FabricCryptoConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.FabricMSPConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.FabricNodeOUs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.FabricOUIdentifier
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.IdemixMSPSignerConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.KeyInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.MSPConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdemixIdentity
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.SerializedIdentity
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.msp.SigningIdentityInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.BatchSize
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.BatchTimeout
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestation
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.BlockAttestationResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.BroadcastResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.ChannelRestrictions
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.ConsensusType
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.DeliverResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.BlockMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ClusterMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.ConfigMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Consenter
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.etcdraft.Options
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.KafkaBrokers
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessage
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageConnect
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageRegular
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMessageTimeToCut
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.KafkaMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.SeekInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.SeekNewest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.SeekNextCommit
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.SeekOldest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.SeekPosition
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.SeekSpecified
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.StepRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.StepResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.SubmitRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.orderer.SubmitResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ACLs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeer
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.AnchorPeers
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.APIResource
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ApplicationPolicy
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.BlockAndPrivateData
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.CDSData
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeAction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeActionPayload
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeCall
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeData
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeDeploymentSpec
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsedAction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEndorsement
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeEvent
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeHeaderExtension
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeID
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeIdentifier
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInput
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInterest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeInvocationSpec
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeMessage
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeProposalPayload
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeQueryResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeSpec
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChaincodeValidation
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChannelInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ChannelQueryResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.CollectionConfigPackage
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.CollectionPolicyConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ConfigTree
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.DeliverResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.DelState
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.Endorsement
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.FilteredBlock
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.FilteredChaincodeAction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransaction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.FilteredTransactionActions
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.GetHistoryForKey
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.GetQueryResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.GetState
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.GetStateByRange
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.GetStateMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.JoinBySnapshotStatus
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ApproveChaincodeDefinitionForMyOrgResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeEndorsementInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Local
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource.Unavailable
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeSource
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.ChaincodeValidationInfo
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CheckCommitReadinessResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.CommitChaincodeDefinitionResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.GetInstalledChaincodePackageResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.InstallChaincodeResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryApprovedChaincodeDefinitionResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult.ChaincodeDefinition
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryChaincodeDefinitionsResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.Chaincode
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult.References
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodeResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.Chaincode
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.InstalledChaincode
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult.References
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.QueryInstalledChaincodesResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateData
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.lifecycle.StateMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.LifecycleEvent
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ProcessedTransaction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.Proposal
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.ProposalResponsePayload
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.PurgePrivateState
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.PutState
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.PutStateMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.QueryMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.QueryPendingSnapshotsResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.QueryResponse
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.QueryResponseMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.QueryResultBytes
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.QueryStateClose
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.QueryStateNext
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.Response
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.SignedChaincodeDeploymentSpec
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.SignedProposal
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.SignedSnapshotRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.SnapshotQuery
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.SnapshotRequest
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.StateMetadata
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.StateMetadataResult
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.StaticCollectionConfig
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.Transaction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.TransactionAction
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.peer.VSCCArgs
 
writeTo(CodedOutputStream) - Method in class org.hyperledger.fabric.protos.transientstore.TxPvtReadWriteSetWithConfigInfo
 
A B C D E F G H I J K L M N O P Q R S T U V W 
Skip navigation links

Copyright © 2022. All rights reserved.