types

package
v1.1.0 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: May 26, 2020 License: Apache-2.0 Imports: 25 Imported by: 0

Documentation

Index

Constants

View Source
const (
	EventTypeCreateContext           = "create_context"
	EventTypePauseContext            = "pause_context"
	EventTypeCompleteContext         = "complete_context"
	EventTypeNewBatch                = "new_batch"
	EventTypeNewBatchRequest         = "new_batch_request"
	EventTypeNewBatchRequestProvider = "new_batch_request_provider"
	EventTypeCompleteBatch           = "complete_batch"
	EventTypeServiceSlash            = "service_slash"

	AttributeValueCategory          = ModuleName
	AttributeKeyAuthor              = "author"
	AttributeKeyServiceName         = "service_name"
	AttributeKeyProvider            = "provider"
	AttributeKeyConsumer            = "consumer"
	AttributeKeyRequestContextID    = "request_context_id"
	AttributeKeyRequestContextState = "request_context_state"
	AttributeKeyRequests            = "requests"
	AttributeKeyRequestID           = "request_id"
	AttributeKeyServiceFee          = "service_fee"
	AttributeKeyRequestHeight       = "request_height"
	AttributeKeyExpirationHeight    = "expiration_height"
	AttributeKeySlashedCoins        = "slashed_coins"
)

service module event types

View Source
const (
	RequestIDLen = 58
	ContextIDLen = 40
)
View Source
const (
	// ModuleName is the name of the service module
	ModuleName = "service"

	// StoreKey is the string store representation
	StoreKey string = ModuleName

	// QuerierRoute is the querier route for the service module
	QuerierRoute string = ModuleName

	// RouterKey is the msg router key for the service module
	RouterKey string = ModuleName

	// DefaultParamspace is the default name for parameter store
	DefaultParamspace = ModuleName

	// DepositAccName is the root string for the service deposit account address
	DepositAccName = "service_deposit_account"

	// RequestAccName is the root string for the service request account address
	RequestAccName = "service_request_account"

	// TxHash is the context key for tx hash
	TxHash = "tx_hash"

	// MsgIndex is the context key for msg index
	MsgIndex = "msg_index"
)
View Source
const (
	TypeMsgDefineService         = "define_service"          // type for MsgDefineService
	TypeMsgBindService           = "bind_service"            // type for MsgBindService
	TypeMsgUpdateServiceBinding  = "update_service_binding"  // type for MsgUpdateServiceBinding
	TypeMsgSetWithdrawAddress    = "set_withdraw_address"    // type for MsgSetWithdrawAddress
	TypeMsgDisableServiceBinding = "disable_service_binding" // type for MsgDisableServiceBinding
	TypeMsgEnableServiceBinding  = "enable_service_binding"  // type for MsgEnableServiceBinding
	TypeMsgRefundServiceDeposit  = "refund_service_deposit"  // type for MsgRefundServiceDeposit
	TypeMsgCallService           = "call_service"            // type for MsgCallService
	TypeMsgRespondService        = "respond_service"         // type for MsgRespondService
	TypeMsgPauseRequestContext   = "pause_request_context"   // type for MsgPauseRequestContext
	TypeMsgStartRequestContext   = "start_request_context"   // type for MsgStartRequestContext
	TypeMsgKillRequestContext    = "kill_request_context"    // type for MsgKillRequestContext
	TypeMsgUpdateRequestContext  = "update_request_context"  // type for MsgUpdateRequestContext
	TypeMsgWithdrawEarnedFees    = "withdraw_earned_fees"    // type for MsgWithdrawEarnedFees

	MaxNameLength        = 70  // maximum length of the service name
	MaxDescriptionLength = 280 // maximum length of the service and author description
	MaxTagsNum           = 10  // maximum total number of the tags
	MaxTagLength         = 70  // maximum length of the tag

	MaxProvidersNum = 10 // maximum total number of the providers to request
)

Message types for the service module

View Source
const (
	QueryDefinition       = "definition"       // query definition
	QueryBinding          = "binding"          // query binding
	QueryBindings         = "bindings"         // query bindings
	QueryWithdrawAddress  = "withdraw_address" // query withdrawal address
	QueryRequest          = "request"          // query request
	QueryRequests         = "requests"         // query requests
	QueryResponse         = "response"         // query response
	QueryRequestContext   = "context"          // query request context
	QueryRequestsByReqCtx = "requests_by_ctx"  // query requests by the request context
	QueryResponses        = "responses"        // query responses
	QueryEarnedFees       = "fees"             // query earned fees
	QuerySchema           = "schema"           // query schema
	QueryParameters       = "parameters"       // query parameters
)
View Source
const (
	// PricingSchema is the Pricing JSON Schema
	PricingSchema = `` /* 1872-byte string literal not displayed */

	// ResultSchema is the JSON Schema for the response result
	ResultSchema = `` /* 414-byte string literal not displayed */

)

Variables

View Source
var (
	ErrInvalidServiceName       = sdkerrors.Register(ModuleName, 2, "invalid service name, must contain alphanumeric characters, _ and - only,length greater than 0 and less than or equal to 70")
	ErrInvalidDescription       = sdkerrors.Register(ModuleName, 3, "invalid description")
	ErrInvalidTags              = sdkerrors.Register(ModuleName, 4, "invalid tags")
	ErrInvalidSchemas           = sdkerrors.Register(ModuleName, 5, "invalid schemas")
	ErrUnknownServiceDefinition = sdkerrors.Register(ModuleName, 6, "unknown service definition")
	ErrServiceDefinitionExists  = sdkerrors.Register(ModuleName, 7, "service definition already exists")

	ErrInvalidDeposit            = sdkerrors.Register(ModuleName, 8, "invalid deposit")
	ErrInvalidPricing            = sdkerrors.Register(ModuleName, 9, "invalid pricing")
	ErrInvalidQoS                = sdkerrors.Register(ModuleName, 10, "invalid qos")
	ErrServiceBindingExists      = sdkerrors.Register(ModuleName, 11, "service binding already exists")
	ErrUnknownServiceBinding     = sdkerrors.Register(ModuleName, 12, "unknown service binding")
	ErrServiceBindingUnavailable = sdkerrors.Register(ModuleName, 13, "service binding unavailable")
	ErrServiceBindingAvailable   = sdkerrors.Register(ModuleName, 14, "service binding available")
	ErrIncorrectRefundTime       = sdkerrors.Register(ModuleName, 15, "incorrect refund time")

	ErrInvalidServiceFee         = sdkerrors.Register(ModuleName, 16, "invalid service fee")
	ErrInvalidProviders          = sdkerrors.Register(ModuleName, 17, "invalid providers")
	ErrInvalidTimeout            = sdkerrors.Register(ModuleName, 18, "invalid timeout")
	ErrInvalidRepeatedFreq       = sdkerrors.Register(ModuleName, 19, "invalid repeated frequency")
	ErrInvalidRepeatedTotal      = sdkerrors.Register(ModuleName, 20, "invalid repeated total count")
	ErrInvalidResponseThreshold  = sdkerrors.Register(ModuleName, 21, "invalid response threshold")
	ErrInvalidResponse           = sdkerrors.Register(ModuleName, 22, "invalid response")
	ErrInvalidRequestID          = sdkerrors.Register(ModuleName, 23, "invalid request ID")
	ErrUnknownRequest            = sdkerrors.Register(ModuleName, 24, "unknown request")
	ErrUnknownResponse           = sdkerrors.Register(ModuleName, 25, "unknown response")
	ErrUnknownRequestContext     = sdkerrors.Register(ModuleName, 26, "unknown request context")
	ErrInvalidRequestContextID   = sdkerrors.Register(ModuleName, 27, "invalid request context ID")
	ErrRequestContextNonRepeated = sdkerrors.Register(ModuleName, 28, "request context non repeated")
	ErrRequestContextNotRunning  = sdkerrors.Register(ModuleName, 29, "request context not running")
	ErrRequestContextNotPaused   = sdkerrors.Register(ModuleName, 30, "request context not paused")
	ErrRequestContextCompleted   = sdkerrors.Register(ModuleName, 31, "request context completed")
	ErrCallbackRegistered        = sdkerrors.Register(ModuleName, 32, "callback registered")
	ErrCallbackNotRegistered     = sdkerrors.Register(ModuleName, 33, "callback not registered")
	ErrNoEarnedFees              = sdkerrors.Register(ModuleName, 34, "no earned fees")

	ErrInvalidRequestInput   = sdkerrors.Register(ModuleName, 35, "invalid request input")
	ErrInvalidResponseOutput = sdkerrors.Register(ModuleName, 36, "invalid response output")
	ErrInvalidResponseResult = sdkerrors.Register(ModuleName, 37, "invalid response result")

	ErrInvalidSchemaName = sdkerrors.Register(ModuleName, 38, "invalid service schema name")
	ErrNotAuthorized     = sdkerrors.Register(ModuleName, 39, "not authorized")
)

service module sentinel errors

View Source
var (
	RequestContextStateToStringMap = map[RequestContextState]string{
		RUNNING:   "running",
		PAUSED:    "paused",
		COMPLETED: "completed",
	}
	StringToRequestContextStateMap = map[string]RequestContextState{
		"running":   RUNNING,
		"paused":    PAUSED,
		"completed": COMPLETED,
	}
)
View Source
var (
	RequestContextBatchStateToStringMap = map[RequestContextBatchState]string{
		BATCHRUNNING:   "running",
		BATCHCOMPLETED: "completed",
	}
	StringToRequestContextBatchStateMap = map[string]RequestContextBatchState{
		"running":   BATCHRUNNING,
		"completed": BATCHCOMPLETED,
	}
)
View Source
var (
	// Separator for string key
	EmptyByte = []byte{0x00}

	// Keys for store prefixes
	ServiceDefinitionKey         = []byte{0x01} // prefix for service definition
	ServiceBindingKey            = []byte{0x02} // prefix for service binding
	OwnerServiceBindingKey       = []byte{0x03} // prefix for owner service binding
	OwnerKey                     = []byte{0x04} // prefix for the owner of a provider
	OwnerProviderKey             = []byte{0x05} // prefix for the provider with an owner
	PricingKey                   = []byte{0x06} // prefix for pricing
	WithdrawAddrKey              = []byte{0x07} // prefix for withdrawal address
	RequestContextKey            = []byte{0x08} // prefix for request context
	ExpiredRequestBatchKey       = []byte{0x09} // prefix for expired request batch
	NewRequestBatchKey           = []byte{0x10} // prefix for new request batch
	ExpiredRequestBatchHeightKey = []byte{0x11} // prefix for expired request batch height
	NewRequestBatchHeightKey     = []byte{0x12} // prefix for new request batch height
	RequestKey                   = []byte{0x13} // prefix for request
	ActiveRequestKey             = []byte{0x14} // prefix for active request
	ActiveRequestByIDKey         = []byte{0x15} // prefix for active requests by ID
	ResponseKey                  = []byte{0x16} // prefix for response
	RequestVolumeKey             = []byte{0x17} // prefix for request volume
	EarnedFeesKey                = []byte{0x18} // prefix for provider earned fees
	OwnerEarnedFeesKey           = []byte{0x19} // prefix for owner earned fees
)
View Source
var (
	DefaultMaxRequestTimeout    = int64(100)
	DefaultMinDepositMultiple   = int64(200)
	DefaultMinDeposit           = sdk.NewCoins(sdk.NewCoin(sdk.DefaultBondDenom, sdk.NewInt(6000))) // 6000stake
	DefaultServiceFeeTax        = sdk.NewDecWithPrec(1, 1)                                          // 10%
	DefaultSlashFraction        = sdk.NewDecWithPrec(1, 3)                                          // 0.1%
	DefaultComplaintRetrospect  = 15 * 24 * time.Hour                                               // 15 days
	DefaultArbitrationTimeLimit = 5 * 24 * time.Hour                                                // 5 days
	DefaultTxSizeLimit          = uint64(4000)
	DefaultBaseDenom            = sdk.DefaultBondDenom
)

Service params default values

View Source
var (
	KeyMaxRequestTimeout    = []byte("MaxRequestTimeout")
	KeyMinDepositMultiple   = []byte("MinDepositMultiple")
	KeyMinDeposit           = []byte("MinDeposit")
	KeyServiceFeeTax        = []byte("ServiceFeeTax")
	KeySlashFraction        = []byte("SlashFraction")
	KeyComplaintRetrospect  = []byte("ComplaintRetrospect")
	KeyArbitrationTimeLimit = []byte("ArbitrationTimeLimit")
	KeyTxSizeLimit          = []byte("TxSizeLimit")
	KeyBaseDenom            = []byte("BaseDenom")
)

