Documentation ¶
Overview ¶
Deprecated.
Legacy types are defined below to aid in the migration of CometBFT consensus parameters from use of the now deprecated x/params modules to a new dedicated x/consensus module.
Application developers should ensure that they implement their upgrade handler correctly such that app.ConsensusParamsKeeper.Set() is called with the values returned by GetConsensusParams().
Example:
baseAppLegacySS := app.ParamsKeeper.Subspace(baseapp.Paramspace).WithKeyTable(paramstypes.ConsensusParamsKeyTable()) app.UpgradeKeeper.SetUpgradeHandler( UpgradeName, func(ctx sdk.Context, plan upgradetypes.Plan, fromVM module.VersionMap) (module.VersionMap, error) { if cp := baseapp.GetConsensusParams(ctx, baseAppLegacySS); cp != nil { app.ConsensusParamsKeeper.Set(ctx, cp) } else { ctx.Logger().Info("warning: consensus parameters are undefined; skipping migration", "upgrade", UpgradeName) } return app.ModuleManager.RunMigrations(ctx, app.Configurator(), fromVM) }, )
Developers can also bypass the use of the legacy Params subspace and set the values to app.ConsensusParamsKeeper.Set() explicitly.
Note, for new chains this is not necessary as CometBFT's consensus parameters will automatically be set for you in InitChain.
Index ¶
- Constants
- Variables
- func DefaultStoreLoader(ms storetypes.CommitMultiStore) error
- func GetConsensusParams(ctx sdk.Context, paramStore LegacyParamStore) *cmtproto.ConsensusParams
- func MigrateParams(ctx sdk.Context, lps LegacyParamStore, ps ParamStore)
- func NoOpPrepareProposal() sdk.PrepareProposalHandler
- func NoOpProcessProposal() sdk.ProcessProposalHandler
- func SetHaltHeight(blockHeight uint64) func(*BaseApp)
- func SetHaltTime(haltTime uint64) func(*BaseApp)
- func SetIAVLCacheSize(size int) func(*BaseApp)
- func SetIAVLDisableFastNode(disable bool) func(*BaseApp)
- func SetIAVLLazyLoading(lazyLoading bool) func(*BaseApp)
- func SetIndexEvents(ie []string) func(*BaseApp)
- func SetInterBlockCache(cache storetypes.MultiStorePersistentCache) func(*BaseApp)
- func SetMempool(mempool mempool.Mempool) func(*BaseApp)
- func SetMinGasPrices(gasPricesStr string) func(*BaseApp)
- func SetMinRetainBlocks(minRetainBlocks uint64) func(*BaseApp)
- func SetPruning(opts pruningtypes.PruningOptions) func(*BaseApp)
- func SetSnapshot(snapshotStore *snapshots.Store, opts snapshottypes.SnapshotOptions) func(*BaseApp)
- func SetTrace(trace bool) func(*BaseApp)
- func SplitABCIQueryPath(requestPath string) (path []string)
- func ValidateBlockParams(i interface{}) error
- func ValidateEvidenceParams(i interface{}) error
- func ValidateValidatorParams(i interface{}) error
- type BaseApp
- func (app *BaseApp) AddRunTxRecoveryHandler(handlers ...RecoveryHandler)
- func (app *BaseApp) AppVersion() uint64
- func (app *BaseApp) ApplySnapshotChunk(req abci.RequestApplySnapshotChunk) abci.ResponseApplySnapshotChunk
- func (app *BaseApp) BeginBlock(req abci.RequestBeginBlock) (res abci.ResponseBeginBlock)
- func (app *BaseApp) CheckTx(req abci.RequestCheckTx) abci.ResponseCheckTx
- func (app *BaseApp) Commit() abci.ResponseCommit
- func (app *BaseApp) CommitMultiStore() storetypes.CommitMultiStore
- func (app *BaseApp) CreateQueryContext(height int64, prove bool) (sdk.Context, error)
- func (app *BaseApp) DefaultPrepareProposal() sdk.PrepareProposalHandler
- func (app *BaseApp) DefaultProcessProposal() sdk.ProcessProposalHandler
- func (app *BaseApp) DeliverTx(req abci.RequestDeliverTx) (res abci.ResponseDeliverTx)
- func (app *BaseApp) EndBlock(req abci.RequestEndBlock) (res abci.ResponseEndBlock)
- func (app *BaseApp) FilterPeerByAddrPort(info string) abci.ResponseQuery
- func (app *BaseApp) FilterPeerByID(info string) abci.ResponseQuery
- func (app *BaseApp) GRPCQueryRouter() *GRPCQueryRouter
- func (app *BaseApp) GetBlockRetentionHeight(commitHeight int64) int64
- func (app *BaseApp) GetConsensusParams(ctx sdk.Context) *cmtproto.ConsensusParams
- func (app *BaseApp) GetContextForDeliverTx(txBytes []byte) sdk.Context
- func (app *BaseApp) GetMaximumBlockGas(ctx sdk.Context) uint64
- func (app *BaseApp) Info(req abci.RequestInfo) abci.ResponseInfo
- func (app *BaseApp) Init() error
- func (app *BaseApp) InitChain(req abci.RequestInitChain) (res abci.ResponseInitChain)
- func (app *BaseApp) IsSealed() bool
- func (app *BaseApp) LastBlockHeight() int64
- func (app *BaseApp) LastCommitID() storetypes.CommitID
- func (app *BaseApp) ListSnapshots(req abci.RequestListSnapshots) abci.ResponseListSnapshots
- func (app *BaseApp) LoadLatestVersion() error
- func (app *BaseApp) LoadSnapshotChunk(req abci.RequestLoadSnapshotChunk) abci.ResponseLoadSnapshotChunk
- func (app *BaseApp) LoadVersion(version int64) error
- func (app *BaseApp) Logger() log.Logger
- func (app *BaseApp) MountKVStores(keys map[string]*storetypes.KVStoreKey)
- func (app *BaseApp) MountMemoryStores(keys map[string]*storetypes.MemoryStoreKey)
- func (app *BaseApp) MountStore(key storetypes.StoreKey, typ storetypes.StoreType)
- func (app *BaseApp) MountStores(keys ...storetypes.StoreKey)
- func (app *BaseApp) MountTransientStores(keys map[string]*storetypes.TransientStoreKey)
- func (app *BaseApp) MsgServiceRouter() *MsgServiceRouter
- func (app *BaseApp) Name() string
- func (app *BaseApp) NewContext(isCheckTx bool, header cmtproto.Header) sdk.Context
- func (app *BaseApp) NewUncachedContext(isCheckTx bool, header cmtproto.Header) sdk.Context
- func (app *BaseApp) OfferSnapshot(req abci.RequestOfferSnapshot) abci.ResponseOfferSnapshot
- func (app *BaseApp) PrepareProposal(req abci.RequestPrepareProposal) (resp abci.ResponsePrepareProposal)
- func (app *BaseApp) ProcessProposal(req abci.RequestProcessProposal) (resp abci.ResponseProcessProposal)
- func (app *BaseApp) Query(req abci.RequestQuery) (res abci.ResponseQuery)
- func (app *BaseApp) RegisterGRPCServer(server gogogrpc.Server)
- func (app *BaseApp) Seal()
- func (app *BaseApp) SetAddrPeerFilter(pf sdk.PeerFilter)
- func (app *BaseApp) SetAnteHandler(ah sdk.AnteHandler)
- func (app *BaseApp) SetBeginBlocker(beginBlocker sdk.BeginBlocker)
- func (app *BaseApp) SetCMS(cms storetypes.CommitMultiStore)
- func (app *BaseApp) SetCommitMultiStoreTracer(w io.Writer)
- func (app *BaseApp) SetDB(db dbm.DB)
- func (app *BaseApp) SetEndBlocker(endBlocker sdk.EndBlocker)
- func (app *BaseApp) SetFauxMerkleMode()
- func (app *BaseApp) SetIDPeerFilter(pf sdk.PeerFilter)
- func (app *BaseApp) SetInitChainer(initChainer sdk.InitChainer)
- func (app *BaseApp) SetInterfaceRegistry(registry types.InterfaceRegistry)
- func (app *BaseApp) SetMempool(mempool mempool.Mempool)
- func (app *BaseApp) SetMsgServiceRouter(msgServiceRouter *MsgServiceRouter)
- func (app *BaseApp) SetName(name string)
- func (app *BaseApp) SetParamStore(ps ParamStore)
- func (app *BaseApp) SetPostHandler(ph sdk.PostHandler)
- func (app *BaseApp) SetPrepareProposal(handler sdk.PrepareProposalHandler)
- func (app *BaseApp) SetProcessProposal(handler sdk.ProcessProposalHandler)
- func (app *BaseApp) SetProtocolVersion(v uint64)
- func (app *BaseApp) SetQueryMultiStore(ms storetypes.MultiStore)
- func (app *BaseApp) SetSnapshot(snapshotStore *snapshots.Store, opts snapshottypes.SnapshotOptions)
- func (app *BaseApp) SetStoreLoader(loader StoreLoader)
- func (app *BaseApp) SetStoreMetrics(gatherer metrics.StoreMetrics)
- func (app *BaseApp) SetStreamingService(appOpts servertypes.AppOptions, appCodec storetypes.Codec, ...) error
- func (app *BaseApp) SetTxDecoder(txDecoder sdk.TxDecoder)
- func (app *BaseApp) SetTxEncoder(txEncoder sdk.TxEncoder)
- func (app *BaseApp) SetVersion(v string)
- func (app *BaseApp) SimCheck(txEncoder sdk.TxEncoder, tx sdk.Tx) (sdk.GasInfo, *sdk.Result, error)
- func (app *BaseApp) SimDeliver(txEncoder sdk.TxEncoder, tx sdk.Tx) (sdk.GasInfo, *sdk.Result, error)
- func (app *BaseApp) Simulate(txBytes []byte) (sdk.GasInfo, *sdk.Result, error)
- func (app *BaseApp) SnapshotManager() *snapshots.Manager
- func (app *BaseApp) StoreConsensusParams(ctx sdk.Context, cp *cmtproto.ConsensusParams)
- func (app *BaseApp) Trace() bool
- func (app *BaseApp) Version() string
- type GRPCQueryHandler
- type GRPCQueryRouter
- type LegacyParamStore
- type MessageRouter
- type MsgServiceHandler
- type MsgServiceRouter
- func (msr *MsgServiceRouter) Handler(msg sdk.Msg) MsgServiceHandler
- func (msr *MsgServiceRouter) HandlerByTypeURL(typeURL string) MsgServiceHandler
- func (msr *MsgServiceRouter) RegisterService(sd *grpc.ServiceDesc, handler interface{})
- func (msr *MsgServiceRouter) SetInterfaceRegistry(interfaceRegistry codectypes.InterfaceRegistry)
- type ParamStore
- type QueryServiceTestHelper
- type RecoveryHandler
- type StoreLoader
Constants ¶
const ( QueryPathApp = "app" QueryPathCustom = "custom" QueryPathP2P = "p2p" QueryPathStore = "store" )
Supported ABCI Query prefixes
const Paramspace = "baseapp"
Variables ¶
var ( ParamStoreKeyBlockParams = []byte("BlockParams") ParamStoreKeyEvidenceParams = []byte("EvidenceParams") ParamStoreKeyValidatorParams = []byte("ValidatorParams") )
Functions ¶
func DefaultStoreLoader ¶
func DefaultStoreLoader(ms storetypes.CommitMultiStore) error
DefaultStoreLoader will be used by default and loads the latest version
func GetConsensusParams ¶
func GetConsensusParams(ctx sdk.Context, paramStore LegacyParamStore) *cmtproto.ConsensusParams
func MigrateParams ¶
func MigrateParams(ctx sdk.Context, lps LegacyParamStore, ps ParamStore)
func NoOpPrepareProposal ¶
func NoOpPrepareProposal() sdk.PrepareProposalHandler
NoOpPrepareProposal defines a no-op PrepareProposal handler. It will always return the transactions sent by the client's request.
func NoOpProcessProposal ¶
func NoOpProcessProposal() sdk.ProcessProposalHandler
NoOpProcessProposal defines a no-op ProcessProposal Handler. It will always return ACCEPT.
func SetHaltHeight ¶
SetHaltHeight returns a BaseApp option function that sets the halt block height.
func SetHaltTime ¶
SetHaltTime returns a BaseApp option function that sets the halt block time.
func SetIAVLCacheSize ¶
SetIAVLCacheSize provides a BaseApp option function that sets the size of IAVL cache.
func SetIAVLDisableFastNode ¶
SetIAVLDisableFastNode enables(false)/disables(true) fast node usage from the IAVL store.
func SetIAVLLazyLoading ¶
SetIAVLLazyLoading enables/disables lazy loading of the IAVL store.
func SetIndexEvents ¶
SetIndexEvents provides a BaseApp option function that sets the events to index.
func SetInterBlockCache ¶
func SetInterBlockCache(cache storetypes.MultiStorePersistentCache) func(*BaseApp)
SetInterBlockCache provides a BaseApp option function that sets the inter-block cache.
func SetMempool ¶
SetMempool sets the mempool on BaseApp.
func SetMinGasPrices ¶
SetMinGasPrices returns an option that sets the minimum gas prices on the app.
func SetMinRetainBlocks ¶
SetMinRetainBlocks returns a BaseApp option function that sets the minimum block retention height value when determining which heights to prune during ABCI Commit.
func SetPruning ¶
func SetPruning(opts pruningtypes.PruningOptions) func(*BaseApp)
SetPruning sets a pruning option on the multistore associated with the app
func SetSnapshot ¶
func SetSnapshot(snapshotStore *snapshots.Store, opts snapshottypes.SnapshotOptions) func(*BaseApp)
SetSnapshot sets the snapshot store.
func SplitABCIQueryPath ¶
SplitABCIQueryPath splits a string path using the delimiter '/'.
e.g. "this/is/funny" becomes []string{"this", "is", "funny"}
func ValidateBlockParams ¶
func ValidateBlockParams(i interface{}) error
func ValidateEvidenceParams ¶
func ValidateEvidenceParams(i interface{}) error
func ValidateValidatorParams ¶
func ValidateValidatorParams(i interface{}) error
Types ¶
type BaseApp ¶
type BaseApp struct {
// contains filtered or unexported fields
}
BaseApp reflects the ABCI application implementation.
func NewBaseApp ¶
func NewBaseApp( name string, logger log.Logger, db dbm.DB, txDecoder sdk.TxDecoder, options ...func(*BaseApp), ) *BaseApp
NewBaseApp returns a reference to an initialized BaseApp. It accepts a variadic number of option functions, which act on the BaseApp to set configuration choices.
NOTE: The db is used to store the version number for now.
func (*BaseApp) AddRunTxRecoveryHandler ¶
func (app *BaseApp) AddRunTxRecoveryHandler(handlers ...RecoveryHandler)
AddRunTxRecoveryHandler adds custom app.runTx method panic handlers.
func (*BaseApp) AppVersion ¶
AppVersion returns the application's protocol version.
func (*BaseApp) ApplySnapshotChunk ¶
func (app *BaseApp) ApplySnapshotChunk(req abci.RequestApplySnapshotChunk) abci.ResponseApplySnapshotChunk
ApplySnapshotChunk implements the ABCI interface. It delegates to app.snapshotManager if set.
func (*BaseApp) BeginBlock ¶
func (app *BaseApp) BeginBlock(req abci.RequestBeginBlock) (res abci.ResponseBeginBlock)
BeginBlock implements the ABCI application interface.
func (*BaseApp) CheckTx ¶
func (app *BaseApp) CheckTx(req abci.RequestCheckTx) abci.ResponseCheckTx
CheckTx implements the ABCI interface and executes a tx in CheckTx mode. In CheckTx mode, messages are not executed. This means messages are only validated and only the AnteHandler is executed. State is persisted to the BaseApp's internal CheckTx state if the AnteHandler passes. Otherwise, the ResponseCheckTx will contain relevant error information. Regardless of tx execution outcome, the ResponseCheckTx will contain relevant gas execution context.
func (*BaseApp) Commit ¶
func (app *BaseApp) Commit() abci.ResponseCommit
Commit implements the ABCI interface. It will commit all state that exists in the deliver state's multi-store and includes the resulting commit ID in the returned abci.ResponseCommit. Commit will set the check state based on the latest header and reset the deliver state. Also, if a non-zero halt height is defined in config, Commit will execute a deferred function call to check against that height and gracefully halt if it matches the latest committed height.
func (*BaseApp) CommitMultiStore ¶
func (app *BaseApp) CommitMultiStore() storetypes.CommitMultiStore
CommitMultiStore returns the root multi-store. App constructor can use this to access the `cms`. UNSAFE: must not be used during the abci life cycle.
func (*BaseApp) CreateQueryContext ¶
createQueryContext creates a new sdk.Context for a query, taking as args the block height and whether the query needs a proof or not.
func (*BaseApp) DefaultPrepareProposal ¶
func (app *BaseApp) DefaultPrepareProposal() sdk.PrepareProposalHandler
DefaultPrepareProposal returns the default implementation for processing an ABCI proposal. The application's mempool is enumerated and all valid transactions are added to the proposal. Transactions are valid if they:
1) Successfully encode to bytes. 2) Are valid (i.e. pass runTx, AnteHandler only).
Enumeration is halted once RequestPrepareProposal.MaxBytes of transactions is reached or the mempool is exhausted.
Note:
- Step (2) is identical to the validation step performed in DefaultProcessProposal. It is very important that the same validation logic is used in both steps, and applications must ensure that this is the case in non-default handlers.
- If no mempool is set or if the mempool is a no-op mempool, the transactions requested from CometBFT will simply be returned, which, by default, are in FIFO order.
func (*BaseApp) DefaultProcessProposal ¶
func (app *BaseApp) DefaultProcessProposal() sdk.ProcessProposalHandler
DefaultProcessProposal returns the default implementation for processing an ABCI proposal. Every transaction in the proposal must pass 2 conditions:
1. The transaction bytes must decode to a valid transaction. 2. The transaction must be valid (i.e. pass runTx, AnteHandler only)
If any transaction fails to pass either condition, the proposal is rejected. Note that step (2) is identical to the validation step performed in DefaultPrepareProposal. It is very important that the same validation logic is used in both steps, and applications must ensure that this is the case in non-default handlers.
func (*BaseApp) DeliverTx ¶
func (app *BaseApp) DeliverTx(req abci.RequestDeliverTx) (res abci.ResponseDeliverTx)
DeliverTx implements the ABCI interface and executes a tx in DeliverTx mode. State only gets persisted if all messages are valid and get executed successfully. Otherwise, the ResponseDeliverTx will contain relevant error information. Regardless of tx execution outcome, the ResponseDeliverTx will contain relevant gas execution context.
func (*BaseApp) EndBlock ¶
func (app *BaseApp) EndBlock(req abci.RequestEndBlock) (res abci.ResponseEndBlock)
EndBlock implements the ABCI interface.
func (*BaseApp) FilterPeerByAddrPort ¶
func (app *BaseApp) FilterPeerByAddrPort(info string) abci.ResponseQuery
FilterPeerByAddrPort filters peers by address/port.
func (*BaseApp) FilterPeerByID ¶
func (app *BaseApp) FilterPeerByID(info string) abci.ResponseQuery
FilterPeerByID filters peers by node ID.
func (*BaseApp) GRPCQueryRouter ¶
func (app *BaseApp) GRPCQueryRouter() *GRPCQueryRouter
GRPCQueryRouter returns the GRPCQueryRouter of a BaseApp.
func (*BaseApp) GetBlockRetentionHeight ¶
GetBlockRetentionHeight returns the height for which all blocks below this height are pruned from CometBFT. Given a commitment height and a non-zero local minRetainBlocks configuration, the retentionHeight is the smallest height that satisfies:
- Unbonding (safety threshold) time: The block interval in which validators can be economically punished for misbehavior. Blocks in this interval must be auditable e.g. by the light client.
- Logical store snapshot interval: The block interval at which the underlying logical store database is persisted to disk, e.g. every 10000 heights. Blocks since the last IAVL snapshot must be available for replay on application restart.
- State sync snapshots: Blocks since the oldest available snapshot must be available for state sync nodes to catch up (oldest because a node may be restoring an old snapshot while a new snapshot was taken).
- Local (minRetainBlocks) config: Archive nodes may want to retain more or all blocks, e.g. via a local config option min-retain-blocks. There may also be a need to vary retention for other nodes, e.g. sentry nodes which do not need historical blocks.
func (*BaseApp) GetConsensusParams ¶
func (app *BaseApp) GetConsensusParams(ctx sdk.Context) *cmtproto.ConsensusParams
GetConsensusParams returns the current consensus parameters from the BaseApp's ParamStore. If the BaseApp has no ParamStore defined, nil is returned.
func (*BaseApp) GetContextForDeliverTx ¶
func (*BaseApp) GetMaximumBlockGas ¶
GetMaximumBlockGas gets the maximum gas from the consensus params. It panics if maximum block gas is less than negative one and returns zero if negative one.
func (*BaseApp) Info ¶
func (app *BaseApp) Info(req abci.RequestInfo) abci.ResponseInfo
Info implements the ABCI interface.
func (*BaseApp) Init ¶
Init initializes the app. It seals the app, preventing any further modifications. In addition, it validates the app against the earlier provided settings. Returns an error if validation fails. nil otherwise. Panics if the app is already sealed.
func (*BaseApp) InitChain ¶
func (app *BaseApp) InitChain(req abci.RequestInitChain) (res abci.ResponseInitChain)
InitChain implements the ABCI interface. It runs the initialization logic directly on the CommitMultiStore.
func (*BaseApp) LastBlockHeight ¶
LastBlockHeight returns the last committed block height.
func (*BaseApp) LastCommitID ¶
func (app *BaseApp) LastCommitID() storetypes.CommitID
LastCommitID returns the last CommitID of the multistore.
func (*BaseApp) ListSnapshots ¶
func (app *BaseApp) ListSnapshots(req abci.RequestListSnapshots) abci.ResponseListSnapshots
ListSnapshots implements the ABCI interface. It delegates to app.snapshotManager if set.
func (*BaseApp) LoadLatestVersion ¶
LoadLatestVersion loads the latest application version. It will panic if called more than once on a running BaseApp.
func (*BaseApp) LoadSnapshotChunk ¶
func (app *BaseApp) LoadSnapshotChunk(req abci.RequestLoadSnapshotChunk) abci.ResponseLoadSnapshotChunk
LoadSnapshotChunk implements the ABCI interface. It delegates to app.snapshotManager if set.
func (*BaseApp) LoadVersion ¶
LoadVersion loads the BaseApp application version. It will panic if called more than once on a running baseapp.
func (*BaseApp) MountKVStores ¶
func (app *BaseApp) MountKVStores(keys map[string]*storetypes.KVStoreKey)
MountKVStores mounts all IAVL or DB stores to the provided keys in the BaseApp multistore.
func (*BaseApp) MountMemoryStores ¶
func (app *BaseApp) MountMemoryStores(keys map[string]*storetypes.MemoryStoreKey)
MountMemoryStores mounts all in-memory KVStores with the BaseApp's internal commit multi-store.
func (*BaseApp) MountStore ¶
func (app *BaseApp) MountStore(key storetypes.StoreKey, typ storetypes.StoreType)
MountStore mounts a store to the provided key in the BaseApp multistore, using the default DB.
func (*BaseApp) MountStores ¶
func (app *BaseApp) MountStores(keys ...storetypes.StoreKey)
MountStores mounts all IAVL or DB stores to the provided keys in the BaseApp multistore.
func (*BaseApp) MountTransientStores ¶
func (app *BaseApp) MountTransientStores(keys map[string]*storetypes.TransientStoreKey)
MountTransientStores mounts all transient stores to the provided keys in the BaseApp multistore.
func (*BaseApp) MsgServiceRouter ¶
func (app *BaseApp) MsgServiceRouter() *MsgServiceRouter
MsgServiceRouter returns the MsgServiceRouter of a BaseApp.
func (*BaseApp) NewContext ¶
Context with current {check, deliver}State of the app used by tests.
func (*BaseApp) NewUncachedContext ¶
func (*BaseApp) OfferSnapshot ¶
func (app *BaseApp) OfferSnapshot(req abci.RequestOfferSnapshot) abci.ResponseOfferSnapshot
OfferSnapshot implements the ABCI interface. It delegates to app.snapshotManager if set.
func (*BaseApp) PrepareProposal ¶
func (app *BaseApp) PrepareProposal(req abci.RequestPrepareProposal) (resp abci.ResponsePrepareProposal)
PrepareProposal implements the PrepareProposal ABCI method and returns a ResponsePrepareProposal object to the client. The PrepareProposal method is responsible for allowing the block proposer to perform application-dependent work in a block before proposing it.
Transactions can be modified, removed, or added by the application. Since the application maintains its own local mempool, it will ignore the transactions provided to it in RequestPrepareProposal. Instead, it will determine which transactions to return based on the mempool's semantics and the MaxTxBytes provided by the client's request.
Ref: https://github.com/verzth/cosmos-sdk/blob/main/docs/architecture/adr-060-abci-1.0.md Ref: https://github.com/cometbft/cometbft/blob/main/spec/abci/abci%2B%2B_basic_concepts.md
func (*BaseApp) ProcessProposal ¶
func (app *BaseApp) ProcessProposal(req abci.RequestProcessProposal) (resp abci.ResponseProcessProposal)
ProcessProposal implements the ProcessProposal ABCI method and returns a ResponseProcessProposal object to the client. The ProcessProposal method is responsible for allowing execution of application-dependent work in a proposed block. Note, the application defines the exact implementation details of ProcessProposal. In general, the application must at the very least ensure that all transactions are valid. If all transactions are valid, then we inform CometBFT that the Status is ACCEPT. However, the application is also able to implement optimizations such as executing the entire proposed block immediately.
If a panic is detected during execution of an application's ProcessProposal handler, it will be recovered and we will reject the proposal.
Ref: https://github.com/verzth/cosmos-sdk/blob/main/docs/architecture/adr-060-abci-1.0.md Ref: https://github.com/cometbft/cometbft/blob/main/spec/abci/abci%2B%2B_basic_concepts.md
func (*BaseApp) Query ¶
func (app *BaseApp) Query(req abci.RequestQuery) (res abci.ResponseQuery)
Query implements the ABCI interface. It delegates to CommitMultiStore if it implements Queryable.
func (*BaseApp) RegisterGRPCServer ¶
RegisterGRPCServer registers gRPC services directly with the gRPC server.
func (*BaseApp) Seal ¶
func (app *BaseApp) Seal()
Seal seals a BaseApp. It prohibits any further modifications to a BaseApp.
func (*BaseApp) SetAddrPeerFilter ¶
func (app *BaseApp) SetAddrPeerFilter(pf sdk.PeerFilter)
func (*BaseApp) SetAnteHandler ¶
func (app *BaseApp) SetAnteHandler(ah sdk.AnteHandler)
func (*BaseApp) SetBeginBlocker ¶
func (app *BaseApp) SetBeginBlocker(beginBlocker sdk.BeginBlocker)
func (*BaseApp) SetCMS ¶
func (app *BaseApp) SetCMS(cms storetypes.CommitMultiStore)
func (*BaseApp) SetCommitMultiStoreTracer ¶
SetCommitMultiStoreTracer sets the store tracer on the BaseApp's underlying CommitMultiStore.
func (*BaseApp) SetEndBlocker ¶
func (app *BaseApp) SetEndBlocker(endBlocker sdk.EndBlocker)
func (*BaseApp) SetFauxMerkleMode ¶
func (app *BaseApp) SetFauxMerkleMode()
func (*BaseApp) SetIDPeerFilter ¶
func (app *BaseApp) SetIDPeerFilter(pf sdk.PeerFilter)
func (*BaseApp) SetInitChainer ¶
func (app *BaseApp) SetInitChainer(initChainer sdk.InitChainer)
func (*BaseApp) SetInterfaceRegistry ¶
func (app *BaseApp) SetInterfaceRegistry(registry types.InterfaceRegistry)
SetInterfaceRegistry sets the InterfaceRegistry.
func (*BaseApp) SetMempool ¶
SetMempool sets the mempool for the BaseApp and is required for the app to start up.
func (*BaseApp) SetMsgServiceRouter ¶
func (app *BaseApp) SetMsgServiceRouter(msgServiceRouter *MsgServiceRouter)
SetMsgServiceRouter sets the MsgServiceRouter of a BaseApp.
func (*BaseApp) SetParamStore ¶
func (app *BaseApp) SetParamStore(ps ParamStore)
SetParamStore sets a parameter store on the BaseApp.
func (*BaseApp) SetPostHandler ¶
func (app *BaseApp) SetPostHandler(ph sdk.PostHandler)
func (*BaseApp) SetPrepareProposal ¶
func (app *BaseApp) SetPrepareProposal(handler sdk.PrepareProposalHandler)
SetPrepareProposal sets the prepare proposal function for the BaseApp.
func (*BaseApp) SetProcessProposal ¶
func (app *BaseApp) SetProcessProposal(handler sdk.ProcessProposalHandler)
SetProcessProposal sets the process proposal function for the BaseApp.
func (*BaseApp) SetProtocolVersion ¶
SetProtocolVersion sets the application's protocol version
func (*BaseApp) SetQueryMultiStore ¶
func (app *BaseApp) SetQueryMultiStore(ms storetypes.MultiStore)
SetQueryMultiStore set a alternative MultiStore implementation to support grpc query service.
func (*BaseApp) SetSnapshot ¶
func (app *BaseApp) SetSnapshot(snapshotStore *snapshots.Store, opts snapshottypes.SnapshotOptions)
SetSnapshot sets the snapshot store and options.
func (*BaseApp) SetStoreLoader ¶
func (app *BaseApp) SetStoreLoader(loader StoreLoader)
SetStoreLoader allows us to customize the rootMultiStore initialization.
func (*BaseApp) SetStoreMetrics ¶
func (app *BaseApp) SetStoreMetrics(gatherer metrics.StoreMetrics)
SetStoreMetrics sets the prepare proposal function for the BaseApp.
func (*BaseApp) SetStreamingService ¶
func (app *BaseApp) SetStreamingService( appOpts servertypes.AppOptions, appCodec storetypes.Codec, keys map[string]*storetypes.KVStoreKey, ) error
SetStreamingService is used to set a streaming service into the BaseApp hooks and load the listeners into the multistore
func (*BaseApp) SetTxDecoder ¶
SetTxDecoder sets the TxDecoder if it wasn't provided in the BaseApp constructor.
func (*BaseApp) SetTxEncoder ¶
SetTxEncoder sets the TxEncoder if it wasn't provided in the BaseApp constructor.
func (*BaseApp) SetVersion ¶
SetVersion sets the application's version string.
func (*BaseApp) SimCheck ¶
SimCheck defines a CheckTx helper function that used in tests and simulations.
func (*BaseApp) SimDeliver ¶
func (*BaseApp) SnapshotManager ¶
SnapshotManager returns the snapshot manager. application use this to register extra extension snapshotters.
func (*BaseApp) StoreConsensusParams ¶
func (app *BaseApp) StoreConsensusParams(ctx sdk.Context, cp *cmtproto.ConsensusParams)
StoreConsensusParams sets the consensus parameters to the baseapp's param store.
type GRPCQueryHandler ¶
type GRPCQueryHandler = func(ctx sdk.Context, req abci.RequestQuery) (abci.ResponseQuery, error)
GRPCQueryHandler defines a function type which handles ABCI Query requests using gRPC
type GRPCQueryRouter ¶
type GRPCQueryRouter struct {
// contains filtered or unexported fields
}
GRPCQueryRouter routes ABCI Query requests to GRPC handlers
func NewGRPCQueryRouter ¶
func NewGRPCQueryRouter() *GRPCQueryRouter
NewGRPCQueryRouter creates a new GRPCQueryRouter
func (*GRPCQueryRouter) RegisterService ¶
func (qrt *GRPCQueryRouter) RegisterService(sd *grpc.ServiceDesc, handler interface{})
RegisterService implements the gRPC Server.RegisterService method. sd is a gRPC service description, handler is an object which implements that gRPC service/
This functions PANICS: - if a protobuf service is registered twice.
func (*GRPCQueryRouter) Route ¶
func (qrt *GRPCQueryRouter) Route(path string) GRPCQueryHandler
Route returns the GRPCQueryHandler for a given query route path or nil if not found
func (*GRPCQueryRouter) SetInterfaceRegistry ¶
func (qrt *GRPCQueryRouter) SetInterfaceRegistry(interfaceRegistry codectypes.InterfaceRegistry)
SetInterfaceRegistry sets the interface registry for the router. This will also register the interface reflection gRPC service.
type LegacyParamStore ¶
type MessageRouter ¶
type MessageRouter interface { Handler(msg sdk.Msg) MsgServiceHandler HandlerByTypeURL(typeURL string) MsgServiceHandler }
MessageRouter ADR 031 request type routing https://github.com/verzth/cosmos-sdk/blob/main/docs/architecture/adr-031-msg-service.md
type MsgServiceHandler ¶
MsgServiceHandler defines a function type which handles Msg service message.
type MsgServiceRouter ¶
type MsgServiceRouter struct {
// contains filtered or unexported fields
}
MsgServiceRouter routes fully-qualified Msg service methods to their handler.
func NewMsgServiceRouter ¶
func NewMsgServiceRouter() *MsgServiceRouter
NewMsgServiceRouter creates a new MsgServiceRouter.
func (*MsgServiceRouter) Handler ¶
func (msr *MsgServiceRouter) Handler(msg sdk.Msg) MsgServiceHandler
Handler returns the MsgServiceHandler for a given msg or nil if not found.
func (*MsgServiceRouter) HandlerByTypeURL ¶
func (msr *MsgServiceRouter) HandlerByTypeURL(typeURL string) MsgServiceHandler
HandlerByTypeURL returns the MsgServiceHandler for a given query route path or nil if not found.
func (*MsgServiceRouter) RegisterService ¶
func (msr *MsgServiceRouter) RegisterService(sd *grpc.ServiceDesc, handler interface{})
RegisterService implements the gRPC Server.RegisterService method. sd is a gRPC service description, handler is an object which implements that gRPC service.
This function PANICs:
- if it is called before the service `Msg`s have been registered using RegisterInterfaces,
- or if a service is being registered twice.
func (*MsgServiceRouter) SetInterfaceRegistry ¶
func (msr *MsgServiceRouter) SetInterfaceRegistry(interfaceRegistry codectypes.InterfaceRegistry)
SetInterfaceRegistry sets the interface registry for the router.
type ParamStore ¶
type ParamStore interface { Get(ctx sdk.Context) (*cmtproto.ConsensusParams, error) Has(ctx sdk.Context) bool Set(ctx sdk.Context, cp *cmtproto.ConsensusParams) }
ParamStore defines the interface the parameter store used by the BaseApp must fulfill.
type QueryServiceTestHelper ¶
type QueryServiceTestHelper struct { *GRPCQueryRouter Ctx sdk.Context }
QueryServiceTestHelper provides a helper for making grpc query service rpc calls in unit tests. It implements both the grpc Server and ClientConn interfaces needed to register a query service server and create a query service client.
func NewQueryServerTestHelper ¶
func NewQueryServerTestHelper(ctx sdk.Context, interfaceRegistry types.InterfaceRegistry) *QueryServiceTestHelper
NewQueryServerTestHelper creates a new QueryServiceTestHelper that wraps the provided sdk.Context
func (*QueryServiceTestHelper) Invoke ¶
func (q *QueryServiceTestHelper) Invoke(_ gocontext.Context, method string, args, reply interface{}, _ ...grpc.CallOption) error
Invoke implements the grpc ClientConn.Invoke method
func (*QueryServiceTestHelper) NewStream ¶
func (q *QueryServiceTestHelper) NewStream(gocontext.Context, *grpc.StreamDesc, string, ...grpc.CallOption) (grpc.ClientStream, error)
NewStream implements the grpc ClientConn.NewStream method
type RecoveryHandler ¶
type RecoveryHandler func(recoveryObj interface{}) error
RecoveryHandler handles recovery() object. Return a non-nil error if recoveryObj was processed. Return nil if recoveryObj was not processed.
type StoreLoader ¶
type StoreLoader func(ms storetypes.CommitMultiStore) error
StoreLoader defines a customizable function to control how we load the CommitMultiStore from disk. This is useful for state migration, when loading a datastore written with an older version of the software. In particular, if a module changed the substore key name (or removed a substore) between two versions of the software.