Documentation ¶
Index ¶
- Constants
- func IsDevMode() bool
- func NewTxKey(channelID, txID string) string
- func ParseName(ccName string) *sysccprovider.ChaincodeInstance
- type ACLProvider
- type ActiveTransactions
- type ApplicationConfigRetriever
- type CertGenerator
- type ChaincodeSupport
- func (cs *ChaincodeSupport) CheckInvocation(txParams *ccprovider.TransactionParams, chaincodeName string, ...) (ccid string, cctype pb.ChaincodeMessage_Type, err error)
- func (cs *ChaincodeSupport) Execute(txParams *ccprovider.TransactionParams, chaincodeName string, ...) (*pb.Response, *pb.ChaincodeEvent, error)
- func (cs *ChaincodeSupport) ExecuteLegacyInit(txParams *ccprovider.TransactionParams, ccName, ccVersion string, ...) (*pb.Response, *pb.ChaincodeEvent, error)
- func (cs *ChaincodeSupport) HandleChaincodeStream(stream ccintf.ChaincodeStream) error
- func (cs *ChaincodeSupport) Invoke(txParams *ccprovider.TransactionParams, chaincodeName string, ...) (*pb.ChaincodeMessage, error)
- func (cs *ChaincodeSupport) Launch(ccid string) (*Handler, error)
- func (cs *ChaincodeSupport) LaunchInProc(ccid string) <-chan struct{}
- func (cs *ChaincodeSupport) Register(stream pb.ChaincodeSupport_RegisterServer) error
- type CollectionACLCache
- type Config
- type ConnectionHandler
- type ContainerRouter
- type ContainerRuntime
- type ContextRegistry
- type Handler
- func (h *Handler) Close()
- func (h *Handler) Execute(txParams *ccprovider.TransactionParams, namespace string, ...) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleDelState(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleGetHistoryForKey(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleGetPrivateDataHash(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleGetQueryResult(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleGetState(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleGetStateByRange(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleGetStateMetadata(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleInvokeChaincode(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandlePutState(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandlePutStateMetadata(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleQueryStateClose(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleQueryStateNext(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
- func (h *Handler) HandleRegister(msg *pb.ChaincodeMessage)
- func (h *Handler) HandleTransaction(msg *pb.ChaincodeMessage, delegate handleFunc)
- func (h *Handler) Notify(msg *pb.ChaincodeMessage)
- func (h *Handler) ProcessStream(stream ccintf.ChaincodeStream) error
- func (h *Handler) State() State
- type HandlerMetrics
- type HandlerRegistry
- func (r *HandlerRegistry) Deregister(ccid string) error
- func (r *HandlerRegistry) Failed(ccid string, err error)
- func (r *HandlerRegistry) Handler(ccid string) *Handler
- func (r *HandlerRegistry) Launching(ccid string) (*LaunchState, bool)
- func (r *HandlerRegistry) Ready(ccid string)
- func (r *HandlerRegistry) Register(h *Handler) error
- type Invoker
- type LaunchMetrics
- type LaunchRegistry
- type LaunchState
- type Launcher
- type LedgerGetter
- type Lifecycle
- type MessageHandler
- type PendingQueryResult
- type QueryResponseBuilder
- type QueryResponseGenerator
- type Registry
- type Runtime
- type RuntimeLauncher
- type State
- type TransactionContext
- func (t *TransactionContext) CleanupQueryContext(queryID string)
- func (t *TransactionContext) CleanupQueryContextWithBookmark(queryID string) string
- func (t *TransactionContext) CloseQueryIterators()
- func (t *TransactionContext) GetPendingQueryResult(queryID string) *PendingQueryResult
- func (t *TransactionContext) GetQueryIterator(queryID string) commonledger.ResultsIterator
- func (t *TransactionContext) GetTotalReturnCount(queryID string) *int32
- func (t *TransactionContext) InitializeCollectionACLCache()
- func (t *TransactionContext) InitializeQueryContext(queryID string, iter commonledger.ResultsIterator)
- type TransactionContexts
- type TransactionRegistry
- type TxQueryExecutorGetter
- type UUIDGenerator
- type UUIDGeneratorFunc
Constants ¶
const DevModeUserRunsChaincode string = "dev"
DevModeUserRunsChaincode enables chaincode execution in a development environment
const ( // InitializedKeyName is the reserved key in a chaincode's namespace which // records the ID of the chaincode which initialized the namespace. // In this way, we can enforce Init exactly once semantics, whenever // the backing chaincode bytes change (but not be required to re-initialize // the chaincode say, when endorsement policy changes). InitializedKeyName = "\x00" + string(utf8.MaxRune) + "initialized" )
Variables ¶
This section is empty.
Functions ¶
func IsDevMode ¶
func IsDevMode() bool
IsDevMode returns true if the peer was configured with development-mode enabled.
func ParseName ¶
func ParseName(ccName string) *sysccprovider.ChaincodeInstance
ParseName parses a chaincode name into a ChaincodeInstance. The name should be of the form "chaincode-name:version/channel-name" with optional elements.
Types ¶
type ACLProvider ¶
An ACLProvider performs access control checks when invoking chaincode.
type ActiveTransactions ¶
type ActiveTransactions struct {
// contains filtered or unexported fields
}
func NewActiveTransactions ¶
func NewActiveTransactions() *ActiveTransactions
func (*ActiveTransactions) Add ¶
func (a *ActiveTransactions) Add(channelID, txID string) bool
func (*ActiveTransactions) Remove ¶
func (a *ActiveTransactions) Remove(channelID, txID string)
type ApplicationConfigRetriever ¶
type ApplicationConfigRetriever interface { // GetApplicationConfig returns the channelconfig.Application for the channel // and whether the Application config exists GetApplicationConfig(cid string) (channelconfig.Application, bool) }
ApplicationConfigRetriever to retrieve the application configuration for a channel
type CertGenerator ¶
type CertGenerator interface { // Generate returns a certificate and private key and associates // the hash of the certificates with the given chaincode name Generate(ccName string) (*accesscontrol.CertAndPrivKeyPair, error) }
CertGenerator generates client certificates for chaincode.
type ChaincodeSupport ¶
type ChaincodeSupport struct { ACLProvider ACLProvider AppConfig ApplicationConfigRetriever BuiltinSCCs scc.BuiltinSCCs DeployedCCInfoProvider ledger.DeployedChaincodeInfoProvider ExecuteTimeout time.Duration InstallTimeout time.Duration HandlerMetrics *HandlerMetrics HandlerRegistry *HandlerRegistry Keepalive time.Duration Launcher Launcher Lifecycle Lifecycle Peer *peer.Peer Runtime Runtime TotalQueryLimit int UserRunsCC bool }
ChaincodeSupport responsible for providing interfacing with chaincodes from the Peer.
func (*ChaincodeSupport) CheckInvocation ¶
func (cs *ChaincodeSupport) CheckInvocation(txParams *ccprovider.TransactionParams, chaincodeName string, input *pb.ChaincodeInput) (ccid string, cctype pb.ChaincodeMessage_Type, err error)
CheckInvocation inspects the parameters of an invocation and determines if, how, and to where a that invocation should be routed. First, we ensure that the target namespace is defined on the channel and invokable on this peer, according to the lifecycle implementation. Then, if the chaincode definition requires it, this function enforces 'init exactly once' semantics. Finally, it returns the chaincode ID to route to and the message type of the request (normal transation, or init).
func (*ChaincodeSupport) Execute ¶
func (cs *ChaincodeSupport) Execute(txParams *ccprovider.TransactionParams, chaincodeName string, input *pb.ChaincodeInput) (*pb.Response, *pb.ChaincodeEvent, error)
Execute invokes chaincode and returns the original response.
func (*ChaincodeSupport) ExecuteLegacyInit ¶
func (cs *ChaincodeSupport) ExecuteLegacyInit(txParams *ccprovider.TransactionParams, ccName, ccVersion string, input *pb.ChaincodeInput) (*pb.Response, *pb.ChaincodeEvent, error)
ExecuteLegacyInit is a temporary method which should be removed once the old style lifecycle is entirely deprecated. Ideally one release after the introduction of the new lifecycle. It does not attempt to start the chaincode based on the information from lifecycle, but instead accepts the container information directly in the form of a ChaincodeDeploymentSpec.
func (*ChaincodeSupport) HandleChaincodeStream ¶
func (cs *ChaincodeSupport) HandleChaincodeStream(stream ccintf.ChaincodeStream) error
HandleChaincodeStream implements ccintf.HandleChaincodeStream for all vms to call with appropriate stream
func (*ChaincodeSupport) Invoke ¶
func (cs *ChaincodeSupport) Invoke(txParams *ccprovider.TransactionParams, chaincodeName string, input *pb.ChaincodeInput) (*pb.ChaincodeMessage, error)
Invoke will invoke chaincode and return the message containing the response. The chaincode will be launched if it is not already running.
func (*ChaincodeSupport) Launch ¶
func (cs *ChaincodeSupport) Launch(ccid string) (*Handler, error)
Launch starts executing chaincode if it is not already running. This method blocks until the peer side handler gets into ready state or encounters a fatal error. If the chaincode is already running, it simply returns.
func (*ChaincodeSupport) LaunchInProc ¶
func (cs *ChaincodeSupport) LaunchInProc(ccid string) <-chan struct{}
LaunchInProc is a stopgap solution to be called by the inproccontroller to allow system chaincodes to register
func (*ChaincodeSupport) Register ¶
func (cs *ChaincodeSupport) Register(stream pb.ChaincodeSupport_RegisterServer) error
Register the bidi stream entry point called by chaincode to register with the Peer.
type CollectionACLCache ¶
type CollectionACLCache map[string]*readWritePermission
CollectionACLCache encapsulates a cache that stores read write permission on a collection
type Config ¶
type Config struct { TotalQueryLimit int TLSEnabled bool Keepalive time.Duration ExecuteTimeout time.Duration InstallTimeout time.Duration StartupTimeout time.Duration LogFormat string LogLevel string ShimLogLevel string SCCWhitelist map[string]bool }
func GlobalConfig ¶
func GlobalConfig() *Config
type ConnectionHandler ¶
type ConnectionHandler interface {
Stream(ccid string, ccinfo *ccintf.ChaincodeServerInfo, sHandler extcc.StreamHandler) error
}
ConnectionHandler handles the `Chaincode` client connection
type ContainerRouter ¶
type ContainerRouter interface { Build(ccid string) error ChaincodeServerInfo(ccid string) (*ccintf.ChaincodeServerInfo, error) Start(ccid string, peerConnection *ccintf.PeerConnection) error Stop(ccid string) error Wait(ccid string) (int, error) }
ContainerRouter is a poor abstraction used for building, and running chaincode processes. This management probably does not belong in this package, chaincode process lifecycle should be driven by what chaincodes are defined, what chaincodes are instantiated, and not driven by invocations. But, the legacy lifecycle makes this very challenging. Once the legacy lifecycle is removed (or perhaps before), this interface should probably go away entirely.
type ContainerRuntime ¶
type ContainerRuntime struct { ContainerRouter ContainerRouter BuildRegistry *container.BuildRegistry }
ContainerRuntime is responsible for managing containerized chaincode.
func (*ContainerRuntime) Build ¶
func (c *ContainerRuntime) Build(ccid string) (*ccintf.ChaincodeServerInfo, error)
Build builds the chaincode if necessary and returns ChaincodeServerInfo if the chaincode is a server
func (*ContainerRuntime) Start ¶
func (c *ContainerRuntime) Start(ccid string, ccinfo *ccintf.PeerConnection) error
Start launches chaincode in a runtime environment.
func (*ContainerRuntime) Stop ¶
func (c *ContainerRuntime) Stop(ccid string) error
Stop terminates chaincode and its container runtime environment.
type ContextRegistry ¶
type ContextRegistry interface { Create(txParams *ccprovider.TransactionParams) (*TransactionContext, error) Get(chainID, txID string) *TransactionContext Delete(chainID, txID string) Close() }
A ContextRegistry is responsible for managing transaction contexts.
type Handler ¶
type Handler struct { // Keepalive specifies the interval at which keep-alive messages are sent. Keepalive time.Duration // TotalQueryLimit specifies the maximum number of results to return for // chaincode queries. TotalQueryLimit int // Invoker is used to invoke chaincode. Invoker Invoker // Registry is used to track active handlers. Registry Registry // ACLProvider is used to check if a chaincode invocation should be allowed. ACLProvider ACLProvider // TXContexts is a collection of TransactionContext instances // that are accessed by channel name and transaction ID. TXContexts ContextRegistry // activeTransactions holds active transaction identifiers. ActiveTransactions TransactionRegistry // BuiltinSCCs can be used to determine if a name is associated with a system chaincode BuiltinSCCs scc.BuiltinSCCs // QueryResponseBuilder is used to build query responses QueryResponseBuilder QueryResponseBuilder // LedgerGetter is used to get the ledger associated with a channel LedgerGetter LedgerGetter // DeployedCCInfoProvider is used to initialize the Collection Store DeployedCCInfoProvider ledger.DeployedChaincodeInfoProvider // UUIDGenerator is used to generate UUIDs UUIDGenerator UUIDGenerator // AppConfig is used to retrieve the application config for a channel AppConfig ApplicationConfigRetriever // Metrics holds chaincode handler metrics Metrics *HandlerMetrics // contains filtered or unexported fields }
Handler implements the peer side of the chaincode stream.
func (*Handler) Execute ¶
func (h *Handler) Execute(txParams *ccprovider.TransactionParams, namespace string, msg *pb.ChaincodeMessage, timeout time.Duration) (*pb.ChaincodeMessage, error)
func (*Handler) HandleDelState ¶
func (h *Handler) HandleDelState(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
func (*Handler) HandleGetHistoryForKey ¶
func (h *Handler) HandleGetHistoryForKey(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
Handles query to ledger history db
func (*Handler) HandleGetPrivateDataHash ¶ added in v1.4.2
func (h *Handler) HandleGetPrivateDataHash(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
func (*Handler) HandleGetQueryResult ¶
func (h *Handler) HandleGetQueryResult(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
Handles query to ledger to execute query state
func (*Handler) HandleGetState ¶
func (h *Handler) HandleGetState(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
Handles query to ledger to get state
func (*Handler) HandleGetStateByRange ¶
func (h *Handler) HandleGetStateByRange(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
Handles query to ledger to rage query state
func (*Handler) HandleGetStateMetadata ¶
func (h *Handler) HandleGetStateMetadata(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
Handles query to ledger to get state metadata
func (*Handler) HandleInvokeChaincode ¶
func (h *Handler) HandleInvokeChaincode(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
Handles requests that modify ledger state
func (*Handler) HandlePutState ¶
func (h *Handler) HandlePutState(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
func (*Handler) HandlePutStateMetadata ¶
func (h *Handler) HandlePutStateMetadata(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
func (*Handler) HandleQueryStateClose ¶
func (h *Handler) HandleQueryStateClose(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
Handles the closing of a state iterator
func (*Handler) HandleQueryStateNext ¶
func (h *Handler) HandleQueryStateNext(msg *pb.ChaincodeMessage, txContext *TransactionContext) (*pb.ChaincodeMessage, error)
Handles query to ledger for query state next
func (*Handler) HandleRegister ¶
func (h *Handler) HandleRegister(msg *pb.ChaincodeMessage)
handleRegister is invoked when chaincode tries to register.
func (*Handler) HandleTransaction ¶
func (h *Handler) HandleTransaction(msg *pb.ChaincodeMessage, delegate handleFunc)
HandleTransaction is a middleware function that obtains and verifies a transaction context prior to forwarding the message to the provided delegate. Response messages returned by the delegate are sent to the chat stream. Any errors returned by the delegate are packaged as chaincode error messages.
func (*Handler) Notify ¶
func (h *Handler) Notify(msg *pb.ChaincodeMessage)
func (*Handler) ProcessStream ¶
func (h *Handler) ProcessStream(stream ccintf.ChaincodeStream) error
type HandlerMetrics ¶
type HandlerMetrics struct { ShimRequestsReceived metrics.Counter ShimRequestsCompleted metrics.Counter ShimRequestDuration metrics.Histogram ExecuteTimeouts metrics.Counter }
func NewHandlerMetrics ¶
func NewHandlerMetrics(p metrics.Provider) *HandlerMetrics
type HandlerRegistry ¶
type HandlerRegistry struct {
// contains filtered or unexported fields
}
HandlerRegistry maintains chaincode Handler instances.
func NewHandlerRegistry ¶
func NewHandlerRegistry(allowUnsolicitedRegistration bool) *HandlerRegistry
NewHandlerRegistry constructs a HandlerRegistry.
func (*HandlerRegistry) Deregister ¶
func (r *HandlerRegistry) Deregister(ccid string) error
Deregister clears references to state associated specified chaincode. As part of the cleanup, it closes the handler so it can cleanup any state. If the registry does not contain the provided handler, an error is returned.
func (*HandlerRegistry) Failed ¶
func (r *HandlerRegistry) Failed(ccid string, err error)
Failed indicates that registration of a launched chaincode has failed.
func (*HandlerRegistry) Handler ¶
func (r *HandlerRegistry) Handler(ccid string) *Handler
Handler retrieves the handler for a chaincode instance.
func (*HandlerRegistry) Launching ¶
func (r *HandlerRegistry) Launching(ccid string) (*LaunchState, bool)
Launching indicates that chaincode is being launched. The LaunchState that is returned provides mechanisms to determine when the operation has completed and whether or not it failed. The bool indicates whether or not the chaincode has already been started.
func (*HandlerRegistry) Ready ¶
func (r *HandlerRegistry) Ready(ccid string)
Ready indicates that the chaincode registration has completed and the READY response has been sent to the chaincode.
func (*HandlerRegistry) Register ¶
func (r *HandlerRegistry) Register(h *Handler) error
Register adds a chaincode handler to the registry. An error will be returned if a handler is already registered for the chaincode. An error will also be returned if the chaincode has not already been "launched", and unsolicited registration is not allowed.
type Invoker ¶
type Invoker interface {
Invoke(txParams *ccprovider.TransactionParams, chaincodeName string, spec *pb.ChaincodeInput) (*pb.ChaincodeMessage, error)
}
An Invoker invokes chaincode.
type LaunchMetrics ¶
type LaunchMetrics struct { LaunchDuration metrics.Histogram LaunchFailures metrics.Counter LaunchTimeouts metrics.Counter }
func NewLaunchMetrics ¶
func NewLaunchMetrics(p metrics.Provider) *LaunchMetrics
type LaunchRegistry ¶
type LaunchRegistry interface { Launching(ccid string) (launchState *LaunchState, started bool) Deregister(ccid string) error }
LaunchRegistry tracks launching chaincode instances.
type LaunchState ¶
type LaunchState struct {
// contains filtered or unexported fields
}
func NewLaunchState ¶
func NewLaunchState() *LaunchState
func (*LaunchState) Done ¶
func (l *LaunchState) Done() <-chan struct{}
func (*LaunchState) Err ¶
func (l *LaunchState) Err() error
func (*LaunchState) Notify ¶
func (l *LaunchState) Notify(err error)
type Launcher ¶
type Launcher interface {
Launch(ccid string, streamHandler extcc.StreamHandler) error
}
Launcher is used to launch chaincode runtimes.
type LedgerGetter ¶
type LedgerGetter interface {
GetLedger(cid string) ledger.PeerLedger
}
LedgerGetter is used to get ledgers for chaincode.
type Lifecycle ¶
type Lifecycle interface { // ChaincodeEndorsementInfo looks up the chaincode info in the given channel. It is the responsibility // of the implementation to add appropriate read dependencies for the information returned. ChaincodeEndorsementInfo(channelID, chaincodeName string, qe ledger.SimpleQueryExecutor) (*lifecycle.ChaincodeEndorsementInfo, error) }
Lifecycle provides a way to retrieve chaincode definitions and the packages necessary to run them
type MessageHandler ¶
type MessageHandler interface {
Handle(*pb.ChaincodeMessage, *TransactionContext) (*pb.ChaincodeMessage, error)
}
type PendingQueryResult ¶
type PendingQueryResult struct {
// contains filtered or unexported fields
}
func (*PendingQueryResult) Add ¶
func (p *PendingQueryResult) Add(queryResult commonledger.QueryResult) error
func (*PendingQueryResult) Cut ¶
func (p *PendingQueryResult) Cut() []*pb.QueryResultBytes
func (*PendingQueryResult) Size ¶
func (p *PendingQueryResult) Size() int
type QueryResponseBuilder ¶
type QueryResponseBuilder interface { BuildQueryResponse(txContext *TransactionContext, iter commonledger.ResultsIterator, iterID string, isPaginated bool, totalReturnLimit int32) (*pb.QueryResponse, error) }
QueryResponseBuilder is responsible for building QueryResponse messages for query transactions initiated by chaincode.
type QueryResponseGenerator ¶
type QueryResponseGenerator struct {
MaxResultLimit int
}
func (*QueryResponseGenerator) BuildQueryResponse ¶
func (q *QueryResponseGenerator) BuildQueryResponse(txContext *TransactionContext, iter commonledger.ResultsIterator, iterID string, isPaginated bool, totalReturnLimit int32) (*pb.QueryResponse, error)
BuildQueryResponse takes an iterator and fetch state to construct QueryResponse
type Registry ¶
type Registry interface { Register(*Handler) error Ready(string) Failed(string, error) Deregister(string) error }
A Registry is responsible for tracking handlers.
type Runtime ¶
type Runtime interface { Build(ccid string) (*ccintf.ChaincodeServerInfo, error) Start(ccid string, ccinfo *ccintf.PeerConnection) error Stop(ccid string) error Wait(ccid string) (int, error) }
Runtime is used to manage chaincode runtime instances.
type RuntimeLauncher ¶
type RuntimeLauncher struct { Runtime Runtime Registry LaunchRegistry StartupTimeout time.Duration Metrics *LaunchMetrics PeerAddress string CACert []byte CertGenerator CertGenerator ConnectionHandler ConnectionHandler }
RuntimeLauncher is responsible for launching chaincode runtimes.
func (*RuntimeLauncher) ChaincodeClientInfo ¶
func (r *RuntimeLauncher) ChaincodeClientInfo(ccid string) (*ccintf.PeerConnection, error)
func (*RuntimeLauncher) Launch ¶
func (r *RuntimeLauncher) Launch(ccid string, streamHandler extcc.StreamHandler) error
type TransactionContext ¶
type TransactionContext struct { ChannelID string NamespaceID string SignedProp *pb.SignedProposal Proposal *pb.Proposal ResponseNotifier chan *pb.ChaincodeMessage TXSimulator ledger.TxSimulator HistoryQueryExecutor ledger.HistoryQueryExecutor CollectionStore privdata.CollectionStore IsInitTransaction bool // cache used to save the result of collection acl // as a transactionContext is created for every chaincode // invoke (even in case of chaincode-calling-chaincode, // we do not need to store the namespace in the map and // collection alone is sufficient. CollectionACLCache CollectionACLCache // contains filtered or unexported fields }
func (*TransactionContext) CleanupQueryContext ¶
func (t *TransactionContext) CleanupQueryContext(queryID string)
func (*TransactionContext) CleanupQueryContextWithBookmark ¶
func (t *TransactionContext) CleanupQueryContextWithBookmark(queryID string) string
func (*TransactionContext) CloseQueryIterators ¶
func (t *TransactionContext) CloseQueryIterators()
func (*TransactionContext) GetPendingQueryResult ¶
func (t *TransactionContext) GetPendingQueryResult(queryID string) *PendingQueryResult
func (*TransactionContext) GetQueryIterator ¶
func (t *TransactionContext) GetQueryIterator(queryID string) commonledger.ResultsIterator
func (*TransactionContext) GetTotalReturnCount ¶
func (t *TransactionContext) GetTotalReturnCount(queryID string) *int32
func (*TransactionContext) InitializeCollectionACLCache ¶
func (t *TransactionContext) InitializeCollectionACLCache()
func (*TransactionContext) InitializeQueryContext ¶
func (t *TransactionContext) InitializeQueryContext(queryID string, iter commonledger.ResultsIterator)
type TransactionContexts ¶
type TransactionContexts struct {
// contains filtered or unexported fields
}
TransactionContexts maintains active transaction contexts for a Handler.
func NewTransactionContexts ¶
func NewTransactionContexts() *TransactionContexts
NewTransactionContexts creates a registry for active transaction contexts.
func (*TransactionContexts) Close ¶
func (c *TransactionContexts) Close()
Close closes all query iterators assocated with the context.
func (*TransactionContexts) Create ¶
func (c *TransactionContexts) Create(txParams *ccprovider.TransactionParams) (*TransactionContext, error)
Create creates a new TransactionContext for the specified channel and transaction ID. An error is returned when a transaction context has already been created for the specified channel and transaction ID.
func (*TransactionContexts) Delete ¶
func (c *TransactionContexts) Delete(channelID, txID string)
Delete removes the transaction context associated with the specified channel and transaction ID.
func (*TransactionContexts) Get ¶
func (c *TransactionContexts) Get(channelID, txID string) *TransactionContext
Get retrieves the transaction context associated with the channel and transaction ID.
type TransactionRegistry ¶
type TransactionRegistry interface { Add(channelID, txID string) bool Remove(channelID, txID string) }
TransactionRegistry tracks active transactions for each channel.
type TxQueryExecutorGetter ¶
type TxQueryExecutorGetter struct { HandlerRegistry *HandlerRegistry CCID string }
func (*TxQueryExecutorGetter) TxQueryExecutor ¶
func (g *TxQueryExecutorGetter) TxQueryExecutor(chainID, txID string) ledger.SimpleQueryExecutor
type UUIDGenerator ¶
type UUIDGenerator interface {
New() string
}
UUIDGenerator is responsible for creating unique query identifiers.
type UUIDGeneratorFunc ¶
type UUIDGeneratorFunc func() string
func (UUIDGeneratorFunc) New ¶
func (u UUIDGeneratorFunc) New() string
Source Files ¶
Directories ¶
Path | Synopsis |
---|---|
mock
Code generated by counterfeiter.
|
Code generated by counterfeiter. |
Code generated by counterfeiter.
|
Code generated by counterfeiter. |
mock
Code generated by counterfeiter.
|
Code generated by counterfeiter. |
Code generated by counterfeiter.
|
Code generated by counterfeiter. |
mock
Code generated by counterfeiter.
|
Code generated by counterfeiter. |
mock
Code generated by counterfeiter.
|
Code generated by counterfeiter. |