Keys for parameter access nolint

View Source
var (
	ErrInvalidLengthTypes        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowTypes          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupTypes = fmt.Errorf("proto: unexpected end of group")
)
View Source
var ModuleCdc *codec.Codec

ModuleCdc defines the module codec

View Source
var RequestContextBatchState_name = map[int32]string{
	0: "BATCH_RUNNING",
	1: "BATCH_COMPLETED",
}
View Source
var RequestContextBatchState_value = map[string]int32{
	"BATCH_RUNNING":   0,
	"BATCH_COMPLETED": 1,
}
View Source
var RequestContextState_name = map[int32]string{
	0: "RUNNING",
	1: "PAUSED",
	2: "COMPLETED",
}
View Source
var RequestContextState_value = map[string]int32{
	"RUNNING":   0,
	"PAUSED":    1,
	"COMPLETED": 2,
}

Functions

func ActionTag

func ActionTag(action string, tagKeys ...string) string

ActionTag appends action and all tagKeys

func ConvertRequestID

func ConvertRequestID(requestIDStr string) (tmbytes.HexBytes, error)

ConvertRequestID converts the given string to request ID

func GenerateRequestContextID

func GenerateRequestContextID(txHash []byte, msgIndex int64) tmbytes.HexBytes

GenerateRequestContextID generates a unique ID for the request context from the specified params

func GenerateRequestID

func GenerateRequestID(requestContextID tmbytes.HexBytes, requestContextBatchCounter uint64, requestHeight int64, batchRequestIndex int16) tmbytes.HexBytes

GenerateRequestID generates a unique request ID from the given params

func GetActiveRequestKey

func GetActiveRequestKey(serviceName string, provider sdk.AccAddress, expirationHeight int64, requestID []byte) []byte

GetActiveRequestKey returns the key for the active request with the specified request ID in the given height

func GetActiveRequestKeyByID

func GetActiveRequestKeyByID(requestID []byte) []byte

GetActiveRequestKeyByID returns the key for the active request with the specified request ID

func GetActiveRequestSubspace

func GetActiveRequestSubspace(serviceName string, provider sdk.AccAddress) []byte

GetActiveRequestSubspace returns the key prefix for iterating through the active requests for the specified provider

func GetActiveRequestSubspaceByReqCtx

func GetActiveRequestSubspaceByReqCtx(requestContextID []byte, batchCounter uint64) []byte

GetActiveRequestSubspaceByReqCtx returns the key prefix for iterating through the active requests for the specified request context

func GetBindingsSubspace

func GetBindingsSubspace(serviceName string) []byte

GetBindingsSubspace gets the key prefix for iterating through all bindings of the specified service name

func GetDiscountByTime

func GetDiscountByTime(pricing Pricing, time time.Time) sdk.Dec

GetDiscountByTime gets the discount level by the specified time

func GetDiscountByVolume

func GetDiscountByVolume(pricing Pricing, volume uint64) sdk.Dec

GetDiscountByVolume gets the discount level by the specified volume Note: make sure that the promotions by volume are sorted in ascending order

func GetEarnedFeesKey

func GetEarnedFeesKey(provider sdk.AccAddress, denom string) []byte

GetEarnedFeesKey gets the key for the earned fees of the specified provider and denom

func GetEarnedFeesSubspace

func GetEarnedFeesSubspace(provider sdk.AccAddress) []byte

GetEarnedFeesSubspace gets the subspace for the earned fees of the specified provider

func GetExpiredRequestBatchHeightKey

func GetExpiredRequestBatchHeightKey(requestContextID []byte) []byte

GetExpiredRequestBatchHeightKey returns the key for the current request batch expiration height of the specified request context

func GetExpiredRequestBatchKey

func GetExpiredRequestBatchKey(requestContextID []byte, batchExpirationHeight int64) []byte

GetExpiredRequestBatchKey returns the key for the request batch expiration of the specified request context

func GetExpiredRequestBatchSubspace

func GetExpiredRequestBatchSubspace(batchExpirationHeight int64) []byte

GetExpiredRequestBatchSubspace returns the key prefix for iterating through the expired request batch queue in the specified height

func GetNewRequestBatchHeightKey

func GetNewRequestBatchHeightKey(requestContextID []byte) []byte

GetNewRequestBatchHeightKey returns the key for the new request batch height of the specified request context

func GetNewRequestBatchKey

func GetNewRequestBatchKey(requestContextID []byte, requestBatchHeight int64) []byte

GetNewRequestBatchKey returns the key for the new batch request of the specified request context in the given height

func GetNewRequestBatchSubspace

func GetNewRequestBatchSubspace(requestBatchHeight int64) []byte

GetNewRequestBatchSubspace returns the key prefix for iterating through the new request batch queue in the specified height

func GetOwnerBindingsSubspace

func GetOwnerBindingsSubspace(owner sdk.AccAddress, serviceName string) []byte

GetOwnerBindingsSubspace gets the key prefix for iterating through all bindings of the specified service name and owner

func GetOwnerEarnedFeesKey

func GetOwnerEarnedFeesKey(owner sdk.AccAddress, denom string) []byte

GetOwnerEarnedFeesKey returns the key for the earned fees of the specified owner and denom

func GetOwnerEarnedFeesSubspace

func GetOwnerEarnedFeesSubspace(owner sdk.AccAddress) []byte

GetEarnedFeesSubspace gets the subspace for the earned fees of the specified provider

func GetOwnerKey

func GetOwnerKey(provider sdk.AccAddress) []byte

GetOwnerKey gets the key for the specified provider VALUE: sdk.AccAddress

func GetOwnerProviderKey

func GetOwnerProviderKey(owner, provider sdk.AccAddress) []byte

GetOwnerProviderKey gets the key for the specified owner and provider VALUE: []byte{}

func GetOwnerProvidersSubspace

func GetOwnerProvidersSubspace(owner sdk.AccAddress) []byte

GetOwnerProvidersSubspace gets the key prefix for iterating through providers of the specified owner

func GetOwnerServiceBindingKey

func GetOwnerServiceBindingKey(owner sdk.AccAddress, serviceName string, provider sdk.AccAddress) []byte

GetOwnerServiceBindingKey gets the key for the service binding with the specified owner VALUE: []byte{}

func GetPricingKey

func GetPricingKey(serviceName string, provider sdk.AccAddress) []byte

GetPricingKey gets the key for the pricing of the specified binding VALUE: service/Pricing

func GetRequestContextKey

func GetRequestContextKey(requestContextID []byte) []byte

GetRequestContextKey returns the key for the request context with the specified ID

func GetRequestKey

func GetRequestKey(requestID []byte) []byte

GetRequestKey returns the key for the request with the specified request ID

func GetRequestSubspaceByReqCtx

func GetRequestSubspaceByReqCtx(requestContextID []byte, batchCounter uint64) []byte

GetRequestSubspaceByReqCtx returns the key prefix for iterating through the requests of the specified request context

func GetRequestVolumeKey

func GetRequestVolumeKey(consumer sdk.AccAddress, serviceName string, provider sdk.AccAddress) []byte

GetRequestVolumeKey returns the key for the request volume for the specified consumer and binding

func GetResponseKey

func GetResponseKey(requestID []byte) []byte

GetResponseKey returns the key for the response for the given request ID

func GetResponseSubspaceByReqCtx

func GetResponseSubspaceByReqCtx(requestContextID []byte, batchCounter uint64) []byte

GetResponseSubspaceByReqCtx returns the key prefix for iterating throuth responses for the specified request context and batch counter

func GetServiceBindingKey

func GetServiceBindingKey(serviceName string, provider sdk.AccAddress) []byte

GetServiceBindingKey gets the key for the service binding with the specified service name and provider VALUE: service/ServiceBinding

func GetServiceDefinitionKey

func GetServiceDefinitionKey(serviceName string) []byte

GetServiceDefinitionKey gets the key for the service definition with the specified service name VALUE: service/ServiceDefinition

func GetWithdrawAddrKey

func GetWithdrawAddrKey(provider sdk.AccAddress) []byte

GetWithdrawAddrKey gets the key for the withdrawal address of the specified provider VALUE: withdrawal address ([]byte)

func HasDuplicate

func HasDuplicate(arr []string) bool

HasDuplicate checks if the given array contains duplicate elements. Return true if there exists duplicate elements, false otherwise

func ParseCoinParts

func ParseCoinParts(coinStr string) (denom, amount string, err error)

ParseCoinParts parses the given string to the amount and denom

func RegisterCodec

func RegisterCodec(cdc *codec.Codec)

RegisterCodec registers concrete types on codec

func SplitRequestContextID

func SplitRequestContextID(contextID tmbytes.HexBytes) (tmbytes.HexBytes, int64, error)

SplitRequestContextID splits the given contextID to txHash and msgIndex

func SplitRequestID

func SplitRequestID(requestID tmbytes.HexBytes) (tmbytes.HexBytes, uint64, int64, int16, error)

SplitRequestID splits the given requestID to contextID, batchCounter, requestHeight, batchRequestIndex

func ValidateAuthor

func ValidateAuthor(author sdk.AccAddress) error

func ValidateAuthorDescription

func ValidateAuthorDescription(authorDescription string) error

func ValidateBindingPricing

func ValidateBindingPricing(pricing string) error

ValidateBindingPricing validates the given pricing against the Pricing JSON Schema

func ValidateConsumer

func ValidateConsumer(consumer sdk.AccAddress) error

func ValidateContextID

func ValidateContextID(contextID []byte) error

func ValidateGenesis

func ValidateGenesis(data GenesisState) error

ValidateGenesis validates the provided service genesis state to ensure the expected invariants holds.

func ValidateInput

func ValidateInput(input string) error

func ValidateOutput

func ValidateOutput(code uint16, output string) error

func ValidateOwner

func ValidateOwner(owner sdk.AccAddress) error

func ValidatePricing

func ValidatePricing(pricing Pricing) error

ValidatePricing validates the given pricing

func ValidateProvider

func ValidateProvider(provider sdk.AccAddress) error

func ValidateProvidersCanEmpty

func ValidateProvidersCanEmpty(providers []sdk.AccAddress) error

func ValidateProvidersNoEmpty

func ValidateProvidersNoEmpty(providers []sdk.AccAddress) error

func ValidateQoS

func ValidateQoS(qos uint64) error

func ValidateRequest

func ValidateRequest(
	serviceName string,
	serviceFeeCap sdk.Coins,
	providers []sdk.AccAddress,
	input string,
	timeout int64,
	repeated bool,
	repeatedFrequency uint64,
	repeatedTotal int64,
) error

ValidateRequest validates the request params

func ValidateRequestContextUpdating

func ValidateRequestContextUpdating(
	providers []sdk.AccAddress,
	serviceFeeCap sdk.Coins,
	timeout int64,
	repeatedFrequency uint64,
	repeatedTotal int64,
) error

ValidateRequestContextUpdating validates the request context updating operation

func ValidateRequestID

func ValidateRequestID(reqID []byte) error

func ValidateRequestInput

func ValidateRequestInput(schemas string, input string) error

ValidateRequestInput validates the request input against the input schema

func ValidateResponseOutput

func ValidateResponseOutput(schemas string, output string) error

ValidateResponseOutput validates the response output against the output schema

func ValidateResponseResult

func ValidateResponseResult(result string) error

ValidateResponseResult validates the response result against the result schema

func ValidateServiceDeposit

func ValidateServiceDeposit(deposit sdk.Coins) error

func ValidateServiceDescription

func ValidateServiceDescription(svcDescription string) error

func ValidateServiceFeeCap

func ValidateServiceFeeCap(serviceFeeCap sdk.Coins) error

func ValidateServiceName

func ValidateServiceName(name string) error

ValidateServiceName validates the service name

func ValidateServiceSchemas

func ValidateServiceSchemas(schemas string) error

ValidateServiceSchemas validates the given service schemas

func ValidateTags

func ValidateTags(tags []string) error

func ValidateWithdrawAddress

func ValidateWithdrawAddress(withdrawAddress sdk.AccAddress) error

Types

type AccountKeeper

type AccountKeeper interface {
	GetAccount(ctx sdk.Context, addr sdk.AccAddress) auth.Account
	GetModuleAddress(name string) sdk.AccAddress
	GetModuleAccount(ctx sdk.Context, name string) auth.ModuleAccountI
}

AccountKeeper defines the expected account keeper used for simulations (noalias)

type BankKeeper

type BankKeeper interface {
	MintCoins(ctx sdk.Context, moduleName string, amt sdk.Coins) error
	BurnCoins(ctx sdk.Context, moduleName string, amt sdk.Coins) error

	GetSupply(ctx sdk.Context) (supply bank.SupplyI)
	GetBalance(ctx sdk.Context, addr sdk.AccAddress, denom string) sdk.Coin

	SendCoinsFromModuleToAccount(ctx sdk.Context, senderModule string, recipientAddr sdk.AccAddress, amt sdk.Coins) error
	SendCoinsFromAccountToModule(ctx sdk.Context, senderAddr sdk.AccAddress, recipientModule string, amt sdk.Coins) error
	SendCoinsFromModuleToModule(ctx sdk.Context, senderModule, recipientModule string, amt sdk.Coins) error

	SpendableCoins(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
}

BankKeeper defines the expected bank keeper for module accounts (noalias)

type BatchState

type BatchState struct {
	BatchCounter           uint64                   `json:"batch_counter"`
	State                  RequestContextBatchState `json:"state"`
	BatchResponseThreshold uint32                   `json:"batch_response_threshold"`
	BatchRequestCount      uint32                   `json:"batch_request_count"`
	BatchResponseCount     uint32                   `json:"batch_response_count"`
}

type CompactRequest

type CompactRequest struct {
	RequestContextID           github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 199-byte string literal not displayed */
	RequestContextBatchCounter uint64                                               `` /* 181-byte string literal not displayed */
	Provider                   github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,3,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	ServiceFee                 github_com_cosmos_cosmos_sdk_types.Coins             `` /* 154-byte string literal not displayed */
	RequestHeight              int64                                                `protobuf:"varint,5,opt,name=request_height,json=requestHeight,proto3" json:"request_height,omitempty" yaml:"request_height"`
	ExpirationHeight           int64                                                `` /* 135-byte string literal not displayed */
}

CompactRequest defines a standard for compact request.

func NewCompactRequest

func NewCompactRequest(
	requestContextID tmbytes.HexBytes,
	batchCounter uint64,
	provider sdk.AccAddress,
	serviceFee sdk.Coins,
	requestHeight int64,
	expirationHeight int64,
) CompactRequest

NewCompactRequest creates a new CompactRequest instance

func (*CompactRequest) Descriptor

func (*CompactRequest) Descriptor() ([]byte, []int)

func (*CompactRequest) Marshal

func (m *CompactRequest) Marshal() (dAtA []byte, err error)

func (*CompactRequest) MarshalTo

func (m *CompactRequest) MarshalTo(dAtA []byte) (int, error)

func (*CompactRequest) MarshalToSizedBuffer

func (m *CompactRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*CompactRequest) ProtoMessage

func (*CompactRequest) ProtoMessage()

func (*CompactRequest) Reset

func (m *CompactRequest) Reset()

func (*CompactRequest) Size

func (m *CompactRequest) Size() (n int)

func (*CompactRequest) String

func (m *CompactRequest) String() string

func (*CompactRequest) Unmarshal

func (m *CompactRequest) Unmarshal(dAtA []byte) error

func (*CompactRequest) XXX_DiscardUnknown

func (m *CompactRequest) XXX_DiscardUnknown()

func (*CompactRequest) XXX_Marshal

func (m *CompactRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*CompactRequest) XXX_Merge

func (m *CompactRequest) XXX_Merge(src proto.Message)

func (*CompactRequest) XXX_Size

func (m *CompactRequest) XXX_Size() int

func (*CompactRequest) XXX_Unmarshal

func (m *CompactRequest) XXX_Unmarshal(b []byte) error

type GenesisState

type GenesisState struct {
	Params            Params                    `json:"params"`             // service params
	Definitions       []ServiceDefinition       `json:"definitions"`        // service definitions
	Bindings          []ServiceBinding          `json:"bindings"`           // service bindings
	WithdrawAddresses map[string]sdk.AccAddress `json:"withdraw_addresses"` // withdrawal addresses
	RequestContexts   map[string]RequestContext `json:"request_contexts"`   // request contexts
}

GenesisState - all service state that must be provided at genesis

func DefaultGenesisState

func DefaultGenesisState() GenesisState

DefaultGenesisState gets the raw genesis raw message for testing

func DefaultGenesisStateForTest

func DefaultGenesisStateForTest(moduleSvcDefinitions []ServiceDefinition) GenesisState

get raw genesis raw message for testing

func NewGenesisState

func NewGenesisState(
	params Params,
	definitions []ServiceDefinition,
	bindings []ServiceBinding,
	withdrawAddresses map[string]sdk.AccAddress,
	requestContexts map[string]RequestContext,
) GenesisState

NewGenesisState constructs a GenesisState

type MockToken

type MockToken struct {
	Symbol  string
	MinUnit string
	Scale   uint32
}

MockToken represents a mock implementation for TokenI

func (MockToken) GetMinUnit

func (token MockToken) GetMinUnit() string

GetMinUnit gets the min unit

func (MockToken) GetScale

func (token MockToken) GetScale() uint32

GetScale gets the scale

func (MockToken) GetSymbol

func (token MockToken) GetSymbol() string

GetSymbol gets the symbol

type MsgBindService

type MsgBindService struct {
	ServiceName string                                        `protobuf:"bytes,1,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty" yaml:"service_name"`
	Provider    github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,2,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Deposit     github_com_cosmos_cosmos_sdk_types.Coins      `protobuf:"bytes,3,rep,name=deposit,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"deposit"`
	Pricing     string                                        `protobuf:"bytes,4,opt,name=pricing,proto3" json:"pricing,omitempty"`
	QoS         uint64                                        `protobuf:"varint,5,opt,name=qos,proto3" json:"qos,omitempty"`
	Owner       github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,6,opt,name=owner,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"owner,omitempty"`
}

MsgBindService defines an SDK message for binding to an existing service.

func NewMsgBindService

func NewMsgBindService(
	serviceName string,
	provider sdk.AccAddress,
	deposit sdk.Coins,
	pricing string,
	qos uint64,
	owner sdk.AccAddress,
) MsgBindService

NewMsgBindService creates a new MsgBindService instance

func (*MsgBindService) Descriptor

func (*MsgBindService) Descriptor() ([]byte, []int)

func (MsgBindService) GetSignBytes

func (msg MsgBindService) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgBindService) GetSigners

func (msg MsgBindService) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgBindService) Marshal

func (m *MsgBindService) Marshal() (dAtA []byte, err error)

func (*MsgBindService) MarshalTo

func (m *MsgBindService) MarshalTo(dAtA []byte) (int, error)

func (*MsgBindService) MarshalToSizedBuffer

func (m *MsgBindService) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgBindService) ProtoMessage

func (*MsgBindService) ProtoMessage()

func (*MsgBindService) Reset

func (m *MsgBindService) Reset()

func (MsgBindService) Route

func (msg MsgBindService) Route() string

Route implements Msg.

func (*MsgBindService) Size

func (m *MsgBindService) Size() (n int)

func (*MsgBindService) String

func (m *MsgBindService) String() string

func (MsgBindService) Type

func (msg MsgBindService) Type() string

Type implements Msg.

func (*MsgBindService) Unmarshal

func (m *MsgBindService) Unmarshal(dAtA []byte) error

func (MsgBindService) ValidateBasic

func (msg MsgBindService) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgBindService) XXX_DiscardUnknown

func (m *MsgBindService) XXX_DiscardUnknown()

func (*MsgBindService) XXX_Marshal

func (m *MsgBindService) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgBindService) XXX_Merge

func (m *MsgBindService) XXX_Merge(src proto.Message)

func (*MsgBindService) XXX_Size

func (m *MsgBindService) XXX_Size() int

func (*MsgBindService) XXX_Unmarshal

func (m *MsgBindService) XXX_Unmarshal(b []byte) error

type MsgCallService

type MsgCallService struct {
	ServiceName       string                                          `protobuf:"bytes,1,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty" yaml:"service_name"`
	Providers         []github_com_cosmos_cosmos_sdk_types.AccAddress `` /* 126-byte string literal not displayed */
	Consumer          github_com_cosmos_cosmos_sdk_types.AccAddress   `protobuf:"bytes,3,opt,name=consumer,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"consumer,omitempty"`
	Input             string                                          `protobuf:"bytes,4,opt,name=input,proto3" json:"input,omitempty"`
	ServiceFeeCap     github_com_cosmos_cosmos_sdk_types.Coins        `` /* 169-byte string literal not displayed */
	Timeout           int64                                           `protobuf:"varint,6,opt,name=timeout,proto3" json:"timeout,omitempty"`
	SuperMode         bool                                            `protobuf:"varint,7,opt,name=super_mode,json=superMode,proto3" json:"super_mode,omitempty" yaml:"super_mode"`
	Repeated          bool                                            `protobuf:"varint,8,opt,name=repeated,proto3" json:"repeated,omitempty"`
	RepeatedFrequency uint64                                          `` /* 139-byte string literal not displayed */
	RepeatedTotal     int64                                           `protobuf:"varint,10,opt,name=repeated_total,json=repeatedTotal,proto3" json:"repeated_total,omitempty" yaml:"repeated_total"`
}

MsgCallService defines an SDK message to initiate a service request context.

func NewMsgCallService

func NewMsgCallService(
	serviceName string,
	providers []sdk.AccAddress,
	consumer sdk.AccAddress,
	input string,
	serviceFeeCap sdk.Coins,
	timeout int64,
	superMode bool,
	repeated bool,
	repeatedFrequency uint64,
	repeatedTotal int64,
) MsgCallService

NewMsgCallService creates a new MsgCallService instance

func (*MsgCallService) Descriptor

func (*MsgCallService) Descriptor() ([]byte, []int)

func (MsgCallService) GetSignBytes

func (msg MsgCallService) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgCallService) GetSigners

func (msg MsgCallService) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgCallService) Marshal

func (m *MsgCallService) Marshal() (dAtA []byte, err error)

func (*MsgCallService) MarshalTo

func (m *MsgCallService) MarshalTo(dAtA []byte) (int, error)

func (*MsgCallService) MarshalToSizedBuffer

func (m *MsgCallService) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgCallService) ProtoMessage

func (*MsgCallService) ProtoMessage()

func (*MsgCallService) Reset

func (m *MsgCallService) Reset()

func (MsgCallService) Route

func (msg MsgCallService) Route() string

Route implements Msg.

func (*MsgCallService) Size

func (m *MsgCallService) Size() (n int)

func (*MsgCallService) String

func (m *MsgCallService) String() string

func (MsgCallService) Type

func (msg MsgCallService) Type() string

Type implements Msg.

func (*MsgCallService) Unmarshal

func (m *MsgCallService) Unmarshal(dAtA []byte) error

func (MsgCallService) ValidateBasic

func (msg MsgCallService) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgCallService) XXX_DiscardUnknown

func (m *MsgCallService) XXX_DiscardUnknown()

func (*MsgCallService) XXX_Marshal

func (m *MsgCallService) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgCallService) XXX_Merge

func (m *MsgCallService) XXX_Merge(src proto.Message)

func (*MsgCallService) XXX_Size

func (m *MsgCallService) XXX_Size() int

func (*MsgCallService) XXX_Unmarshal

func (m *MsgCallService) XXX_Unmarshal(b []byte) error

type MsgDefineService

type MsgDefineService struct {
	Name              string                                        `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	Description       string                                        `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	Tags              []string                                      `protobuf:"bytes,3,rep,name=tags,proto3" json:"tags,omitempty"`
	Author            github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,4,opt,name=author,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"author,omitempty"`
	AuthorDescription string                                        `` /* 138-byte string literal not displayed */
	Schemas           string                                        `protobuf:"bytes,6,opt,name=schemas,proto3" json:"schemas,omitempty"`
}

MsgDefineService defines an SDK message for defining a new service.

func NewMsgDefineService

func NewMsgDefineService(
	name,
	description string,
	tags []string,
	author sdk.AccAddress,
	authorDescription,
	schemas string,
) MsgDefineService

NewMsgDefineService creates a new MsgDefineService instance

func (*MsgDefineService) Descriptor

func (*MsgDefineService) Descriptor() ([]byte, []int)

func (MsgDefineService) GetSignBytes

func (msg MsgDefineService) GetSignBytes() []byte

GetSignBytes implements Msg

func (MsgDefineService) GetSigners

func (msg MsgDefineService) GetSigners() []sdk.AccAddress

GetSigners implements Msg

func (*MsgDefineService) Marshal

func (m *MsgDefineService) Marshal() (dAtA []byte, err error)

func (*MsgDefineService) MarshalTo

func (m *MsgDefineService) MarshalTo(dAtA []byte) (int, error)

func (*MsgDefineService) MarshalToSizedBuffer

func (m *MsgDefineService) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgDefineService) ProtoMessage

func (*MsgDefineService) ProtoMessage()

func (*MsgDefineService) Reset

func (m *MsgDefineService) Reset()

func (MsgDefineService) Route

func (msg MsgDefineService) Route() string

Route implements Msg

func (*MsgDefineService) Size

func (m *MsgDefineService) Size() (n int)

func (*MsgDefineService) String

func (m *MsgDefineService) String() string

func (MsgDefineService) Type

func (msg MsgDefineService) Type() string

Type implements Msg

func (*MsgDefineService) Unmarshal

func (m *MsgDefineService) Unmarshal(dAtA []byte) error

func (MsgDefineService) ValidateBasic

func (msg MsgDefineService) ValidateBasic() error

ValidateBasic implements Msg

func (*MsgDefineService) XXX_DiscardUnknown

func (m *MsgDefineService) XXX_DiscardUnknown()

func (*MsgDefineService) XXX_Marshal

func (m *MsgDefineService) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgDefineService) XXX_Merge

func (m *MsgDefineService) XXX_Merge(src proto.Message)

func (*MsgDefineService) XXX_Size

func (m *MsgDefineService) XXX_Size() int

func (*MsgDefineService) XXX_Unmarshal

func (m *MsgDefineService) XXX_Unmarshal(b []byte) error

type MsgDisableServiceBinding

type MsgDisableServiceBinding struct {
	ServiceName string                                        `protobuf:"bytes,1,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty" yaml:"service_name"`
	Provider    github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,2,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Owner       github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,3,opt,name=owner,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"owner,omitempty"`
}

MsgDisableServiceBinding defines an SDK message to disable a service binding.

func NewMsgDisableServiceBinding

func NewMsgDisableServiceBinding(
	serviceName string,
	provider,
	owner sdk.AccAddress,
) MsgDisableServiceBinding

NewMsgDisableServiceBinding creates a new MsgDisableServiceBinding instance

func (*MsgDisableServiceBinding) Descriptor

func (*MsgDisableServiceBinding) Descriptor() ([]byte, []int)

func (MsgDisableServiceBinding) GetSignBytes

func (msg MsgDisableServiceBinding) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgDisableServiceBinding) GetSigners

func (msg MsgDisableServiceBinding) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgDisableServiceBinding) Marshal

func (m *MsgDisableServiceBinding) Marshal() (dAtA []byte, err error)

func (*MsgDisableServiceBinding) MarshalTo

func (m *MsgDisableServiceBinding) MarshalTo(dAtA []byte) (int, error)

func (*MsgDisableServiceBinding) MarshalToSizedBuffer

func (m *MsgDisableServiceBinding) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgDisableServiceBinding) ProtoMessage

func (*MsgDisableServiceBinding) ProtoMessage()

func (*MsgDisableServiceBinding) Reset

func (m *MsgDisableServiceBinding) Reset()

func (MsgDisableServiceBinding) Route

func (msg MsgDisableServiceBinding) Route() string

Route implements Msg.

func (*MsgDisableServiceBinding) Size

func (m *MsgDisableServiceBinding) Size() (n int)

func (*MsgDisableServiceBinding) String

func (m *MsgDisableServiceBinding) String() string

func (MsgDisableServiceBinding) Type

func (msg MsgDisableServiceBinding) Type() string

Type implements Msg.

func (*MsgDisableServiceBinding) Unmarshal

func (m *MsgDisableServiceBinding) Unmarshal(dAtA []byte) error

func (MsgDisableServiceBinding) ValidateBasic

func (msg MsgDisableServiceBinding) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgDisableServiceBinding) XXX_DiscardUnknown

func (m *MsgDisableServiceBinding) XXX_DiscardUnknown()

func (*MsgDisableServiceBinding) XXX_Marshal

func (m *MsgDisableServiceBinding) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgDisableServiceBinding) XXX_Merge

func (m *MsgDisableServiceBinding) XXX_Merge(src proto.Message)

func (*MsgDisableServiceBinding) XXX_Size

func (m *MsgDisableServiceBinding) XXX_Size() int

func (*MsgDisableServiceBinding) XXX_Unmarshal

func (m *MsgDisableServiceBinding) XXX_Unmarshal(b []byte) error

type MsgEnableServiceBinding

type MsgEnableServiceBinding struct {
	ServiceName string                                        `protobuf:"bytes,1,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty" yaml:"service_name"`
	Provider    github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,2,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Deposit     github_com_cosmos_cosmos_sdk_types.Coins      `protobuf:"bytes,3,rep,name=deposit,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"deposit"`
	Owner       github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,4,opt,name=owner,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"owner,omitempty"`
}

MsgEnableServiceBinding defines an SDK message to enable a service binding.

func NewMsgEnableServiceBinding

func NewMsgEnableServiceBinding(
	serviceName string,
	provider sdk.AccAddress,
	deposit sdk.Coins,
	owner sdk.AccAddress,
) MsgEnableServiceBinding

NewMsgEnableServiceBinding creates a new MsgEnableServiceBinding instance

func (*MsgEnableServiceBinding) Descriptor

func (*MsgEnableServiceBinding) Descriptor() ([]byte, []int)

func (MsgEnableServiceBinding) GetSignBytes

func (msg MsgEnableServiceBinding) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgEnableServiceBinding) GetSigners

func (msg MsgEnableServiceBinding) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgEnableServiceBinding) Marshal

func (m *MsgEnableServiceBinding) Marshal() (dAtA []byte, err error)

func (*MsgEnableServiceBinding) MarshalTo

func (m *MsgEnableServiceBinding) MarshalTo(dAtA []byte) (int, error)

func (*MsgEnableServiceBinding) MarshalToSizedBuffer

func (m *MsgEnableServiceBinding) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgEnableServiceBinding) ProtoMessage

func (*MsgEnableServiceBinding) ProtoMessage()

func (*MsgEnableServiceBinding) Reset

func (m *MsgEnableServiceBinding) Reset()

func (MsgEnableServiceBinding) Route

func (msg MsgEnableServiceBinding) Route() string

Route implements Msg.

func (*MsgEnableServiceBinding) Size

func (m *MsgEnableServiceBinding) Size() (n int)

func (*MsgEnableServiceBinding) String

func (m *MsgEnableServiceBinding) String() string

func (MsgEnableServiceBinding) Type

func (msg MsgEnableServiceBinding) Type() string

Type implements Msg.

func (*MsgEnableServiceBinding) Unmarshal

func (m *MsgEnableServiceBinding) Unmarshal(dAtA []byte) error

func (MsgEnableServiceBinding) ValidateBasic

func (msg MsgEnableServiceBinding) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgEnableServiceBinding) XXX_DiscardUnknown

func (m *MsgEnableServiceBinding) XXX_DiscardUnknown()

func (*MsgEnableServiceBinding) XXX_Marshal

func (m *MsgEnableServiceBinding) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgEnableServiceBinding) XXX_Merge

func (m *MsgEnableServiceBinding) XXX_Merge(src proto.Message)

func (*MsgEnableServiceBinding) XXX_Size

func (m *MsgEnableServiceBinding) XXX_Size() int

func (*MsgEnableServiceBinding) XXX_Unmarshal

func (m *MsgEnableServiceBinding) XXX_Unmarshal(b []byte) error

type MsgKillRequestContext

type MsgKillRequestContext struct {
	RequestContextID github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 199-byte string literal not displayed */
	Consumer         github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,2,opt,name=consumer,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"consumer,omitempty"`
}

MsgKillRequestContext defines an SDK message to terminate a service request.

func NewMsgKillRequestContext

func NewMsgKillRequestContext(requestContextID tmbytes.HexBytes, consumer sdk.AccAddress) MsgKillRequestContext

NewMsgKillRequestContext creates a new MsgKillRequestContext instance

func (*MsgKillRequestContext) Descriptor

func (*MsgKillRequestContext) Descriptor() ([]byte, []int)

func (MsgKillRequestContext) GetSignBytes

func (msg MsgKillRequestContext) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgKillRequestContext) GetSigners

func (msg MsgKillRequestContext) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgKillRequestContext) Marshal

func (m *MsgKillRequestContext) Marshal() (dAtA []byte, err error)

func (*MsgKillRequestContext) MarshalTo

func (m *MsgKillRequestContext) MarshalTo(dAtA []byte) (int, error)

func (*MsgKillRequestContext) MarshalToSizedBuffer

func (m *MsgKillRequestContext) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgKillRequestContext) ProtoMessage

func (*MsgKillRequestContext) ProtoMessage()

func (*MsgKillRequestContext) Reset

func (m *MsgKillRequestContext) Reset()

func (MsgKillRequestContext) Route

func (msg MsgKillRequestContext) Route() string

Route implements Msg.

func (*MsgKillRequestContext) Size

func (m *MsgKillRequestContext) Size() (n int)

func (*MsgKillRequestContext) String

func (m *MsgKillRequestContext) String() string

func (MsgKillRequestContext) Type

func (msg MsgKillRequestContext) Type() string

Type implements Msg.

func (*MsgKillRequestContext) Unmarshal

func (m *MsgKillRequestContext) Unmarshal(dAtA []byte) error

func (MsgKillRequestContext) ValidateBasic

func (msg MsgKillRequestContext) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgKillRequestContext) XXX_DiscardUnknown

func (m *MsgKillRequestContext) XXX_DiscardUnknown()

func (*MsgKillRequestContext) XXX_Marshal

func (m *MsgKillRequestContext) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgKillRequestContext) XXX_Merge

func (m *MsgKillRequestContext) XXX_Merge(src proto.Message)

func (*MsgKillRequestContext) XXX_Size

func (m *MsgKillRequestContext) XXX_Size() int

func (*MsgKillRequestContext) XXX_Unmarshal

func (m *MsgKillRequestContext) XXX_Unmarshal(b []byte) error

type MsgPauseRequestContext

type MsgPauseRequestContext struct {
	RequestContextID github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 199-byte string literal not displayed */
	Consumer         github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,2,opt,name=consumer,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"consumer,omitempty"`
}

MsgPauseRequestContext defines an SDK message to pause a service request.

func NewMsgPauseRequestContext

func NewMsgPauseRequestContext(requestContextID tmbytes.HexBytes, consumer sdk.AccAddress) MsgPauseRequestContext

NewMsgPauseRequestContext creates a new MsgPauseRequestContext instance

func (*MsgPauseRequestContext) Descriptor

func (*MsgPauseRequestContext) Descriptor() ([]byte, []int)

func (MsgPauseRequestContext) GetSignBytes

func (msg MsgPauseRequestContext) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgPauseRequestContext) GetSigners

func (msg MsgPauseRequestContext) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgPauseRequestContext) Marshal

func (m *MsgPauseRequestContext) Marshal() (dAtA []byte, err error)

func (*MsgPauseRequestContext) MarshalTo

func (m *MsgPauseRequestContext) MarshalTo(dAtA []byte) (int, error)

func (*MsgPauseRequestContext) MarshalToSizedBuffer

func (m *MsgPauseRequestContext) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgPauseRequestContext) ProtoMessage

func (*MsgPauseRequestContext) ProtoMessage()

func (*MsgPauseRequestContext) Reset

func (m *MsgPauseRequestContext) Reset()

func (MsgPauseRequestContext) Route

func (msg MsgPauseRequestContext) Route() string

Route implements Msg.

func (*MsgPauseRequestContext) Size

func (m *MsgPauseRequestContext) Size() (n int)

func (*MsgPauseRequestContext) String

func (m *MsgPauseRequestContext) String() string

func (MsgPauseRequestContext) Type

func (msg MsgPauseRequestContext) Type() string

Type implements Msg.

func (*MsgPauseRequestContext) Unmarshal

func (m *MsgPauseRequestContext) Unmarshal(dAtA []byte) error

func (MsgPauseRequestContext) ValidateBasic

func (msg MsgPauseRequestContext) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgPauseRequestContext) XXX_DiscardUnknown

func (m *MsgPauseRequestContext) XXX_DiscardUnknown()

func (*MsgPauseRequestContext) XXX_Marshal

func (m *MsgPauseRequestContext) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgPauseRequestContext) XXX_Merge

func (m *MsgPauseRequestContext) XXX_Merge(src proto.Message)

func (*MsgPauseRequestContext) XXX_Size

func (m *MsgPauseRequestContext) XXX_Size() int

func (*MsgPauseRequestContext) XXX_Unmarshal

func (m *MsgPauseRequestContext) XXX_Unmarshal(b []byte) error

type MsgRefundServiceDeposit

type MsgRefundServiceDeposit struct {
	ServiceName string                                        `protobuf:"bytes,1,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty" yaml:"service_name"`
	Provider    github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,2,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Owner       github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,3,opt,name=owner,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"owner,omitempty"`
}

MsgRefundServiceDeposit defines an SDK message to refund deposit from a service binding.

func NewMsgRefundServiceDeposit

func NewMsgRefundServiceDeposit(
	serviceName string,
	provider,
	owner sdk.AccAddress,
) MsgRefundServiceDeposit

NewMsgRefundServiceDeposit creates a new MsgRefundServiceDeposit instance

func (*MsgRefundServiceDeposit) Descriptor

func (*MsgRefundServiceDeposit) Descriptor() ([]byte, []int)

func (MsgRefundServiceDeposit) GetSignBytes

func (msg MsgRefundServiceDeposit) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgRefundServiceDeposit) GetSigners

func (msg MsgRefundServiceDeposit) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgRefundServiceDeposit) Marshal

func (m *MsgRefundServiceDeposit) Marshal() (dAtA []byte, err error)

func (*MsgRefundServiceDeposit) MarshalTo

func (m *MsgRefundServiceDeposit) MarshalTo(dAtA []byte) (int, error)

func (*MsgRefundServiceDeposit) MarshalToSizedBuffer

func (m *MsgRefundServiceDeposit) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgRefundServiceDeposit) ProtoMessage

func (*MsgRefundServiceDeposit) ProtoMessage()

func (*MsgRefundServiceDeposit) Reset

func (m *MsgRefundServiceDeposit) Reset()

func (MsgRefundServiceDeposit) Route

func (msg MsgRefundServiceDeposit) Route() string

Route implements Msg.

func (*MsgRefundServiceDeposit) Size

func (m *MsgRefundServiceDeposit) Size() (n int)

func (*MsgRefundServiceDeposit) String

func (m *MsgRefundServiceDeposit) String() string

func (MsgRefundServiceDeposit) Type

func (msg MsgRefundServiceDeposit) Type() string

Type implements Msg.

func (*MsgRefundServiceDeposit) Unmarshal

func (m *MsgRefundServiceDeposit) Unmarshal(dAtA []byte) error

func (MsgRefundServiceDeposit) ValidateBasic

func (msg MsgRefundServiceDeposit) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgRefundServiceDeposit) XXX_DiscardUnknown

func (m *MsgRefundServiceDeposit) XXX_DiscardUnknown()

func (*MsgRefundServiceDeposit) XXX_Marshal

func (m *MsgRefundServiceDeposit) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgRefundServiceDeposit) XXX_Merge

func (m *MsgRefundServiceDeposit) XXX_Merge(src proto.Message)

func (*MsgRefundServiceDeposit) XXX_Size

func (m *MsgRefundServiceDeposit) XXX_Size() int

func (*MsgRefundServiceDeposit) XXX_Unmarshal

func (m *MsgRefundServiceDeposit) XXX_Unmarshal(b []byte) error

type MsgRespondService

type MsgRespondService struct {
	RequestID github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 168-byte string literal not displayed */
	Provider  github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,2,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Result    string                                               `protobuf:"bytes,3,opt,name=result,proto3" json:"result,omitempty"`
	Output    string                                               `protobuf:"bytes,4,opt,name=output,proto3" json:"output,omitempty"`
}

MsgRespondService defines an SDK message to respond a service request.

func NewMsgRespondService

func NewMsgRespondService(
	requestID tmbytes.HexBytes,
	provider sdk.AccAddress,
	result string,
	output string,
) MsgRespondService

NewMsgRespondService creates a new MsgRespondService instance

func (*MsgRespondService) Descriptor

func (*MsgRespondService) Descriptor() ([]byte, []int)

func (MsgRespondService) GetSignBytes

func (msg MsgRespondService) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgRespondService) GetSigners

func (msg MsgRespondService) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgRespondService) Marshal

func (m *MsgRespondService) Marshal() (dAtA []byte, err error)

func (*MsgRespondService) MarshalTo

func (m *MsgRespondService) MarshalTo(dAtA []byte) (int, error)

func (*MsgRespondService) MarshalToSizedBuffer

func (m *MsgRespondService) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgRespondService) ProtoMessage

func (*MsgRespondService) ProtoMessage()

func (*MsgRespondService) Reset

func (m *MsgRespondService) Reset()

func (MsgRespondService) Route

func (msg MsgRespondService) Route() string

Route implements Msg.

func (*MsgRespondService) Size

func (m *MsgRespondService) Size() (n int)

func (*MsgRespondService) String

func (m *MsgRespondService) String() string

func (MsgRespondService) Type

func (msg MsgRespondService) Type() string

Type implements Msg.

func (*MsgRespondService) Unmarshal

func (m *MsgRespondService) Unmarshal(dAtA []byte) error

func (MsgRespondService) ValidateBasic

func (msg MsgRespondService) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgRespondService) XXX_DiscardUnknown

func (m *MsgRespondService) XXX_DiscardUnknown()

func (*MsgRespondService) XXX_Marshal

func (m *MsgRespondService) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgRespondService) XXX_Merge

func (m *MsgRespondService) XXX_Merge(src proto.Message)

func (*MsgRespondService) XXX_Size

func (m *MsgRespondService) XXX_Size() int

func (*MsgRespondService) XXX_Unmarshal

func (m *MsgRespondService) XXX_Unmarshal(b []byte) error

type MsgSetWithdrawAddress

type MsgSetWithdrawAddress struct {
	Owner           github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,1,opt,name=owner,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"owner,omitempty"`
	WithdrawAddress github_com_cosmos_cosmos_sdk_types.AccAddress `` /* 185-byte string literal not displayed */
}

MsgSetWithdrawAddress defines an SDK message to set the withdrawal address for a provider.

func NewMsgSetWithdrawAddress

func NewMsgSetWithdrawAddress(owner, withdrawAddr sdk.AccAddress) MsgSetWithdrawAddress

NewMsgSetWithdrawAddress creates a new MsgSetWithdrawAddress instance

func (*MsgSetWithdrawAddress) Descriptor

func (*MsgSetWithdrawAddress) Descriptor() ([]byte, []int)

func (MsgSetWithdrawAddress) GetSignBytes

func (msg MsgSetWithdrawAddress) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgSetWithdrawAddress) GetSigners

func (msg MsgSetWithdrawAddress) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgSetWithdrawAddress) Marshal

func (m *MsgSetWithdrawAddress) Marshal() (dAtA []byte, err error)

func (*MsgSetWithdrawAddress) MarshalTo

func (m *MsgSetWithdrawAddress) MarshalTo(dAtA []byte) (int, error)

func (*MsgSetWithdrawAddress) MarshalToSizedBuffer

func (m *MsgSetWithdrawAddress) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgSetWithdrawAddress) ProtoMessage

func (*MsgSetWithdrawAddress) ProtoMessage()

func (*MsgSetWithdrawAddress) Reset

func (m *MsgSetWithdrawAddress) Reset()

func (MsgSetWithdrawAddress) Route

func (msg MsgSetWithdrawAddress) Route() string

Route implements Msg.

func (*MsgSetWithdrawAddress) Size

func (m *MsgSetWithdrawAddress) Size() (n int)

func (*MsgSetWithdrawAddress) String

func (m *MsgSetWithdrawAddress) String() string

func (MsgSetWithdrawAddress) Type

func (msg MsgSetWithdrawAddress) Type() string

Type implements Msg.

func (*MsgSetWithdrawAddress) Unmarshal

func (m *MsgSetWithdrawAddress) Unmarshal(dAtA []byte) error

func (MsgSetWithdrawAddress) ValidateBasic

func (msg MsgSetWithdrawAddress) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgSetWithdrawAddress) XXX_DiscardUnknown

func (m *MsgSetWithdrawAddress) XXX_DiscardUnknown()

func (*MsgSetWithdrawAddress) XXX_Marshal

func (m *MsgSetWithdrawAddress) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgSetWithdrawAddress) XXX_Merge

func (m *MsgSetWithdrawAddress) XXX_Merge(src proto.Message)

func (*MsgSetWithdrawAddress) XXX_Size

func (m *MsgSetWithdrawAddress) XXX_Size() int

func (*MsgSetWithdrawAddress) XXX_Unmarshal

func (m *MsgSetWithdrawAddress) XXX_Unmarshal(b []byte) error

type MsgStartRequestContext

type MsgStartRequestContext struct {
	RequestContextID github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 199-byte string literal not displayed */
	Consumer         github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,2,opt,name=consumer,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"consumer,omitempty"`
}

MsgStartRequestContext defines an SDK message to resume a service request.

func NewMsgStartRequestContext

func NewMsgStartRequestContext(requestContextID tmbytes.HexBytes, consumer sdk.AccAddress) MsgStartRequestContext

NewMsgStartRequestContext creates a new MsgStartRequestContext instance

func (*MsgStartRequestContext) Descriptor

func (*MsgStartRequestContext) Descriptor() ([]byte, []int)

func (MsgStartRequestContext) GetSignBytes

func (msg MsgStartRequestContext) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgStartRequestContext) GetSigners

func (msg MsgStartRequestContext) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgStartRequestContext) Marshal

func (m *MsgStartRequestContext) Marshal() (dAtA []byte, err error)

func (*MsgStartRequestContext) MarshalTo

func (m *MsgStartRequestContext) MarshalTo(dAtA []byte) (int, error)

func (*MsgStartRequestContext) MarshalToSizedBuffer

func (m *MsgStartRequestContext) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgStartRequestContext) ProtoMessage

func (*MsgStartRequestContext) ProtoMessage()

func (*MsgStartRequestContext) Reset

func (m *MsgStartRequestContext) Reset()

func (MsgStartRequestContext) Route

func (msg MsgStartRequestContext) Route() string

Route implements Msg.

func (*MsgStartRequestContext) Size

func (m *MsgStartRequestContext) Size() (n int)

func (*MsgStartRequestContext) String

func (m *MsgStartRequestContext) String() string

func (MsgStartRequestContext) Type

func (msg MsgStartRequestContext) Type() string

Type implements Msg.

func (*MsgStartRequestContext) Unmarshal

func (m *MsgStartRequestContext) Unmarshal(dAtA []byte) error

func (MsgStartRequestContext) ValidateBasic

func (msg MsgStartRequestContext) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgStartRequestContext) XXX_DiscardUnknown

func (m *MsgStartRequestContext) XXX_DiscardUnknown()

func (*MsgStartRequestContext) XXX_Marshal

func (m *MsgStartRequestContext) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgStartRequestContext) XXX_Merge

func (m *MsgStartRequestContext) XXX_Merge(src proto.Message)

func (*MsgStartRequestContext) XXX_Size

func (m *MsgStartRequestContext) XXX_Size() int

func (*MsgStartRequestContext) XXX_Unmarshal

func (m *MsgStartRequestContext) XXX_Unmarshal(b []byte) error

type MsgUpdateRequestContext

type MsgUpdateRequestContext struct {
	RequestContextID  github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 199-byte string literal not displayed */
	Providers         []github_com_cosmos_cosmos_sdk_types.AccAddress      `` /* 126-byte string literal not displayed */
	Consumer          github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,3,opt,name=consumer,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"consumer,omitempty"`
	ServiceFeeCap     github_com_cosmos_cosmos_sdk_types.Coins             `` /* 169-byte string literal not displayed */
	Timeout           int64                                                `protobuf:"varint,5,opt,name=timeout,proto3" json:"timeout,omitempty"`
	RepeatedFrequency uint64                                               `` /* 139-byte string literal not displayed */
	RepeatedTotal     int64                                                `protobuf:"varint,7,opt,name=repeated_total,json=repeatedTotal,proto3" json:"repeated_total,omitempty" yaml:"repeated_total"`
}

MsgUpdateRequestContext defines an SDK message to update a service request context.

func NewMsgUpdateRequestContext

func NewMsgUpdateRequestContext(
	requestContextID tmbytes.HexBytes,
	providers []sdk.AccAddress,
	serviceFeeCap sdk.Coins,
	timeout int64,
	repeatedFrequency uint64,
	repeatedTotal int64,
	consumer sdk.AccAddress,
) MsgUpdateRequestContext

NewMsgUpdateRequestContext creates a new MsgUpdateRequestContext instance

func (*MsgUpdateRequestContext) Descriptor

func (*MsgUpdateRequestContext) Descriptor() ([]byte, []int)

func (MsgUpdateRequestContext) GetSignBytes

func (msg MsgUpdateRequestContext) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgUpdateRequestContext) GetSigners

func (msg MsgUpdateRequestContext) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgUpdateRequestContext) Marshal

func (m *MsgUpdateRequestContext) Marshal() (dAtA []byte, err error)

func (*MsgUpdateRequestContext) MarshalTo

func (m *MsgUpdateRequestContext) MarshalTo(dAtA []byte) (int, error)

func (*MsgUpdateRequestContext) MarshalToSizedBuffer

func (m *MsgUpdateRequestContext) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgUpdateRequestContext) ProtoMessage

func (*MsgUpdateRequestContext) ProtoMessage()

func (*MsgUpdateRequestContext) Reset

func (m *MsgUpdateRequestContext) Reset()

func (MsgUpdateRequestContext) Route

func (msg MsgUpdateRequestContext) Route() string

Route implements Msg.

func (*MsgUpdateRequestContext) Size

func (m *MsgUpdateRequestContext) Size() (n int)

func (*MsgUpdateRequestContext) String

func (m *MsgUpdateRequestContext) String() string

func (MsgUpdateRequestContext) Type

func (msg MsgUpdateRequestContext) Type() string

Type implements Msg.

func (*MsgUpdateRequestContext) Unmarshal

func (m *MsgUpdateRequestContext) Unmarshal(dAtA []byte) error

func (MsgUpdateRequestContext) ValidateBasic

func (msg MsgUpdateRequestContext) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgUpdateRequestContext) XXX_DiscardUnknown

func (m *MsgUpdateRequestContext) XXX_DiscardUnknown()

func (*MsgUpdateRequestContext) XXX_Marshal

func (m *MsgUpdateRequestContext) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgUpdateRequestContext) XXX_Merge

func (m *MsgUpdateRequestContext) XXX_Merge(src proto.Message)

func (*MsgUpdateRequestContext) XXX_Size

func (m *MsgUpdateRequestContext) XXX_Size() int

func (*MsgUpdateRequestContext) XXX_Unmarshal

func (m *MsgUpdateRequestContext) XXX_Unmarshal(b []byte) error

type MsgUpdateServiceBinding

type MsgUpdateServiceBinding struct {
	ServiceName string                                        `protobuf:"bytes,1,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty"`
	Provider    github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,2,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Deposit     github_com_cosmos_cosmos_sdk_types.Coins      `protobuf:"bytes,3,rep,name=deposit,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"deposit"`
	Pricing     string                                        `protobuf:"bytes,4,opt,name=pricing,proto3" json:"pricing,omitempty"`
	QoS         uint64                                        `protobuf:"varint,5,opt,name=qos,proto3" json:"qos,omitempty"`
	Owner       github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,6,opt,name=owner,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"owner,omitempty"`
}

MsgUpdateServiceBinding defines an SDK message for updating an existing service binding.

func NewMsgUpdateServiceBinding

func NewMsgUpdateServiceBinding(
	serviceName string,
	provider sdk.AccAddress,
	deposit sdk.Coins,
	pricing string,
	qos uint64,
	owner sdk.AccAddress,
) MsgUpdateServiceBinding

NewMsgUpdateServiceBinding creates a new MsgUpdateServiceBinding instance

func (*MsgUpdateServiceBinding) Descriptor

func (*MsgUpdateServiceBinding) Descriptor() ([]byte, []int)

func (MsgUpdateServiceBinding) GetSignBytes

func (msg MsgUpdateServiceBinding) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgUpdateServiceBinding) GetSigners

func (msg MsgUpdateServiceBinding) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgUpdateServiceBinding) Marshal

func (m *MsgUpdateServiceBinding) Marshal() (dAtA []byte, err error)

func (*MsgUpdateServiceBinding) MarshalTo

func (m *MsgUpdateServiceBinding) MarshalTo(dAtA []byte) (int, error)

func (*MsgUpdateServiceBinding) MarshalToSizedBuffer

func (m *MsgUpdateServiceBinding) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgUpdateServiceBinding) ProtoMessage

func (*MsgUpdateServiceBinding) ProtoMessage()

func (*MsgUpdateServiceBinding) Reset

func (m *MsgUpdateServiceBinding) Reset()

func (MsgUpdateServiceBinding) Route

func (msg MsgUpdateServiceBinding) Route() string

Route implements Msg.

func (*MsgUpdateServiceBinding) Size

func (m *MsgUpdateServiceBinding) Size() (n int)

func (*MsgUpdateServiceBinding) String

func (m *MsgUpdateServiceBinding) String() string

func (MsgUpdateServiceBinding) Type

func (msg MsgUpdateServiceBinding) Type() string

Type implements Msg.

func (*MsgUpdateServiceBinding) Unmarshal

func (m *MsgUpdateServiceBinding) Unmarshal(dAtA []byte) error

func (MsgUpdateServiceBinding) ValidateBasic

func (msg MsgUpdateServiceBinding) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgUpdateServiceBinding) XXX_DiscardUnknown

func (m *MsgUpdateServiceBinding) XXX_DiscardUnknown()

func (*MsgUpdateServiceBinding) XXX_Marshal

func (m *MsgUpdateServiceBinding) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgUpdateServiceBinding) XXX_Merge

func (m *MsgUpdateServiceBinding) XXX_Merge(src proto.Message)

func (*MsgUpdateServiceBinding) XXX_Size

func (m *MsgUpdateServiceBinding) XXX_Size() int

func (*MsgUpdateServiceBinding) XXX_Unmarshal

func (m *MsgUpdateServiceBinding) XXX_Unmarshal(b []byte) error

type MsgWithdrawEarnedFees

type MsgWithdrawEarnedFees struct {
	Owner    github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,1,opt,name=owner,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"owner,omitempty"`
	Provider github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,2,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
}

MsgWithdrawEarnedFees defines an SDK message to withdraw the fees earned by the provider or owner.

func NewMsgWithdrawEarnedFees

func NewMsgWithdrawEarnedFees(owner, provider sdk.AccAddress) MsgWithdrawEarnedFees

NewMsgWithdrawEarnedFees creates a new MsgWithdrawEarnedFees instance

func (*MsgWithdrawEarnedFees) Descriptor

func (*MsgWithdrawEarnedFees) Descriptor() ([]byte, []int)

func (MsgWithdrawEarnedFees) GetSignBytes

func (msg MsgWithdrawEarnedFees) GetSignBytes() []byte

GetSignBytes implements Msg.

func (MsgWithdrawEarnedFees) GetSigners

func (msg MsgWithdrawEarnedFees) GetSigners() []sdk.AccAddress

GetSigners implements Msg.

func (*MsgWithdrawEarnedFees) Marshal

func (m *MsgWithdrawEarnedFees) Marshal() (dAtA []byte, err error)

func (*MsgWithdrawEarnedFees) MarshalTo

func (m *MsgWithdrawEarnedFees) MarshalTo(dAtA []byte) (int, error)

func (*MsgWithdrawEarnedFees) MarshalToSizedBuffer

func (m *MsgWithdrawEarnedFees) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgWithdrawEarnedFees) ProtoMessage

func (*MsgWithdrawEarnedFees) ProtoMessage()

func (*MsgWithdrawEarnedFees) Reset

func (m *MsgWithdrawEarnedFees) Reset()

func (MsgWithdrawEarnedFees) Route

func (msg MsgWithdrawEarnedFees) Route() string

Route implements Msg.

func (*MsgWithdrawEarnedFees) Size

func (m *MsgWithdrawEarnedFees) Size() (n int)

func (*MsgWithdrawEarnedFees) String

func (m *MsgWithdrawEarnedFees) String() string

func (MsgWithdrawEarnedFees) Type

func (msg MsgWithdrawEarnedFees) Type() string

Type implements Msg.

func (*MsgWithdrawEarnedFees) Unmarshal

func (m *MsgWithdrawEarnedFees) Unmarshal(dAtA []byte) error

func (MsgWithdrawEarnedFees) ValidateBasic

func (msg MsgWithdrawEarnedFees) ValidateBasic() error

ValidateBasic implements Msg.

func (*MsgWithdrawEarnedFees) XXX_DiscardUnknown

func (m *MsgWithdrawEarnedFees) XXX_DiscardUnknown()

func (*MsgWithdrawEarnedFees) XXX_Marshal

func (m *MsgWithdrawEarnedFees) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgWithdrawEarnedFees) XXX_Merge

func (m *MsgWithdrawEarnedFees) XXX_Merge(src proto.Message)

func (*MsgWithdrawEarnedFees) XXX_Size

func (m *MsgWithdrawEarnedFees) XXX_Size() int

func (*MsgWithdrawEarnedFees) XXX_Unmarshal

func (m *MsgWithdrawEarnedFees) XXX_Unmarshal(b []byte) error

type Params

type Params struct {
	MaxRequestTimeout    int64                                    `` /* 142-byte string literal not displayed */
	MinDepositMultiple   int64                                    `` /* 146-byte string literal not displayed */
	MinDeposit           github_com_cosmos_cosmos_sdk_types.Coins `` /* 135-byte string literal not displayed */
	ServiceFeeTax        github_com_cosmos_cosmos_sdk_types.Dec   `` /* 165-byte string literal not displayed */
	SlashFraction        github_com_cosmos_cosmos_sdk_types.Dec   `` /* 162-byte string literal not displayed */
	ComplaintRetrospect  time.Duration                            `` /* 148-byte string literal not displayed */
	ArbitrationTimeLimit time.Duration                            `` /* 155-byte string literal not displayed */
	TxSizeLimit          uint64                                   `protobuf:"varint,8,opt,name=tx_size_limit,json=txSizeLimit,proto3" json:"tx_size_limit,omitempty" yaml:"tx_size_limit"`
	BaseDenom            string                                   `protobuf:"bytes,9,opt,name=base_denom,json=baseDenom,proto3" json:"base_denom,omitempty" yaml:"base_denom"`
}

service parameters

func DefaultParams

func DefaultParams() Params

DefaultParams returns a default set of parameters.

func NewParams

func NewParams(
	maxRequestTimeout,
	minDepositMultiple int64,
	minDeposit sdk.Coins,
	serviceFeeTax,
	slashFraction sdk.Dec,
	complaintRetrospect,
	arbitrationTimeLimit time.Duration,
	txSizeLimit uint64,
	baseDenom string,
) Params

NewParams creates a new Params instance

func (*Params) Descriptor

func (*Params) Descriptor() ([]byte, []int)

func (*Params) Equal

func (this *Params) Equal(that interface{}) bool

func (*Params) Marshal

func (m *Params) Marshal() (dAtA []byte, err error)

func (*Params) MarshalTo

func (m *Params) MarshalTo(dAtA []byte) (int, error)

func (*Params) MarshalToSizedBuffer

func (m *Params) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Params) ParamSetPairs

func (p *Params) ParamSetPairs() params.ParamSetPairs

ParamSetPairs implements params.ParamSet

func (*Params) ProtoMessage

func (*Params) ProtoMessage()

func (*Params) Reset

func (m *Params) Reset()

func (*Params) Size

func (m *Params) Size() (n int)

func (Params) String

func (p Params) String() string

String implements stringer

func (*Params) Unmarshal

func (m *Params) Unmarshal(dAtA []byte) error

func (Params) Validate

func (p Params) Validate() error

Validate validates a set of params

func (*Params) XXX_DiscardUnknown

func (m *Params) XXX_DiscardUnknown()

func (*Params) XXX_Marshal

func (m *Params) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Params) XXX_Merge

func (m *Params) XXX_Merge(src proto.Message)

func (*Params) XXX_Size

func (m *Params) XXX_Size() int

func (*Params) XXX_Unmarshal

func (m *Params) XXX_Unmarshal(b []byte) error

type Pricing

type Pricing struct {
	Price              github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,6,rep,name=price,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"price"`
	PromotionsByTime   []PromotionByTime                        `` /* 127-byte string literal not displayed */
	PromotionsByVolume []PromotionByVolume                      `` /* 135-byte string literal not displayed */
}

Pricing defines a standard for service pricing.

func (*Pricing) Descriptor

func (*Pricing) Descriptor() ([]byte, []int)

func (*Pricing) Marshal

func (m *Pricing) Marshal() (dAtA []byte, err error)

func (*Pricing) MarshalTo

func (m *Pricing) MarshalTo(dAtA []byte) (int, error)

func (*Pricing) MarshalToSizedBuffer

func (m *Pricing) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Pricing) ProtoMessage

func (*Pricing) ProtoMessage()

func (*Pricing) Reset

func (m *Pricing) Reset()

func (*Pricing) Size

func (m *Pricing) Size() (n int)

func (*Pricing) String

func (m *Pricing) String() string

func (*Pricing) Unmarshal

func (m *Pricing) Unmarshal(dAtA []byte) error

func (*Pricing) XXX_DiscardUnknown

func (m *Pricing) XXX_DiscardUnknown()

func (*Pricing) XXX_Marshal

func (m *Pricing) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Pricing) XXX_Merge

func (m *Pricing) XXX_Merge(src proto.Message)

func (*Pricing) XXX_Size

func (m *Pricing) XXX_Size() int

func (*Pricing) XXX_Unmarshal

func (m *Pricing) XXX_Unmarshal(b []byte) error

type PromotionByTime

type PromotionByTime struct {
	StartTime time.Time                              `protobuf:"bytes,1,opt,name=start_time,json=startTime,proto3,stdtime" json:"start_time" yaml:"start_time"`
	EndTime   time.Time                              `protobuf:"bytes,2,opt,name=end_time,json=endTime,proto3,stdtime" json:"end_time" yaml:"end_time"`
	Discount  github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,3,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
}

PromotionByTime defines a standard for service promotion by time.

func (*PromotionByTime) Descriptor

func (*PromotionByTime) Descriptor() ([]byte, []int)

func (*PromotionByTime) Marshal

func (m *PromotionByTime) Marshal() (dAtA []byte, err error)

func (*PromotionByTime) MarshalTo

func (m *PromotionByTime) MarshalTo(dAtA []byte) (int, error)

func (*PromotionByTime) MarshalToSizedBuffer

func (m *PromotionByTime) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*PromotionByTime) ProtoMessage

func (*PromotionByTime) ProtoMessage()

func (*PromotionByTime) Reset

func (m *PromotionByTime) Reset()

func (*PromotionByTime) Size

func (m *PromotionByTime) Size() (n int)

func (*PromotionByTime) String

func (m *PromotionByTime) String() string

func (*PromotionByTime) Unmarshal

func (m *PromotionByTime) Unmarshal(dAtA []byte) error

func (*PromotionByTime) XXX_DiscardUnknown

func (m *PromotionByTime) XXX_DiscardUnknown()

func (*PromotionByTime) XXX_Marshal

func (m *PromotionByTime) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*PromotionByTime) XXX_Merge

func (m *PromotionByTime) XXX_Merge(src proto.Message)

func (*PromotionByTime) XXX_Size

func (m *PromotionByTime) XXX_Size() int

func (*PromotionByTime) XXX_Unmarshal

func (m *PromotionByTime) XXX_Unmarshal(b []byte) error

type PromotionByVolume

type PromotionByVolume struct {
	Volume   uint64                                 `protobuf:"varint,1,opt,name=volume,proto3" json:"volume,omitempty"`
	Discount github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,2,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
}

PromotionByVolume defines a standard for service promotion by volume.

func (*PromotionByVolume) Descriptor

func (*PromotionByVolume) Descriptor() ([]byte, []int)

func (*PromotionByVolume) Marshal

func (m *PromotionByVolume) Marshal() (dAtA []byte, err error)

func (*PromotionByVolume) MarshalTo

func (m *PromotionByVolume) MarshalTo(dAtA []byte) (int, error)

func (*PromotionByVolume) MarshalToSizedBuffer

func (m *PromotionByVolume) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*PromotionByVolume) ProtoMessage

func (*PromotionByVolume) ProtoMessage()

func (*PromotionByVolume) Reset

func (m *PromotionByVolume) Reset()

func (*PromotionByVolume) Size

func (m *PromotionByVolume) Size() (n int)

func (*PromotionByVolume) String

func (m *PromotionByVolume) String() string

func (*PromotionByVolume) Unmarshal

func (m *PromotionByVolume) Unmarshal(dAtA []byte) error

func (*PromotionByVolume) XXX_DiscardUnknown

func (m *PromotionByVolume) XXX_DiscardUnknown()

func (*PromotionByVolume) XXX_Marshal

func (m *PromotionByVolume) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*PromotionByVolume) XXX_Merge

func (m *PromotionByVolume) XXX_Merge(src proto.Message)

func (*PromotionByVolume) XXX_Size

func (m *PromotionByVolume) XXX_Size() int

func (*PromotionByVolume) XXX_Unmarshal

func (m *PromotionByVolume) XXX_Unmarshal(b []byte) error

type QueryBindingParams

type QueryBindingParams struct {
	ServiceName string
	Provider    sdk.AccAddress
}

QueryBindingParams defines the params to query a service binding

type QueryBindingsParams

type QueryBindingsParams struct {
	ServiceName string
	Owner       sdk.AccAddress
}

QueryBindingsParams defines the params to query all bindings of a service definition with an optional owner

type QueryDefinitionParams

type QueryDefinitionParams struct {
	ServiceName string
}

QueryDefinitionParams defines the params to query a service definition

type QueryEarnedFeesParams

type QueryEarnedFeesParams struct {
	Provider sdk.AccAddress
}

QueryEarnedFeesParams defines the params to query the earned fees for a provider

type QueryRequestContextParams

type QueryRequestContextParams struct {
	RequestContextID tmbytes.HexBytes
}

QueryRequestContextParams defines the params to query the request context

type QueryRequestParams

type QueryRequestParams struct {
	RequestID []byte
}

QueryRequestParams defines the params to query the request by ID

type QueryRequestsByReqCtxParams

type QueryRequestsByReqCtxParams struct {
	RequestContextID tmbytes.HexBytes
	BatchCounter     uint64
}

QueryRequestsByReqCtxParams defines the params to query active requests by the request context ID

type QueryRequestsParams

type QueryRequestsParams struct {
	ServiceName string
	Provider    sdk.AccAddress
}

QueryRequestsParams defines the params to query active requests for a service binding

type QueryResponseParams

type QueryResponseParams struct {
	RequestID tmbytes.HexBytes
}

QueryResponseParams defines the params to query the response to a request

type QueryResponsesParams

type QueryResponsesParams struct {
	RequestContextID tmbytes.HexBytes
	BatchCounter     uint64
}

QueryResponsesParams defines the params to query active responses by the request context ID

type QuerySchemaParams

type QuerySchemaParams struct {
	SchemaName string
}

QuerySchemaParams defines the params to query the system schemas by the schema name

type QueryWithdrawAddressParams

type QueryWithdrawAddressParams struct {
	Owner sdk.AccAddress
}

QueryWithdrawAddressParams defines the params to query the withdrawal address of an owner

type RawPricing

type RawPricing struct {
	Price              string              `json:"price"`                // base price string
	PromotionsByTime   []PromotionByTime   `json:"promotions_by_time"`   // promotions by time
	PromotionsByVolume []PromotionByVolume `json:"promotions_by_volume"` // promotions by volume
}

RawPricing represents the raw pricing of a service binding

type Request

type Request struct {
	ID                         github_com_tendermint_tendermint_libs_bytes.HexBytes `protobuf:"bytes,1,opt,name=id,proto3,casttype=github.com/tendermint/tendermint/libs/bytes.HexBytes" json:"id,omitempty"`
	ServiceName                string                                               `protobuf:"bytes,2,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty" yaml:"service_name"`
	Provider                   github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,3,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Consumer                   github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,4,opt,name=consumer,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"consumer,omitempty"`
	Input                      string                                               `protobuf:"bytes,5,opt,name=input,proto3" json:"input,omitempty"`
	ServiceFee                 github_com_cosmos_cosmos_sdk_types.Coins             `` /* 154-byte string literal not displayed */
	SuperMode                  bool                                                 `protobuf:"varint,7,opt,name=super_mode,json=superMode,proto3" json:"super_mode,omitempty" yaml:"super_mode"`
	RequestHeight              int64                                                `protobuf:"varint,8,opt,name=request_height,json=requestHeight,proto3" json:"request_height,omitempty" yaml:"request_height"`
	ExpirationHeight           int64                                                `` /* 135-byte string literal not displayed */
	RequestContextID           github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 200-byte string literal not displayed */
	RequestContextBatchCounter uint64                                               `` /* 182-byte string literal not displayed */
}

Request defines a standard for request.

func NewRequest

func NewRequest(
	id tmbytes.HexBytes,
	serviceName string,
	provider,
	consumer sdk.AccAddress,
	input string,
	serviceFee sdk.Coins,
	superMode bool,
	requestHeight int64,
	expirationHeight int64,
	requestContextID tmbytes.HexBytes,
	batchCounter uint64,
) Request

NewRequest creates a new Request instance

func (*Request) Descriptor

func (*Request) Descriptor() ([]byte, []int)

func (Request) Empty

func (r Request) Empty() bool

Empty returns true if empty

func (*Request) Marshal

func (m *Request) Marshal() (dAtA []byte, err error)

func (*Request) MarshalTo

func (m *Request) MarshalTo(dAtA []byte) (int, error)

func (*Request) MarshalToSizedBuffer

func (m *Request) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Request) ProtoMessage

func (*Request) ProtoMessage()

func (*Request) Reset

func (m *Request) Reset()

func (*Request) Size

func (m *Request) Size() (n int)

func (*Request) String

func (m *Request) String() string

func (*Request) Unmarshal

func (m *Request) Unmarshal(dAtA []byte) error

func (*Request) XXX_DiscardUnknown

func (m *Request) XXX_DiscardUnknown()

func (*Request) XXX_Marshal

func (m *Request) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Request) XXX_Merge

func (m *Request) XXX_Merge(src proto.Message)

func (*Request) XXX_Size

func (m *Request) XXX_Size() int

func (*Request) XXX_Unmarshal

func (m *Request) XXX_Unmarshal(b []byte) error

type RequestContext

type RequestContext struct {
	ServiceName            string                                          `protobuf:"bytes,1,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty" yaml:"service_name"`
	Providers              []github_com_cosmos_cosmos_sdk_types.AccAddress `` /* 126-byte string literal not displayed */
	Consumer               github_com_cosmos_cosmos_sdk_types.AccAddress   `protobuf:"bytes,3,opt,name=consumer,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"consumer,omitempty"`
	Input                  string                                          `protobuf:"bytes,4,opt,name=input,proto3" json:"input,omitempty"`
	ServiceFeeCap          github_com_cosmos_cosmos_sdk_types.Coins        `` /* 169-byte string literal not displayed */
	ModuleName             string                                          `protobuf:"bytes,6,opt,name=module_name,json=moduleName,proto3" json:"module_name,omitempty" yaml:"module_name"`
	Timeout                int64                                           `protobuf:"varint,7,opt,name=timeout,proto3" json:"timeout,omitempty"`
	SuperMode              bool                                            `protobuf:"varint,8,opt,name=super_mode,json=superMode,proto3" json:"super_mode,omitempty" yaml:"super_mode"`
	Repeated               bool                                            `protobuf:"varint,9,opt,name=repeated,proto3" json:"repeated,omitempty"`
	RepeatedFrequency      uint64                                          `` /* 140-byte string literal not displayed */
	RepeatedTotal          int64                                           `protobuf:"varint,11,opt,name=repeated_total,json=repeatedTotal,proto3" json:"repeated_total,omitempty" yaml:"repeated_total"`
	BatchCounter           uint64                                          `protobuf:"varint,12,opt,name=batch_counter,json=batchCounter,proto3" json:"batch_counter,omitempty" yaml:"batch_counter"`
	BatchRequestCount      uint32                                          `` /* 143-byte string literal not displayed */
	BatchResponseCount     uint32                                          `` /* 147-byte string literal not displayed */
	BatchResponseThreshold uint32                                          `` /* 163-byte string literal not displayed */
	ResponseThreshold      uint32                                          `` /* 140-byte string literal not displayed */
	BatchState             RequestContextBatchState                        `` /* 158-byte string literal not displayed */
	State                  RequestContextState                             `protobuf:"varint,18,opt,name=state,proto3,enum=irismod.service.RequestContextState" json:"state,omitempty"`
}

RequestContext defines a standard for request context.

func NewRequestContext

func NewRequestContext(
	serviceName string,
	providers []sdk.AccAddress,
	consumer sdk.AccAddress,
	input string,
	serviceFeeCap sdk.Coins,
	timeout int64,
	superMode bool,
	repeated bool,
	repeatedFrequency uint64,
	repeatedTotal int64,
	batchCounter uint64,
	batchRequestCount,
	batchResponseCount uint32,
	batchResponseThreshold uint32,
	batchState RequestContextBatchState,
	state RequestContextState,
	responseThreshold uint32,
	moduleName string,
) RequestContext

NewRequestContext creates a new RequestContext instance

func (*RequestContext) Descriptor

func (*RequestContext) Descriptor() ([]byte, []int)

func (RequestContext) Empty

func (rc RequestContext) Empty() bool

Empty returns true if empty

func (*RequestContext) Marshal

func (m *RequestContext) Marshal() (dAtA []byte, err error)

func (*RequestContext) MarshalTo

func (m *RequestContext) MarshalTo(dAtA []byte) (int, error)

func (*RequestContext) MarshalToSizedBuffer

func (m *RequestContext) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*RequestContext) ProtoMessage

func (*RequestContext) ProtoMessage()

func (*RequestContext) Reset

func (m *RequestContext) Reset()

func (*RequestContext) Size

func (m *RequestContext) Size() (n int)

func (*RequestContext) String

func (m *RequestContext) String() string

func (*RequestContext) Unmarshal

func (m *RequestContext) Unmarshal(dAtA []byte) error

func (RequestContext) Validate

func (rc RequestContext) Validate() error

Validate validates the request context

func (*RequestContext) XXX_DiscardUnknown

func (m *RequestContext) XXX_DiscardUnknown()

func (*RequestContext) XXX_Marshal

func (m *RequestContext) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*RequestContext) XXX_Merge

func (m *RequestContext) XXX_Merge(src proto.Message)

func (*RequestContext) XXX_Size

func (m *RequestContext) XXX_Size() int

func (*RequestContext) XXX_Unmarshal

func (m *RequestContext) XXX_Unmarshal(b []byte) error

type RequestContextBatchState

type RequestContextBatchState int32

RequestContextBatchState is a type alias that represents a request batch status as a byte

const (
	// BATCH_RUNNING defines the running batch status.
	BATCHRUNNING RequestContextBatchState = 0
	// BATCH_COMPLETED defines the completed batch status.
	BATCHCOMPLETED RequestContextBatchState = 1
)

func RequestContextBatchStateFromString

func RequestContextBatchStateFromString(str string) (RequestContextBatchState, error)

func (RequestContextBatchState) EnumDescriptor

func (RequestContextBatchState) EnumDescriptor() ([]byte, []int)

func (RequestContextBatchState) Format

func (state RequestContextBatchState) Format(s fmt.State, verb rune)

func (RequestContextBatchState) Marshal

func (state RequestContextBatchState) Marshal() ([]byte, error)

Marshal needed for protobuf compatibility

func (RequestContextBatchState) MarshalJSON

func (state RequestContextBatchState) MarshalJSON() ([]byte, error)

MarshalJSON returns the JSON representation

func (RequestContextBatchState) MarshalYAML

func (state RequestContextBatchState) MarshalYAML() (interface{}, error)

MarshalYAML returns the YAML representation

func (RequestContextBatchState) String

func (state RequestContextBatchState) String() string

func (*RequestContextBatchState) Unmarshal

func (state *RequestContextBatchState) Unmarshal(data []byte) error

Unmarshal needed for protobuf compatibility

func (*RequestContextBatchState) UnmarshalJSON

func (state *RequestContextBatchState) UnmarshalJSON(data []byte) error

UnmarshalJSON unmarshals raw JSON bytes into a RequestContextBatchState

type RequestContextState

type RequestContextState int32

RequestContextState is a type alias that represents a request status as a byte

const (
	// RUNNING defines the running request context status.
	RUNNING RequestContextState = 0
	// PAUSED defines the paused request context status.
	PAUSED RequestContextState = 1
	// COMPLETED defines the completed request context status.
	COMPLETED RequestContextState = 2
)

func RequestContextStateFromString

func RequestContextStateFromString(str string) (RequestContextState, error)

func (RequestContextState) EnumDescriptor

func (RequestContextState) EnumDescriptor() ([]byte, []int)

func (RequestContextState) Format

func (state RequestContextState) Format(s fmt.State, verb rune)

func (RequestContextState) Marshal

func (state RequestContextState) Marshal() ([]byte, error)

Marshal needed for protobuf compatibility

func (RequestContextState) MarshalJSON

func (state RequestContextState) MarshalJSON() ([]byte, error)

MarshalJSON returns the JSON representation

func (RequestContextState) MarshalYAML

func (state RequestContextState) MarshalYAML() (interface{}, error)

MarshalYAML returns the YAML representation

func (RequestContextState) String

func (state RequestContextState) String() string

func (*RequestContextState) Unmarshal

func (state *RequestContextState) Unmarshal(data []byte) error

Unmarshal needed for protobuf compatibility

func (*RequestContextState) UnmarshalJSON

func (state *RequestContextState) UnmarshalJSON(data []byte) error

UnmarshalJSON unmarshals raw JSON bytes into a RequestContextState.

type Response

type Response struct {
	Provider                   github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,1,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Consumer                   github_com_cosmos_cosmos_sdk_types.AccAddress        `protobuf:"bytes,2,opt,name=consumer,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"consumer,omitempty"`
	Result                     string                                               `protobuf:"bytes,3,opt,name=result,proto3" json:"result,omitempty"`
	Output                     string                                               `protobuf:"bytes,4,opt,name=output,proto3" json:"output,omitempty"`
	RequestContextID           github_com_tendermint_tendermint_libs_bytes.HexBytes `` /* 199-byte string literal not displayed */
	RequestContextBatchCounter uint64                                               `` /* 181-byte string literal not displayed */
}

Response defines a standard for response.

func NewResponse

func NewResponse(
	provider,
	consumer sdk.AccAddress,
	result,
	output string,
	requestContextID tmbytes.HexBytes,
	batchCounter uint64,
) Response

NewResponse creates a new Response instance

func (*Response) Descriptor

func (*Response) Descriptor() ([]byte, []int)

func (Response) Empty

func (r Response) Empty() bool

Empty returns true if empty

func (*Response) Marshal

func (m *Response) Marshal() (dAtA []byte, err error)

func (*Response) MarshalTo

func (m *Response) MarshalTo(dAtA []byte) (int, error)

func (*Response) MarshalToSizedBuffer

func (m *Response) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Response) ProtoMessage

func (*Response) ProtoMessage()

func (*Response) Reset

func (m *Response) Reset()

func (*Response) Size

func (m *Response) Size() (n int)

func (*Response) String

func (m *Response) String() string

func (*Response) Unmarshal

func (m *Response) Unmarshal(dAtA []byte) error

func (*Response) XXX_DiscardUnknown

func (m *Response) XXX_DiscardUnknown()

func (*Response) XXX_Marshal

func (m *Response) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Response) XXX_Merge

func (m *Response) XXX_Merge(src proto.Message)

func (*Response) XXX_Size

func (m *Response) XXX_Size() int

func (*Response) XXX_Unmarshal

func (m *Response) XXX_Unmarshal(b []byte) error

type ResponseCallback

type ResponseCallback func(ctx sdk.Context, requestContextID tmbytes.HexBytes, responses []string, err error)

ResponseCallback defines the response callback interface

type Result

type Result struct {
	Code    uint16 `json:"code"`
	Message string `json:"message"`
}

Result defines a struct for the response result

func ParseResult

func ParseResult(result string) (Result, error)

ParseResult parses the given string to Result

type ServiceBinding

type ServiceBinding struct {
	ServiceName  string                                        `protobuf:"bytes,1,opt,name=service_name,json=serviceName,proto3" json:"service_name,omitempty" yaml:"service_name"`
	Provider     github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,2,opt,name=provider,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"provider,omitempty"`
	Deposit      github_com_cosmos_cosmos_sdk_types.Coins      `protobuf:"bytes,3,rep,name=deposit,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"deposit"`
	Pricing      string                                        `protobuf:"bytes,4,opt,name=pricing,proto3" json:"pricing,omitempty"`
	QoS          uint64                                        `protobuf:"varint,5,opt,name=qos,proto3" json:"qos,omitempty"`
	Available    bool                                          `protobuf:"varint,6,opt,name=available,proto3" json:"available,omitempty"`
	DisabledTime time.Time                                     `protobuf:"bytes,7,opt,name=disabled_time,json=disabledTime,proto3,stdtime" json:"disabled_time" yaml:"disabled_time"`
	Owner        github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,8,opt,name=owner,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"owner,omitempty"`
}

ServiceBinding defines a standard for service binding.

func NewServiceBinding

func NewServiceBinding(
	serviceName string,
	provider sdk.AccAddress,
	deposit sdk.Coins,
	pricing string,
	qos uint64,
	available bool,
	disabledTime time.Time,
	owner sdk.AccAddress,
) ServiceBinding

NewServiceBinding creates a new ServiceBinding instance

func (*ServiceBinding) Descriptor

func (*ServiceBinding) Descriptor() ([]byte, []int)

func (*ServiceBinding) Marshal

func (m *ServiceBinding) Marshal() (dAtA []byte, err error)

func (*ServiceBinding) MarshalTo

func (m *ServiceBinding) MarshalTo(dAtA []byte) (int, error)

func (*ServiceBinding) MarshalToSizedBuffer

func (m *ServiceBinding) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*ServiceBinding) ProtoMessage

func (*ServiceBinding) ProtoMessage()

func (*ServiceBinding) Reset

func (m *ServiceBinding) Reset()

func (*ServiceBinding) Size

func (m *ServiceBinding) Size() (n int)

func (*ServiceBinding) String

func (m *ServiceBinding) String() string

func (*ServiceBinding) Unmarshal

func (m *ServiceBinding) Unmarshal(dAtA []byte) error

func (ServiceBinding) Validate

func (binding ServiceBinding) Validate() error

Validate validates the service binding

func (*ServiceBinding) XXX_DiscardUnknown

func (m *ServiceBinding) XXX_DiscardUnknown()

func (*ServiceBinding) XXX_Marshal

func (m *ServiceBinding) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*ServiceBinding) XXX_Merge

func (m *ServiceBinding) XXX_Merge(src proto.Message)

func (*ServiceBinding) XXX_Size

func (m *ServiceBinding) XXX_Size() int

func (*ServiceBinding) XXX_Unmarshal

func (m *ServiceBinding) XXX_Unmarshal(b []byte) error

type ServiceDefinition

type ServiceDefinition struct {
	Name              string                                        `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	Description       string                                        `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	Tags              []string                                      `protobuf:"bytes,3,rep,name=tags,proto3" json:"tags,omitempty"`
	Author            github_com_cosmos_cosmos_sdk_types.AccAddress `protobuf:"bytes,4,opt,name=author,proto3,casttype=github.com/cosmos/cosmos-sdk/types.AccAddress" json:"author,omitempty"`
	AuthorDescription string                                        `` /* 138-byte string literal not displayed */
	Schemas           string                                        `protobuf:"bytes,6,opt,name=schemas,proto3" json:"schemas,omitempty"`
}

ServiceDefinition defines a standard for service definition.

func NewServiceDefinition

func NewServiceDefinition(
	name string,
	description string,
	tags []string,
	author sdk.AccAddress,
	authorDescription,
	schemas string,
) ServiceDefinition

NewServiceDefinition creates a new ServiceDefinition instance

func (*ServiceDefinition) Descriptor

func (*ServiceDefinition) Descriptor() ([]byte, []int)

func (*ServiceDefinition) Marshal

func (m *ServiceDefinition) Marshal() (dAtA []byte, err error)

func (*ServiceDefinition) MarshalTo

func (m *ServiceDefinition) MarshalTo(dAtA []byte) (int, error)

func (*ServiceDefinition) MarshalToSizedBuffer

func (m *ServiceDefinition) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*ServiceDefinition) ProtoMessage

func (*ServiceDefinition) ProtoMessage()

func (*ServiceDefinition) Reset

func (m *ServiceDefinition) Reset()

func (*ServiceDefinition) Size

func (m *ServiceDefinition) Size() (n int)

func (*ServiceDefinition) String

func (m *ServiceDefinition) String() string

func (*ServiceDefinition) Unmarshal

func (m *ServiceDefinition) Unmarshal(dAtA []byte) error

func (ServiceDefinition) Validate

func (svcDef ServiceDefinition) Validate() error

Validate validates the service definition

func (*ServiceDefinition) XXX_DiscardUnknown

func (m *ServiceDefinition) XXX_DiscardUnknown()

func (*ServiceDefinition) XXX_Marshal

func (m *ServiceDefinition) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*ServiceDefinition) XXX_Merge

func (m *ServiceDefinition) XXX_Merge(src proto.Message)

func (*ServiceDefinition) XXX_Size

func (m *ServiceDefinition) XXX_Size() int

func (*ServiceDefinition) XXX_Unmarshal

func (m *ServiceDefinition) XXX_Unmarshal(b []byte) error

type ServiceSchemas

type ServiceSchemas struct {
	Input  map[string]interface{} `json:"input"`
	Output map[string]interface{} `json:"output"`
}

ServiceSchemas defines the service schemas

type StateCallback

type StateCallback func(ctx sdk.Context, requestContextID tmbytes.HexBytes, cause string)

StateCallback defines the state callback interface

type TokenI

type TokenI interface {
	GetMinUnit() string
	GetScale() uint32
}

TokenI defines the interface for Token

type TokenKeeper

type TokenKeeper interface {
	GetToken(ctx sdk.Context, denom string) (TokenI, error)
}

TokenKeeper defines the expected token keeper (noalias)

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL