nosqlplugin

package
v1.0.0 Latest Latest
Warning

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

Go to latest
Published: Mar 17, 2023 License: MIT Imports: 12 Imported by: 0

Documentation

Overview

Package nosqlplugin is a generated GoMock package.

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

func GetDefaultTestSchemaDir added in v0.24.0

func GetDefaultTestSchemaDir(testSchemaRelativePath string) (string, error)

func NewConditionFailure added in v0.22.0

func NewConditionFailure(name string) error

Types

type AdminDB added in v0.23.1

type AdminDB interface {
	SetupTestDatabase(schemaBaseDir string) error
	TeardownTestDatabase() error
}

AdminDB is for tooling and testing

type ClientErrorChecker added in v0.22.0

type ClientErrorChecker interface {
	IsTimeoutError(error) bool
	IsNotFoundError(error) bool
	IsThrottlingError(error) bool
	IsDBUnavailableError(error) bool
}

ClientErrorChecker checks for common nosql errors on client

type ConditionFailure added in v0.22.0

type ConditionFailure struct {
	// contains filtered or unexported fields
}

Condition Errors for NoSQL interfaces

func (*ConditionFailure) Error added in v0.22.0

func (e *ConditionFailure) Error() string

type ConfigStoreCRUD added in v0.23.1

type ConfigStoreCRUD interface {
	// InsertConfig insert a config entry with version. Return nosqlplugin.NewConditionFailure if the same version of the row_type is existing
	InsertConfig(ctx context.Context, row *persistence.InternalConfigStoreEntry) error
	// SelectLatestConfig returns the config entry of the row_type with the largest(latest) version value
	SelectLatestConfig(ctx context.Context, rowType int) (*persistence.InternalConfigStoreEntry, error)
}

**

  • ConfigStoreCRUD is for storing dynamic configuration parameters *
  • Recommendation: one table *
  • Significant columns:
  • domain: partition key(row_type), range key(version)

type ConflictedShardRow added in v0.22.0

type ConflictedShardRow struct {
	ShardID int
	// PreviousRangeID is the condition of previous change that used for conditional update
	PreviousRangeID int64
	// optional detailed information for logging purpose
	Details string
}

ConflictedShardRow contains the partial information about a shard returned when a conditional write fails

type CrossClusterTask added in v0.22.0

type CrossClusterTask struct {
	TransferTask
	TargetCluster string
}

CrossClusterTask is for cross cluster transfer task

type CurrentWorkflowRow added in v0.22.0

type CurrentWorkflowRow struct {
	ShardID          int
	DomainID         string
	WorkflowID       string
	RunID            string
	State            int
	CloseStatus      int
	CreateRequestID  string
	LastWriteVersion int64
}

CurrentWorkflowRow is the current_workflow row

type CurrentWorkflowWriteCondition added in v0.22.0

type CurrentWorkflowWriteCondition struct {
	CurrentRunID     *string
	LastWriteVersion *int64
	State            *int
}

CurrentWorkflowWriteCondition is the condition for updating current_workflow record

func (*CurrentWorkflowWriteCondition) GetCurrentRunID added in v0.22.0

func (w *CurrentWorkflowWriteCondition) GetCurrentRunID() string

GetCurrentRunID returns the current runID

type CurrentWorkflowWriteMode added in v0.22.0

type CurrentWorkflowWriteMode int

CurrentWorkflowWriteMode controls how to write current_workflow

const (
	CurrentWorkflowWriteModeNoop CurrentWorkflowWriteMode = iota
	CurrentWorkflowWriteModeUpdate
	CurrentWorkflowWriteModeInsert
)

enums of CurrentWorkflowWriteMode

type CurrentWorkflowWriteRequest added in v0.22.0

type CurrentWorkflowWriteRequest struct {
	WriteMode CurrentWorkflowWriteMode
	Row       CurrentWorkflowRow
	Condition *CurrentWorkflowWriteCondition
}

CurrentWorkflowWriteRequest is for insert/update current_workflow record

type DB

type DB interface {
	PluginName() string
	Close()

	ClientErrorChecker
	// contains filtered or unexported methods
}

DB defines the API for regular NoSQL operations of a Cadence server

type DomainCRUD added in v0.23.1

type DomainCRUD interface {
	// Insert a new record to domain
	// return types.DomainAlreadyExistsError error if failed or already exists
	// Must return ConditionFailure error if other condition doesn't match
	InsertDomain(ctx context.Context, row *DomainRow) error
	// Update domain data
	// Must return ConditionFailure error if update condition doesn't match
	UpdateDomain(ctx context.Context, row *DomainRow) error
	// Get one domain data, either by domainID or domainName
	SelectDomain(ctx context.Context, domainID *string, domainName *string) (*DomainRow, error)
	// Get all domain data
	SelectAllDomains(ctx context.Context, pageSize int, pageToken []byte) ([]*DomainRow, []byte, error)
	//  Delete a domain, either by domainID or domainName
	DeleteDomain(ctx context.Context, domainID *string, domainName *string) error
	// right now domain metadata is just an integer as notification version
	SelectDomainMetadata(ctx context.Context) (int64, error)
}

**

  • DomainCRUD is for domain + domain metadata storage system *
  • Recommendation: two tables(domain, domain_metadata) to implement if conditional updates on two tables is supported *
  • Significant columns:
  • domain: partition key( a constant value), range key(domainName), local secondary index(domainID)
  • domain_metadata: partition key( a constant value), range key(N/A), query condition column(notificationVersion) *
  • Note 1: About Cassandra's implementation: Because of historical reasons, Cassandra uses two table,
  • domains and domains_by_name_v2. Therefore, Cassandra implementation lost the atomicity causing some edge cases,
  • and the implementation is more complicated than it should be. *
  • Note 2: Cassandra doesn't support conditional updates on multiple tables. Hence the domain_metadata table is implemented
  • as a special record as "domain metadata". It is an integer number as notification version.
  • The main purpose of it is to notify clusters that there is some changes in domains, so domain cache needs to refresh.
  • It always increase by one, whenever a domain is updated or inserted.
  • Updating this failover metadata with domain insert/update needs to be atomic.
  • Because Batch LWTs is only allowed within one table and same partition.
  • The Cassandra implementation stores it in the same table as domain in domains_by_name_v2. *
  • Note 3: It's okay to use a constant value for partition key because domain table is serving very small volume of traffic.

type DomainRow added in v0.17.0

type DomainRow struct {
	Info                        *persistence.DomainInfo
	Config                      *NoSQLInternalDomainConfig
	ReplicationConfig           *persistence.DomainReplicationConfig
	ConfigVersion               int64
	FailoverVersion             int64
	FailoverNotificationVersion int64
	PreviousFailoverVersion     int64
	FailoverEndTime             *time.Time
	NotificationVersion         int64
	LastUpdatedTime             time.Time
	IsGlobalDomain              bool
}

DomainRow defines the row struct for queue message

type EventBufferWriteMode added in v0.23.1

type EventBufferWriteMode int

EventBufferWriteMode controls how to write EventBuffer

const (
	// EventBufferWriteModeNone is for not doing anything to the event buffer
	EventBufferWriteModeNone EventBufferWriteMode = iota
	// EventBufferWriteModeAppend will append a new event to the event buffer
	EventBufferWriteModeAppend
	// EventBufferWriteModeClear will clear(delete all event from) the event buffer
	EventBufferWriteModeClear
)

type HistoryEventsCRUD added in v0.23.1

type HistoryEventsCRUD interface {
	// InsertIntoHistoryTreeAndNode inserts one or two rows: tree row and node row(at least one of them)
	InsertIntoHistoryTreeAndNode(ctx context.Context, treeRow *HistoryTreeRow, nodeRow *HistoryNodeRow) error

	// SelectFromHistoryNode read nodes based on a filter
	SelectFromHistoryNode(ctx context.Context, filter *HistoryNodeFilter) ([]*HistoryNodeRow, []byte, error)

	// DeleteFromHistoryTreeAndNode delete a branch record, and a list of ranges of nodes.
	// for each range, it will delete all nodes starting from MinNodeID(inclusive)
	DeleteFromHistoryTreeAndNode(ctx context.Context, treeFilter *HistoryTreeFilter, nodeFilters []*HistoryNodeFilter) error

	// SelectAllHistoryTrees will return all tree branches with pagination
	SelectAllHistoryTrees(ctx context.Context, nextPageToken []byte, pageSize int) ([]*HistoryTreeRow, []byte, error)

	// SelectFromHistoryTree read branch records for a tree.
	// It returns without pagination, because we assume one tree won't have too many branches.
	SelectFromHistoryTree(ctx context.Context, filter *HistoryTreeFilter) ([]*HistoryTreeRow, error)
}

*

  • HistoryEventsCRUD is for History events storage system
  • Recommendation: use two tables: history_tree for branch records and history_node for node records
  • if a single update query can operate on two tables. *
  • Significant columns:
  • history_tree partition key: (shardID, treeID), range key: (branchID)
  • history_node partition key: (shardID, treeID), range key: (branchID, nodeID ASC, txnID DESC)

type HistoryNodeFilter

type HistoryNodeFilter struct {
	ShardID  int
	TreeID   string
	BranchID string
	// Inclusive
	MinNodeID int64
	// Exclusive
	MaxNodeID     int64
	NextPageToken []byte
	PageSize      int
}

HistoryNodeFilter contains the column names within history_node table that can be used to filter results through a WHERE clause

type HistoryNodeRow

type HistoryNodeRow struct {
	ShardID  int
	TreeID   string
	BranchID string
	NodeID   int64
	// Note: use pointer so that it's easier to multiple by -1 if needed
	TxnID        *int64
	Data         []byte
	DataEncoding string
}

HistoryNodeRow represents a row in history_node table

type HistoryTreeFilter

type HistoryTreeFilter struct {
	ShardID  int
	TreeID   string
	BranchID *string
}

HistoryTreeFilter contains the column names within history_tree table that can be used to filter results through a WHERE clause

type HistoryTreeRow

type HistoryTreeRow struct {
	ShardID         int
	TreeID          string
	BranchID        string
	Ancestors       []*types.HistoryBranchRange
	CreateTimestamp time.Time
	Info            string
}

HistoryTreeRow represents a row in history_tree table

type ListTaskListResult added in v0.22.0

type ListTaskListResult struct {
	TaskLists     []*TaskListRow
	NextPageToken []byte
}

ListTaskListResult is the result of list tasklists

type MessageQueueCRUD added in v0.23.1

type MessageQueueCRUD interface {
	//Insert message into queue, return error if failed or already exists
	// Must return conditionFailed error if row already exists
	InsertIntoQueue(ctx context.Context, row *QueueMessageRow) error
	// Get the ID of last message inserted into the queue
	SelectLastEnqueuedMessageID(ctx context.Context, queueType persistence.QueueType) (int64, error)
	// Read queue messages starting from the exclusiveBeginMessageID
	SelectMessagesFrom(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64, maxRows int) ([]*QueueMessageRow, error)
	// Read queue message starting from exclusiveBeginMessageID int64, inclusiveEndMessageID int64
	SelectMessagesBetween(ctx context.Context, request SelectMessagesBetweenRequest) (*SelectMessagesBetweenResponse, error)
	// Delete all messages before exclusiveBeginMessageID
	DeleteMessagesBefore(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64) error
	// Delete all messages in a range between exclusiveBeginMessageID and inclusiveEndMessageID
	DeleteMessagesInRange(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64, inclusiveEndMessageID int64) error
	// Delete one message
	DeleteMessage(ctx context.Context, queueType persistence.QueueType, messageID int64) error

	// Insert an empty metadata row, starting from a version
	InsertQueueMetadata(ctx context.Context, queueType persistence.QueueType, version int64) error
	// **Conditionally** update a queue metadata row, if current version is matched(meaning current == row.Version - 1),
	// then the current version will increase by one when updating the metadata row
	// Must return conditionFailed error if the condition is not met
	UpdateQueueMetadataCas(ctx context.Context, row QueueMetadataRow) error
	// Read a QueueMetadata
	SelectQueueMetadata(ctx context.Context, queueType persistence.QueueType) (*QueueMetadataRow, error)
	// GetQueueSize return the queue size
	GetQueueSize(ctx context.Context, queueType persistence.QueueType) (int64, error)
}

**

  • MessageQueueCRUD is for the message queue storage system *
  • Recommendation: use two tables(queue_message,and queue_metadata) to implement this interface *
  • Significant columns:
  • queue_message partition key: (queueType), range key: (messageID)
  • queue_metadata partition key: (queueType), range key: N/A, query condition column(version)

type MockAdminDB added in v0.23.1

type MockAdminDB struct {
	// contains filtered or unexported fields
}

MockAdminDB is a mock of AdminDB interface.

func NewMockAdminDB added in v0.23.1

func NewMockAdminDB(ctrl *gomock.Controller) *MockAdminDB

NewMockAdminDB creates a new mock instance.

func (*MockAdminDB) EXPECT added in v0.23.1

func (m *MockAdminDB) EXPECT() *MockAdminDBMockRecorder

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockAdminDB) SetupTestDatabase added in v0.23.1

func (m *MockAdminDB) SetupTestDatabase(schemaBaseDir string) error

SetupTestDatabase mocks base method.

func (*MockAdminDB) TeardownTestDatabase added in v0.23.1

func (m *MockAdminDB) TeardownTestDatabase() error

TeardownTestDatabase mocks base method.

type MockAdminDBMockRecorder added in v0.23.1

type MockAdminDBMockRecorder struct {
	// contains filtered or unexported fields
}

MockAdminDBMockRecorder is the mock recorder for MockAdminDB.

func (*MockAdminDBMockRecorder) SetupTestDatabase added in v0.23.1

func (mr *MockAdminDBMockRecorder) SetupTestDatabase(schemaBaseDir interface{}) *gomock.Call

SetupTestDatabase indicates an expected call of SetupTestDatabase.

func (*MockAdminDBMockRecorder) TeardownTestDatabase added in v0.23.1

func (mr *MockAdminDBMockRecorder) TeardownTestDatabase() *gomock.Call

TeardownTestDatabase indicates an expected call of TeardownTestDatabase.

type MockClientErrorChecker added in v0.23.1

type MockClientErrorChecker struct {
	// contains filtered or unexported fields
}

MockClientErrorChecker is a mock of ClientErrorChecker interface.

func NewMockClientErrorChecker added in v0.23.1

func NewMockClientErrorChecker(ctrl *gomock.Controller) *MockClientErrorChecker

NewMockClientErrorChecker creates a new mock instance.

func (*MockClientErrorChecker) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockClientErrorChecker) IsDBUnavailableError added in v0.25.0

func (m *MockClientErrorChecker) IsDBUnavailableError(arg0 error) bool

IsDBUnavailableError mocks base method.

func (*MockClientErrorChecker) IsNotFoundError added in v0.23.1

func (m *MockClientErrorChecker) IsNotFoundError(arg0 error) bool

IsNotFoundError mocks base method.

func (*MockClientErrorChecker) IsThrottlingError added in v0.23.1

func (m *MockClientErrorChecker) IsThrottlingError(arg0 error) bool

IsThrottlingError mocks base method.

func (*MockClientErrorChecker) IsTimeoutError added in v0.23.1

func (m *MockClientErrorChecker) IsTimeoutError(arg0 error) bool

IsTimeoutError mocks base method.

type MockClientErrorCheckerMockRecorder added in v0.23.1

type MockClientErrorCheckerMockRecorder struct {
	// contains filtered or unexported fields
}

MockClientErrorCheckerMockRecorder is the mock recorder for MockClientErrorChecker.

func (*MockClientErrorCheckerMockRecorder) IsDBUnavailableError added in v0.25.0

func (mr *MockClientErrorCheckerMockRecorder) IsDBUnavailableError(arg0 interface{}) *gomock.Call

IsDBUnavailableError indicates an expected call of IsDBUnavailableError.

func (*MockClientErrorCheckerMockRecorder) IsNotFoundError added in v0.23.1

func (mr *MockClientErrorCheckerMockRecorder) IsNotFoundError(arg0 interface{}) *gomock.Call

IsNotFoundError indicates an expected call of IsNotFoundError.

func (*MockClientErrorCheckerMockRecorder) IsThrottlingError added in v0.23.1

func (mr *MockClientErrorCheckerMockRecorder) IsThrottlingError(arg0 interface{}) *gomock.Call

IsThrottlingError indicates an expected call of IsThrottlingError.

func (*MockClientErrorCheckerMockRecorder) IsTimeoutError added in v0.23.1

func (mr *MockClientErrorCheckerMockRecorder) IsTimeoutError(arg0 interface{}) *gomock.Call

IsTimeoutError indicates an expected call of IsTimeoutError.

type MockConfigStoreCRUD added in v0.23.1

type MockConfigStoreCRUD struct {
	// contains filtered or unexported fields
}

MockConfigStoreCRUD is a mock of ConfigStoreCRUD interface.

func NewMockConfigStoreCRUD added in v0.23.1

func NewMockConfigStoreCRUD(ctrl *gomock.Controller) *MockConfigStoreCRUD

NewMockConfigStoreCRUD creates a new mock instance.

func (*MockConfigStoreCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockConfigStoreCRUD) InsertConfig added in v0.23.1

InsertConfig mocks base method.

func (*MockConfigStoreCRUD) SelectLatestConfig added in v0.23.1

func (m *MockConfigStoreCRUD) SelectLatestConfig(ctx context.Context, rowType int) (*persistence.InternalConfigStoreEntry, error)

SelectLatestConfig mocks base method.

type MockConfigStoreCRUDMockRecorder added in v0.23.1

type MockConfigStoreCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MockConfigStoreCRUDMockRecorder is the mock recorder for MockConfigStoreCRUD.

func (*MockConfigStoreCRUDMockRecorder) InsertConfig added in v0.23.1

func (mr *MockConfigStoreCRUDMockRecorder) InsertConfig(ctx, row interface{}) *gomock.Call

InsertConfig indicates an expected call of InsertConfig.

func (*MockConfigStoreCRUDMockRecorder) SelectLatestConfig added in v0.23.1

func (mr *MockConfigStoreCRUDMockRecorder) SelectLatestConfig(ctx, rowType interface{}) *gomock.Call

SelectLatestConfig indicates an expected call of SelectLatestConfig.

type MockDB added in v0.23.1

type MockDB struct {
	// contains filtered or unexported fields
}

MockDB is a mock of DB interface.

func NewMockDB added in v0.23.1

func NewMockDB(ctrl *gomock.Controller) *MockDB

NewMockDB creates a new mock instance.

func (*MockDB) Close added in v0.23.1

func (m *MockDB) Close()

Close mocks base method.

func (*MockDB) DeleteCrossClusterTask added in v0.23.1

func (m *MockDB) DeleteCrossClusterTask(ctx context.Context, shardID int, targetCluster string, taskID int64) error

DeleteCrossClusterTask mocks base method.

func (*MockDB) DeleteCurrentWorkflow added in v0.23.1

func (m *MockDB) DeleteCurrentWorkflow(ctx context.Context, shardID int, domainID, workflowID, currentRunIDCondition string) error

DeleteCurrentWorkflow mocks base method.

func (*MockDB) DeleteDomain added in v0.23.1

func (m *MockDB) DeleteDomain(ctx context.Context, domainID, domainName *string) error

DeleteDomain mocks base method.

func (*MockDB) DeleteFromHistoryTreeAndNode added in v0.23.1

func (m *MockDB) DeleteFromHistoryTreeAndNode(ctx context.Context, treeFilter *HistoryTreeFilter, nodeFilters []*HistoryNodeFilter) error

DeleteFromHistoryTreeAndNode mocks base method.

func (*MockDB) DeleteMessage added in v0.23.1

func (m *MockDB) DeleteMessage(ctx context.Context, queueType persistence.QueueType, messageID int64) error

DeleteMessage mocks base method.

func (*MockDB) DeleteMessagesBefore added in v0.23.1

func (m *MockDB) DeleteMessagesBefore(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64) error

DeleteMessagesBefore mocks base method.

func (*MockDB) DeleteMessagesInRange added in v0.23.1

func (m *MockDB) DeleteMessagesInRange(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID, inclusiveEndMessageID int64) error

DeleteMessagesInRange mocks base method.

func (*MockDB) DeleteReplicationDLQTask added in v0.23.1

func (m *MockDB) DeleteReplicationDLQTask(ctx context.Context, shardID int, sourceCluster string, taskID int64) error

DeleteReplicationDLQTask mocks base method.

func (*MockDB) DeleteReplicationTask added in v0.23.1

func (m *MockDB) DeleteReplicationTask(ctx context.Context, shardID int, taskID int64) error

DeleteReplicationTask mocks base method.

func (*MockDB) DeleteTaskList added in v0.23.1

func (m *MockDB) DeleteTaskList(ctx context.Context, filter *TaskListFilter, previousRangeID int64) error

DeleteTaskList mocks base method.

func (*MockDB) DeleteTimerTask added in v0.23.1

func (m *MockDB) DeleteTimerTask(ctx context.Context, shardID int, taskID int64, visibilityTimestamp time.Time) error

DeleteTimerTask mocks base method.

func (*MockDB) DeleteTransferTask added in v0.23.1

func (m *MockDB) DeleteTransferTask(ctx context.Context, shardID int, taskID int64) error

DeleteTransferTask mocks base method.

func (*MockDB) DeleteVisibility added in v0.23.1

func (m *MockDB) DeleteVisibility(ctx context.Context, domainID, workflowID, runID string) error

DeleteVisibility mocks base method.

func (*MockDB) DeleteWorkflowExecution added in v0.23.1

func (m *MockDB) DeleteWorkflowExecution(ctx context.Context, shardID int, domainID, workflowID, runID string) error

DeleteWorkflowExecution mocks base method.

func (*MockDB) EXPECT added in v0.23.1

func (m *MockDB) EXPECT() *MockDBMockRecorder

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockDB) GetQueueSize added in v0.23.1

func (m *MockDB) GetQueueSize(ctx context.Context, queueType persistence.QueueType) (int64, error)

GetQueueSize mocks base method.

func (*MockDB) InsertConfig added in v0.23.1

func (m *MockDB) InsertConfig(ctx context.Context, row *persistence.InternalConfigStoreEntry) error

InsertConfig mocks base method.

func (*MockDB) InsertDomain added in v0.23.1

func (m *MockDB) InsertDomain(ctx context.Context, row *DomainRow) error

InsertDomain mocks base method.

func (*MockDB) InsertIntoHistoryTreeAndNode added in v0.23.1

func (m *MockDB) InsertIntoHistoryTreeAndNode(ctx context.Context, treeRow *HistoryTreeRow, nodeRow *HistoryNodeRow) error

InsertIntoHistoryTreeAndNode mocks base method.

func (*MockDB) InsertIntoQueue added in v0.23.1

func (m *MockDB) InsertIntoQueue(ctx context.Context, row *QueueMessageRow) error

InsertIntoQueue mocks base method.

func (*MockDB) InsertQueueMetadata added in v0.23.1

func (m *MockDB) InsertQueueMetadata(ctx context.Context, queueType persistence.QueueType, version int64) error

InsertQueueMetadata mocks base method.

func (*MockDB) InsertReplicationDLQTask added in v0.23.1

func (m *MockDB) InsertReplicationDLQTask(ctx context.Context, shardID int, sourceCluster string, task ReplicationTask) error

InsertReplicationDLQTask mocks base method.

func (*MockDB) InsertReplicationTask added in v0.23.1

func (m *MockDB) InsertReplicationTask(ctx context.Context, tasks []*ReplicationTask, condition ShardCondition) error

InsertReplicationTask mocks base method.

func (*MockDB) InsertShard added in v0.23.1

func (m *MockDB) InsertShard(ctx context.Context, row *ShardRow) error

InsertShard mocks base method.

func (*MockDB) InsertTaskList added in v0.23.1

func (m *MockDB) InsertTaskList(ctx context.Context, row *TaskListRow) error

InsertTaskList mocks base method.

func (*MockDB) InsertTasks added in v0.23.1

func (m *MockDB) InsertTasks(ctx context.Context, tasksToInsert []*TaskRowForInsert, tasklistCondition *TaskListRow) error

InsertTasks mocks base method.

func (*MockDB) InsertVisibility added in v0.23.1

func (m *MockDB) InsertVisibility(ctx context.Context, ttlSeconds int64, row *VisibilityRowForInsert) error

InsertVisibility mocks base method.

func (*MockDB) InsertWorkflowExecutionWithTasks added in v0.23.1

func (m *MockDB) InsertWorkflowExecutionWithTasks(ctx context.Context, currentWorkflowRequest *CurrentWorkflowWriteRequest, execution *WorkflowExecutionRequest, transferTasks []*TransferTask, crossClusterTasks []*CrossClusterTask, replicationTasks []*ReplicationTask, timerTasks []*TimerTask, shardCondition *ShardCondition) error

InsertWorkflowExecutionWithTasks mocks base method.

func (*MockDB) IsDBUnavailableError added in v0.25.0

func (m *MockDB) IsDBUnavailableError(arg0 error) bool

IsDBUnavailableError mocks base method.

func (*MockDB) IsNotFoundError added in v0.23.1

func (m *MockDB) IsNotFoundError(arg0 error) bool

IsNotFoundError mocks base method.

func (*MockDB) IsThrottlingError added in v0.23.1

func (m *MockDB) IsThrottlingError(arg0 error) bool

IsThrottlingError mocks base method.

func (*MockDB) IsTimeoutError added in v0.23.1

func (m *MockDB) IsTimeoutError(arg0 error) bool

IsTimeoutError mocks base method.

func (*MockDB) IsWorkflowExecutionExists added in v0.23.1

func (m *MockDB) IsWorkflowExecutionExists(ctx context.Context, shardID int, domainID, workflowID, runID string) (bool, error)

IsWorkflowExecutionExists mocks base method.

func (*MockDB) ListTaskList added in v0.23.1

func (m *MockDB) ListTaskList(ctx context.Context, pageSize int, nextPageToken []byte) (*ListTaskListResult, error)

ListTaskList mocks base method.

func (*MockDB) PluginName added in v0.23.1

func (m *MockDB) PluginName() string

PluginName mocks base method.

func (*MockDB) RangeDeleteCrossClusterTasks added in v0.23.1

func (m *MockDB) RangeDeleteCrossClusterTasks(ctx context.Context, shardID int, targetCluster string, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteCrossClusterTasks mocks base method.

func (*MockDB) RangeDeleteReplicationDLQTasks added in v0.23.1

func (m *MockDB) RangeDeleteReplicationDLQTasks(ctx context.Context, shardID int, sourceCluster string, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteReplicationDLQTasks mocks base method.

func (*MockDB) RangeDeleteReplicationTasks added in v0.23.1

func (m *MockDB) RangeDeleteReplicationTasks(ctx context.Context, shardID int, inclusiveEndTaskID int64) error

RangeDeleteReplicationTasks mocks base method.

func (*MockDB) RangeDeleteTasks added in v0.23.1

func (m *MockDB) RangeDeleteTasks(ctx context.Context, filter *TasksFilter) (int, error)

RangeDeleteTasks mocks base method.

func (*MockDB) RangeDeleteTimerTasks added in v0.23.1

func (m *MockDB) RangeDeleteTimerTasks(ctx context.Context, shardID int, inclusiveMinTime, exclusiveMaxTime time.Time) error

RangeDeleteTimerTasks mocks base method.

func (*MockDB) RangeDeleteTransferTasks added in v0.23.1

func (m *MockDB) RangeDeleteTransferTasks(ctx context.Context, shardID int, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteTransferTasks mocks base method.

func (*MockDB) SelectAllCurrentWorkflows added in v0.23.1

func (m *MockDB) SelectAllCurrentWorkflows(ctx context.Context, shardID int, pageToken []byte, pageSize int) ([]*persistence.CurrentWorkflowExecution, []byte, error)

SelectAllCurrentWorkflows mocks base method.

func (*MockDB) SelectAllDomains added in v0.23.1

func (m *MockDB) SelectAllDomains(ctx context.Context, pageSize int, pageToken []byte) ([]*DomainRow, []byte, error)

SelectAllDomains mocks base method.

func (*MockDB) SelectAllHistoryTrees added in v0.23.1

func (m *MockDB) SelectAllHistoryTrees(ctx context.Context, nextPageToken []byte, pageSize int) ([]*HistoryTreeRow, []byte, error)

SelectAllHistoryTrees mocks base method.

func (*MockDB) SelectAllWorkflowExecutions added in v0.23.1

func (m *MockDB) SelectAllWorkflowExecutions(ctx context.Context, shardID int, pageToken []byte, pageSize int) ([]*persistence.InternalListConcreteExecutionsEntity, []byte, error)

SelectAllWorkflowExecutions mocks base method.

func (*MockDB) SelectCrossClusterTasksOrderByTaskID added in v0.23.1

func (m *MockDB) SelectCrossClusterTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, targetCluster string, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*CrossClusterTask, []byte, error)

SelectCrossClusterTasksOrderByTaskID mocks base method.

func (*MockDB) SelectCurrentWorkflow added in v0.23.1

func (m *MockDB) SelectCurrentWorkflow(ctx context.Context, shardID int, domainID, workflowID string) (*CurrentWorkflowRow, error)

SelectCurrentWorkflow mocks base method.

func (*MockDB) SelectDomain added in v0.23.1

func (m *MockDB) SelectDomain(ctx context.Context, domainID, domainName *string) (*DomainRow, error)

SelectDomain mocks base method.

func (*MockDB) SelectDomainMetadata added in v0.23.1

func (m *MockDB) SelectDomainMetadata(ctx context.Context) (int64, error)

SelectDomainMetadata mocks base method.

func (*MockDB) SelectFromHistoryNode added in v0.23.1

func (m *MockDB) SelectFromHistoryNode(ctx context.Context, filter *HistoryNodeFilter) ([]*HistoryNodeRow, []byte, error)

SelectFromHistoryNode mocks base method.

func (*MockDB) SelectFromHistoryTree added in v0.23.1

func (m *MockDB) SelectFromHistoryTree(ctx context.Context, filter *HistoryTreeFilter) ([]*HistoryTreeRow, error)

SelectFromHistoryTree mocks base method.

func (*MockDB) SelectLastEnqueuedMessageID added in v0.23.1

func (m *MockDB) SelectLastEnqueuedMessageID(ctx context.Context, queueType persistence.QueueType) (int64, error)

SelectLastEnqueuedMessageID mocks base method.

func (*MockDB) SelectLatestConfig added in v0.23.1

func (m *MockDB) SelectLatestConfig(ctx context.Context, rowType int) (*persistence.InternalConfigStoreEntry, error)

SelectLatestConfig mocks base method.

func (*MockDB) SelectMessagesBetween added in v0.23.1

func (m *MockDB) SelectMessagesBetween(ctx context.Context, request SelectMessagesBetweenRequest) (*SelectMessagesBetweenResponse, error)

SelectMessagesBetween mocks base method.

func (*MockDB) SelectMessagesFrom added in v0.23.1

func (m *MockDB) SelectMessagesFrom(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64, maxRows int) ([]*QueueMessageRow, error)

SelectMessagesFrom mocks base method.

func (*MockDB) SelectOneClosedWorkflow added in v0.23.1

func (m *MockDB) SelectOneClosedWorkflow(ctx context.Context, domainID, workflowID, runID string) (*VisibilityRow, error)

SelectOneClosedWorkflow mocks base method.

func (*MockDB) SelectQueueMetadata added in v0.23.1

func (m *MockDB) SelectQueueMetadata(ctx context.Context, queueType persistence.QueueType) (*QueueMetadataRow, error)

SelectQueueMetadata mocks base method.

func (*MockDB) SelectReplicationDLQTasksCount added in v0.23.1

func (m *MockDB) SelectReplicationDLQTasksCount(ctx context.Context, shardID int, sourceCluster string) (int64, error)

SelectReplicationDLQTasksCount mocks base method.

func (*MockDB) SelectReplicationDLQTasksOrderByTaskID added in v0.23.1

func (m *MockDB) SelectReplicationDLQTasksOrderByTaskID(ctx context.Context, shardID int, sourceCluster string, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*ReplicationTask, []byte, error)

SelectReplicationDLQTasksOrderByTaskID mocks base method.

func (*MockDB) SelectReplicationTasksOrderByTaskID added in v0.23.1

func (m *MockDB) SelectReplicationTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*ReplicationTask, []byte, error)

SelectReplicationTasksOrderByTaskID mocks base method.

func (*MockDB) SelectShard added in v0.23.1

func (m *MockDB) SelectShard(ctx context.Context, shardID int, currentClusterName string) (int64, *ShardRow, error)

SelectShard mocks base method.

func (*MockDB) SelectTaskList added in v0.23.1

func (m *MockDB) SelectTaskList(ctx context.Context, filter *TaskListFilter) (*TaskListRow, error)

SelectTaskList mocks base method.

func (*MockDB) SelectTasks added in v0.23.1

func (m *MockDB) SelectTasks(ctx context.Context, filter *TasksFilter) ([]*TaskRow, error)

SelectTasks mocks base method.

func (*MockDB) SelectTimerTasksOrderByVisibilityTime added in v0.23.1

func (m *MockDB) SelectTimerTasksOrderByVisibilityTime(ctx context.Context, shardID, pageSize int, pageToken []byte, inclusiveMinTime, exclusiveMaxTime time.Time) ([]*TimerTask, []byte, error)

SelectTimerTasksOrderByVisibilityTime mocks base method.

func (*MockDB) SelectTransferTasksOrderByTaskID added in v0.23.1

func (m *MockDB) SelectTransferTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*TransferTask, []byte, error)

SelectTransferTasksOrderByTaskID mocks base method.

func (*MockDB) SelectVisibility added in v0.23.1

func (m *MockDB) SelectVisibility(ctx context.Context, filter *VisibilityFilter) (*SelectVisibilityResponse, error)

SelectVisibility mocks base method.

func (*MockDB) SelectWorkflowExecution added in v0.23.1

func (m *MockDB) SelectWorkflowExecution(ctx context.Context, shardID int, domainID, workflowID, runID string) (*WorkflowExecution, error)

SelectWorkflowExecution mocks base method.

func (*MockDB) UpdateDomain added in v0.23.1

func (m *MockDB) UpdateDomain(ctx context.Context, row *DomainRow) error

UpdateDomain mocks base method.

func (*MockDB) UpdateQueueMetadataCas added in v0.23.1

func (m *MockDB) UpdateQueueMetadataCas(ctx context.Context, row QueueMetadataRow) error

UpdateQueueMetadataCas mocks base method.

func (*MockDB) UpdateRangeID added in v0.23.1

func (m *MockDB) UpdateRangeID(ctx context.Context, shardID int, rangeID, previousRangeID int64) error

UpdateRangeID mocks base method.

func (*MockDB) UpdateShard added in v0.23.1

func (m *MockDB) UpdateShard(ctx context.Context, row *ShardRow, previousRangeID int64) error

UpdateShard mocks base method.

func (*MockDB) UpdateTaskList added in v0.23.1

func (m *MockDB) UpdateTaskList(ctx context.Context, row *TaskListRow, previousRangeID int64) error

UpdateTaskList mocks base method.

func (*MockDB) UpdateTaskListWithTTL added in v0.23.1

func (m *MockDB) UpdateTaskListWithTTL(ctx context.Context, ttlSeconds int64, row *TaskListRow, previousRangeID int64) error

UpdateTaskListWithTTL mocks base method.

func (*MockDB) UpdateVisibility added in v0.23.1

func (m *MockDB) UpdateVisibility(ctx context.Context, ttlSeconds int64, row *VisibilityRowForUpdate) error

UpdateVisibility mocks base method.

func (*MockDB) UpdateWorkflowExecutionWithTasks added in v0.23.1

func (m *MockDB) UpdateWorkflowExecutionWithTasks(ctx context.Context, currentWorkflowRequest *CurrentWorkflowWriteRequest, mutatedExecution, insertedExecution, resetExecution *WorkflowExecutionRequest, transferTasks []*TransferTask, crossClusterTasks []*CrossClusterTask, replicationTasks []*ReplicationTask, timerTasks []*TimerTask, shardCondition *ShardCondition) error

UpdateWorkflowExecutionWithTasks mocks base method.

type MockDBMockRecorder added in v0.23.1

type MockDBMockRecorder struct {
	// contains filtered or unexported fields
}

MockDBMockRecorder is the mock recorder for MockDB.

func (*MockDBMockRecorder) Close added in v0.23.1

func (mr *MockDBMockRecorder) Close() *gomock.Call

Close indicates an expected call of Close.

func (*MockDBMockRecorder) DeleteCrossClusterTask added in v0.23.1

func (mr *MockDBMockRecorder) DeleteCrossClusterTask(ctx, shardID, targetCluster, taskID interface{}) *gomock.Call

DeleteCrossClusterTask indicates an expected call of DeleteCrossClusterTask.

func (*MockDBMockRecorder) DeleteCurrentWorkflow added in v0.23.1

func (mr *MockDBMockRecorder) DeleteCurrentWorkflow(ctx, shardID, domainID, workflowID, currentRunIDCondition interface{}) *gomock.Call

DeleteCurrentWorkflow indicates an expected call of DeleteCurrentWorkflow.

func (*MockDBMockRecorder) DeleteDomain added in v0.23.1

func (mr *MockDBMockRecorder) DeleteDomain(ctx, domainID, domainName interface{}) *gomock.Call

DeleteDomain indicates an expected call of DeleteDomain.

func (*MockDBMockRecorder) DeleteFromHistoryTreeAndNode added in v0.23.1

func (mr *MockDBMockRecorder) DeleteFromHistoryTreeAndNode(ctx, treeFilter, nodeFilters interface{}) *gomock.Call

DeleteFromHistoryTreeAndNode indicates an expected call of DeleteFromHistoryTreeAndNode.

func (*MockDBMockRecorder) DeleteMessage added in v0.23.1

func (mr *MockDBMockRecorder) DeleteMessage(ctx, queueType, messageID interface{}) *gomock.Call

DeleteMessage indicates an expected call of DeleteMessage.

func (*MockDBMockRecorder) DeleteMessagesBefore added in v0.23.1

func (mr *MockDBMockRecorder) DeleteMessagesBefore(ctx, queueType, exclusiveBeginMessageID interface{}) *gomock.Call

DeleteMessagesBefore indicates an expected call of DeleteMessagesBefore.

func (*MockDBMockRecorder) DeleteMessagesInRange added in v0.23.1

func (mr *MockDBMockRecorder) DeleteMessagesInRange(ctx, queueType, exclusiveBeginMessageID, inclusiveEndMessageID interface{}) *gomock.Call

DeleteMessagesInRange indicates an expected call of DeleteMessagesInRange.

func (*MockDBMockRecorder) DeleteReplicationDLQTask added in v0.23.1

func (mr *MockDBMockRecorder) DeleteReplicationDLQTask(ctx, shardID, sourceCluster, taskID interface{}) *gomock.Call

DeleteReplicationDLQTask indicates an expected call of DeleteReplicationDLQTask.

func (*MockDBMockRecorder) DeleteReplicationTask added in v0.23.1

func (mr *MockDBMockRecorder) DeleteReplicationTask(ctx, shardID, taskID interface{}) *gomock.Call

DeleteReplicationTask indicates an expected call of DeleteReplicationTask.

func (*MockDBMockRecorder) DeleteTaskList added in v0.23.1

func (mr *MockDBMockRecorder) DeleteTaskList(ctx, filter, previousRangeID interface{}) *gomock.Call

DeleteTaskList indicates an expected call of DeleteTaskList.

func (*MockDBMockRecorder) DeleteTimerTask added in v0.23.1

func (mr *MockDBMockRecorder) DeleteTimerTask(ctx, shardID, taskID, visibilityTimestamp interface{}) *gomock.Call

DeleteTimerTask indicates an expected call of DeleteTimerTask.

func (*MockDBMockRecorder) DeleteTransferTask added in v0.23.1

func (mr *MockDBMockRecorder) DeleteTransferTask(ctx, shardID, taskID interface{}) *gomock.Call

DeleteTransferTask indicates an expected call of DeleteTransferTask.

func (*MockDBMockRecorder) DeleteVisibility added in v0.23.1

func (mr *MockDBMockRecorder) DeleteVisibility(ctx, domainID, workflowID, runID interface{}) *gomock.Call

DeleteVisibility indicates an expected call of DeleteVisibility.

func (*MockDBMockRecorder) DeleteWorkflowExecution added in v0.23.1

func (mr *MockDBMockRecorder) DeleteWorkflowExecution(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

DeleteWorkflowExecution indicates an expected call of DeleteWorkflowExecution.

func (*MockDBMockRecorder) GetQueueSize added in v0.23.1

func (mr *MockDBMockRecorder) GetQueueSize(ctx, queueType interface{}) *gomock.Call

GetQueueSize indicates an expected call of GetQueueSize.

func (*MockDBMockRecorder) InsertConfig added in v0.23.1

func (mr *MockDBMockRecorder) InsertConfig(ctx, row interface{}) *gomock.Call

InsertConfig indicates an expected call of InsertConfig.

func (*MockDBMockRecorder) InsertDomain added in v0.23.1

func (mr *MockDBMockRecorder) InsertDomain(ctx, row interface{}) *gomock.Call

InsertDomain indicates an expected call of InsertDomain.

func (*MockDBMockRecorder) InsertIntoHistoryTreeAndNode added in v0.23.1

func (mr *MockDBMockRecorder) InsertIntoHistoryTreeAndNode(ctx, treeRow, nodeRow interface{}) *gomock.Call

InsertIntoHistoryTreeAndNode indicates an expected call of InsertIntoHistoryTreeAndNode.

func (*MockDBMockRecorder) InsertIntoQueue added in v0.23.1

func (mr *MockDBMockRecorder) InsertIntoQueue(ctx, row interface{}) *gomock.Call

InsertIntoQueue indicates an expected call of InsertIntoQueue.

func (*MockDBMockRecorder) InsertQueueMetadata added in v0.23.1

func (mr *MockDBMockRecorder) InsertQueueMetadata(ctx, queueType, version interface{}) *gomock.Call

InsertQueueMetadata indicates an expected call of InsertQueueMetadata.

func (*MockDBMockRecorder) InsertReplicationDLQTask added in v0.23.1

func (mr *MockDBMockRecorder) InsertReplicationDLQTask(ctx, shardID, sourceCluster, task interface{}) *gomock.Call

InsertReplicationDLQTask indicates an expected call of InsertReplicationDLQTask.

func (*MockDBMockRecorder) InsertReplicationTask added in v0.23.1

func (mr *MockDBMockRecorder) InsertReplicationTask(ctx, tasks, condition interface{}) *gomock.Call

InsertReplicationTask indicates an expected call of InsertReplicationTask.

func (*MockDBMockRecorder) InsertShard added in v0.23.1

func (mr *MockDBMockRecorder) InsertShard(ctx, row interface{}) *gomock.Call

InsertShard indicates an expected call of InsertShard.

func (*MockDBMockRecorder) InsertTaskList added in v0.23.1

func (mr *MockDBMockRecorder) InsertTaskList(ctx, row interface{}) *gomock.Call

InsertTaskList indicates an expected call of InsertTaskList.

func (*MockDBMockRecorder) InsertTasks added in v0.23.1

func (mr *MockDBMockRecorder) InsertTasks(ctx, tasksToInsert, tasklistCondition interface{}) *gomock.Call

InsertTasks indicates an expected call of InsertTasks.

func (*MockDBMockRecorder) InsertVisibility added in v0.23.1

func (mr *MockDBMockRecorder) InsertVisibility(ctx, ttlSeconds, row interface{}) *gomock.Call

InsertVisibility indicates an expected call of InsertVisibility.

func (*MockDBMockRecorder) InsertWorkflowExecutionWithTasks added in v0.23.1

func (mr *MockDBMockRecorder) InsertWorkflowExecutionWithTasks(ctx, currentWorkflowRequest, execution, transferTasks, crossClusterTasks, replicationTasks, timerTasks, shardCondition interface{}) *gomock.Call

InsertWorkflowExecutionWithTasks indicates an expected call of InsertWorkflowExecutionWithTasks.

func (*MockDBMockRecorder) IsDBUnavailableError added in v0.25.0

func (mr *MockDBMockRecorder) IsDBUnavailableError(arg0 interface{}) *gomock.Call

IsDBUnavailableError indicates an expected call of IsDBUnavailableError.

func (*MockDBMockRecorder) IsNotFoundError added in v0.23.1

func (mr *MockDBMockRecorder) IsNotFoundError(arg0 interface{}) *gomock.Call

IsNotFoundError indicates an expected call of IsNotFoundError.

func (*MockDBMockRecorder) IsThrottlingError added in v0.23.1

func (mr *MockDBMockRecorder) IsThrottlingError(arg0 interface{}) *gomock.Call

IsThrottlingError indicates an expected call of IsThrottlingError.

func (*MockDBMockRecorder) IsTimeoutError added in v0.23.1

func (mr *MockDBMockRecorder) IsTimeoutError(arg0 interface{}) *gomock.Call

IsTimeoutError indicates an expected call of IsTimeoutError.

func (*MockDBMockRecorder) IsWorkflowExecutionExists added in v0.23.1

func (mr *MockDBMockRecorder) IsWorkflowExecutionExists(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

IsWorkflowExecutionExists indicates an expected call of IsWorkflowExecutionExists.

func (*MockDBMockRecorder) ListTaskList added in v0.23.1

func (mr *MockDBMockRecorder) ListTaskList(ctx, pageSize, nextPageToken interface{}) *gomock.Call

ListTaskList indicates an expected call of ListTaskList.

func (*MockDBMockRecorder) PluginName added in v0.23.1

func (mr *MockDBMockRecorder) PluginName() *gomock.Call

PluginName indicates an expected call of PluginName.

func (*MockDBMockRecorder) RangeDeleteCrossClusterTasks added in v0.23.1

func (mr *MockDBMockRecorder) RangeDeleteCrossClusterTasks(ctx, shardID, targetCluster, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteCrossClusterTasks indicates an expected call of RangeDeleteCrossClusterTasks.

func (*MockDBMockRecorder) RangeDeleteReplicationDLQTasks added in v0.23.1

func (mr *MockDBMockRecorder) RangeDeleteReplicationDLQTasks(ctx, shardID, sourceCluster, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteReplicationDLQTasks indicates an expected call of RangeDeleteReplicationDLQTasks.

func (*MockDBMockRecorder) RangeDeleteReplicationTasks added in v0.23.1

func (mr *MockDBMockRecorder) RangeDeleteReplicationTasks(ctx, shardID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteReplicationTasks indicates an expected call of RangeDeleteReplicationTasks.

func (*MockDBMockRecorder) RangeDeleteTasks added in v0.23.1

func (mr *MockDBMockRecorder) RangeDeleteTasks(ctx, filter interface{}) *gomock.Call

RangeDeleteTasks indicates an expected call of RangeDeleteTasks.

func (*MockDBMockRecorder) RangeDeleteTimerTasks added in v0.23.1

func (mr *MockDBMockRecorder) RangeDeleteTimerTasks(ctx, shardID, inclusiveMinTime, exclusiveMaxTime interface{}) *gomock.Call

RangeDeleteTimerTasks indicates an expected call of RangeDeleteTimerTasks.

func (*MockDBMockRecorder) RangeDeleteTransferTasks added in v0.23.1

func (mr *MockDBMockRecorder) RangeDeleteTransferTasks(ctx, shardID, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteTransferTasks indicates an expected call of RangeDeleteTransferTasks.

func (*MockDBMockRecorder) SelectAllCurrentWorkflows added in v0.23.1

func (mr *MockDBMockRecorder) SelectAllCurrentWorkflows(ctx, shardID, pageToken, pageSize interface{}) *gomock.Call

SelectAllCurrentWorkflows indicates an expected call of SelectAllCurrentWorkflows.

func (*MockDBMockRecorder) SelectAllDomains added in v0.23.1

func (mr *MockDBMockRecorder) SelectAllDomains(ctx, pageSize, pageToken interface{}) *gomock.Call

SelectAllDomains indicates an expected call of SelectAllDomains.

func (*MockDBMockRecorder) SelectAllHistoryTrees added in v0.23.1

func (mr *MockDBMockRecorder) SelectAllHistoryTrees(ctx, nextPageToken, pageSize interface{}) *gomock.Call

SelectAllHistoryTrees indicates an expected call of SelectAllHistoryTrees.

func (*MockDBMockRecorder) SelectAllWorkflowExecutions added in v0.23.1

func (mr *MockDBMockRecorder) SelectAllWorkflowExecutions(ctx, shardID, pageToken, pageSize interface{}) *gomock.Call

SelectAllWorkflowExecutions indicates an expected call of SelectAllWorkflowExecutions.

func (*MockDBMockRecorder) SelectCrossClusterTasksOrderByTaskID added in v0.23.1

func (mr *MockDBMockRecorder) SelectCrossClusterTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, targetCluster, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectCrossClusterTasksOrderByTaskID indicates an expected call of SelectCrossClusterTasksOrderByTaskID.

func (*MockDBMockRecorder) SelectCurrentWorkflow added in v0.23.1

func (mr *MockDBMockRecorder) SelectCurrentWorkflow(ctx, shardID, domainID, workflowID interface{}) *gomock.Call

SelectCurrentWorkflow indicates an expected call of SelectCurrentWorkflow.

func (*MockDBMockRecorder) SelectDomain added in v0.23.1

func (mr *MockDBMockRecorder) SelectDomain(ctx, domainID, domainName interface{}) *gomock.Call

SelectDomain indicates an expected call of SelectDomain.

func (*MockDBMockRecorder) SelectDomainMetadata added in v0.23.1

func (mr *MockDBMockRecorder) SelectDomainMetadata(ctx interface{}) *gomock.Call

SelectDomainMetadata indicates an expected call of SelectDomainMetadata.

func (*MockDBMockRecorder) SelectFromHistoryNode added in v0.23.1

func (mr *MockDBMockRecorder) SelectFromHistoryNode(ctx, filter interface{}) *gomock.Call

SelectFromHistoryNode indicates an expected call of SelectFromHistoryNode.

func (*MockDBMockRecorder) SelectFromHistoryTree added in v0.23.1

func (mr *MockDBMockRecorder) SelectFromHistoryTree(ctx, filter interface{}) *gomock.Call

SelectFromHistoryTree indicates an expected call of SelectFromHistoryTree.

func (*MockDBMockRecorder) SelectLastEnqueuedMessageID added in v0.23.1

func (mr *MockDBMockRecorder) SelectLastEnqueuedMessageID(ctx, queueType interface{}) *gomock.Call

SelectLastEnqueuedMessageID indicates an expected call of SelectLastEnqueuedMessageID.

func (*MockDBMockRecorder) SelectLatestConfig added in v0.23.1

func (mr *MockDBMockRecorder) SelectLatestConfig(ctx, rowType interface{}) *gomock.Call

SelectLatestConfig indicates an expected call of SelectLatestConfig.

func (*MockDBMockRecorder) SelectMessagesBetween added in v0.23.1

func (mr *MockDBMockRecorder) SelectMessagesBetween(ctx, request interface{}) *gomock.Call

SelectMessagesBetween indicates an expected call of SelectMessagesBetween.

func (*MockDBMockRecorder) SelectMessagesFrom added in v0.23.1

func (mr *MockDBMockRecorder) SelectMessagesFrom(ctx, queueType, exclusiveBeginMessageID, maxRows interface{}) *gomock.Call

SelectMessagesFrom indicates an expected call of SelectMessagesFrom.

func (*MockDBMockRecorder) SelectOneClosedWorkflow added in v0.23.1

func (mr *MockDBMockRecorder) SelectOneClosedWorkflow(ctx, domainID, workflowID, runID interface{}) *gomock.Call

SelectOneClosedWorkflow indicates an expected call of SelectOneClosedWorkflow.

func (*MockDBMockRecorder) SelectQueueMetadata added in v0.23.1

func (mr *MockDBMockRecorder) SelectQueueMetadata(ctx, queueType interface{}) *gomock.Call

SelectQueueMetadata indicates an expected call of SelectQueueMetadata.

func (*MockDBMockRecorder) SelectReplicationDLQTasksCount added in v0.23.1

func (mr *MockDBMockRecorder) SelectReplicationDLQTasksCount(ctx, shardID, sourceCluster interface{}) *gomock.Call

SelectReplicationDLQTasksCount indicates an expected call of SelectReplicationDLQTasksCount.

func (*MockDBMockRecorder) SelectReplicationDLQTasksOrderByTaskID added in v0.23.1

func (mr *MockDBMockRecorder) SelectReplicationDLQTasksOrderByTaskID(ctx, shardID, sourceCluster, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectReplicationDLQTasksOrderByTaskID indicates an expected call of SelectReplicationDLQTasksOrderByTaskID.

func (*MockDBMockRecorder) SelectReplicationTasksOrderByTaskID added in v0.23.1

func (mr *MockDBMockRecorder) SelectReplicationTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectReplicationTasksOrderByTaskID indicates an expected call of SelectReplicationTasksOrderByTaskID.

func (*MockDBMockRecorder) SelectShard added in v0.23.1

func (mr *MockDBMockRecorder) SelectShard(ctx, shardID, currentClusterName interface{}) *gomock.Call

SelectShard indicates an expected call of SelectShard.

func (*MockDBMockRecorder) SelectTaskList added in v0.23.1

func (mr *MockDBMockRecorder) SelectTaskList(ctx, filter interface{}) *gomock.Call

SelectTaskList indicates an expected call of SelectTaskList.

func (*MockDBMockRecorder) SelectTasks added in v0.23.1

func (mr *MockDBMockRecorder) SelectTasks(ctx, filter interface{}) *gomock.Call

SelectTasks indicates an expected call of SelectTasks.

func (*MockDBMockRecorder) SelectTimerTasksOrderByVisibilityTime added in v0.23.1

func (mr *MockDBMockRecorder) SelectTimerTasksOrderByVisibilityTime(ctx, shardID, pageSize, pageToken, inclusiveMinTime, exclusiveMaxTime interface{}) *gomock.Call

SelectTimerTasksOrderByVisibilityTime indicates an expected call of SelectTimerTasksOrderByVisibilityTime.

func (*MockDBMockRecorder) SelectTransferTasksOrderByTaskID added in v0.23.1

func (mr *MockDBMockRecorder) SelectTransferTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectTransferTasksOrderByTaskID indicates an expected call of SelectTransferTasksOrderByTaskID.

func (*MockDBMockRecorder) SelectVisibility added in v0.23.1

func (mr *MockDBMockRecorder) SelectVisibility(ctx, filter interface{}) *gomock.Call

SelectVisibility indicates an expected call of SelectVisibility.

func (*MockDBMockRecorder) SelectWorkflowExecution added in v0.23.1

func (mr *MockDBMockRecorder) SelectWorkflowExecution(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

SelectWorkflowExecution indicates an expected call of SelectWorkflowExecution.

func (*MockDBMockRecorder) UpdateDomain added in v0.23.1

func (mr *MockDBMockRecorder) UpdateDomain(ctx, row interface{}) *gomock.Call

UpdateDomain indicates an expected call of UpdateDomain.

func (*MockDBMockRecorder) UpdateQueueMetadataCas added in v0.23.1

func (mr *MockDBMockRecorder) UpdateQueueMetadataCas(ctx, row interface{}) *gomock.Call

UpdateQueueMetadataCas indicates an expected call of UpdateQueueMetadataCas.

func (*MockDBMockRecorder) UpdateRangeID added in v0.23.1

func (mr *MockDBMockRecorder) UpdateRangeID(ctx, shardID, rangeID, previousRangeID interface{}) *gomock.Call

UpdateRangeID indicates an expected call of UpdateRangeID.

func (*MockDBMockRecorder) UpdateShard added in v0.23.1

func (mr *MockDBMockRecorder) UpdateShard(ctx, row, previousRangeID interface{}) *gomock.Call

UpdateShard indicates an expected call of UpdateShard.

func (*MockDBMockRecorder) UpdateTaskList added in v0.23.1

func (mr *MockDBMockRecorder) UpdateTaskList(ctx, row, previousRangeID interface{}) *gomock.Call

UpdateTaskList indicates an expected call of UpdateTaskList.

func (*MockDBMockRecorder) UpdateTaskListWithTTL added in v0.23.1

func (mr *MockDBMockRecorder) UpdateTaskListWithTTL(ctx, ttlSeconds, row, previousRangeID interface{}) *gomock.Call

UpdateTaskListWithTTL indicates an expected call of UpdateTaskListWithTTL.

func (*MockDBMockRecorder) UpdateVisibility added in v0.23.1

func (mr *MockDBMockRecorder) UpdateVisibility(ctx, ttlSeconds, row interface{}) *gomock.Call

UpdateVisibility indicates an expected call of UpdateVisibility.

func (*MockDBMockRecorder) UpdateWorkflowExecutionWithTasks added in v0.23.1

func (mr *MockDBMockRecorder) UpdateWorkflowExecutionWithTasks(ctx, currentWorkflowRequest, mutatedExecution, insertedExecution, resetExecution, transferTasks, crossClusterTasks, replicationTasks, timerTasks, shardCondition interface{}) *gomock.Call

UpdateWorkflowExecutionWithTasks indicates an expected call of UpdateWorkflowExecutionWithTasks.

type MockDomainCRUD added in v0.23.1

type MockDomainCRUD struct {
	// contains filtered or unexported fields
}

MockDomainCRUD is a mock of DomainCRUD interface.

func NewMockDomainCRUD added in v0.23.1

func NewMockDomainCRUD(ctrl *gomock.Controller) *MockDomainCRUD

NewMockDomainCRUD creates a new mock instance.

func (*MockDomainCRUD) DeleteDomain added in v0.23.1

func (m *MockDomainCRUD) DeleteDomain(ctx context.Context, domainID, domainName *string) error

DeleteDomain mocks base method.

func (*MockDomainCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockDomainCRUD) InsertDomain added in v0.23.1

func (m *MockDomainCRUD) InsertDomain(ctx context.Context, row *DomainRow) error

InsertDomain mocks base method.

func (*MockDomainCRUD) SelectAllDomains added in v0.23.1

func (m *MockDomainCRUD) SelectAllDomains(ctx context.Context, pageSize int, pageToken []byte) ([]*DomainRow, []byte, error)

SelectAllDomains mocks base method.

func (*MockDomainCRUD) SelectDomain added in v0.23.1

func (m *MockDomainCRUD) SelectDomain(ctx context.Context, domainID, domainName *string) (*DomainRow, error)

SelectDomain mocks base method.

func (*MockDomainCRUD) SelectDomainMetadata added in v0.23.1

func (m *MockDomainCRUD) SelectDomainMetadata(ctx context.Context) (int64, error)

SelectDomainMetadata mocks base method.

func (*MockDomainCRUD) UpdateDomain added in v0.23.1

func (m *MockDomainCRUD) UpdateDomain(ctx context.Context, row *DomainRow) error

UpdateDomain mocks base method.

type MockDomainCRUDMockRecorder added in v0.23.1

type MockDomainCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MockDomainCRUDMockRecorder is the mock recorder for MockDomainCRUD.

func (*MockDomainCRUDMockRecorder) DeleteDomain added in v0.23.1

func (mr *MockDomainCRUDMockRecorder) DeleteDomain(ctx, domainID, domainName interface{}) *gomock.Call

DeleteDomain indicates an expected call of DeleteDomain.

func (*MockDomainCRUDMockRecorder) InsertDomain added in v0.23.1

func (mr *MockDomainCRUDMockRecorder) InsertDomain(ctx, row interface{}) *gomock.Call

InsertDomain indicates an expected call of InsertDomain.

func (*MockDomainCRUDMockRecorder) SelectAllDomains added in v0.23.1

func (mr *MockDomainCRUDMockRecorder) SelectAllDomains(ctx, pageSize, pageToken interface{}) *gomock.Call

SelectAllDomains indicates an expected call of SelectAllDomains.

func (*MockDomainCRUDMockRecorder) SelectDomain added in v0.23.1

func (mr *MockDomainCRUDMockRecorder) SelectDomain(ctx, domainID, domainName interface{}) *gomock.Call

SelectDomain indicates an expected call of SelectDomain.

func (*MockDomainCRUDMockRecorder) SelectDomainMetadata added in v0.23.1

func (mr *MockDomainCRUDMockRecorder) SelectDomainMetadata(ctx interface{}) *gomock.Call

SelectDomainMetadata indicates an expected call of SelectDomainMetadata.

func (*MockDomainCRUDMockRecorder) UpdateDomain added in v0.23.1

func (mr *MockDomainCRUDMockRecorder) UpdateDomain(ctx, row interface{}) *gomock.Call

UpdateDomain indicates an expected call of UpdateDomain.

type MockHistoryEventsCRUD added in v0.23.1

type MockHistoryEventsCRUD struct {
	// contains filtered or unexported fields
}

MockHistoryEventsCRUD is a mock of HistoryEventsCRUD interface.

func NewMockHistoryEventsCRUD added in v0.23.1

func NewMockHistoryEventsCRUD(ctrl *gomock.Controller) *MockHistoryEventsCRUD

NewMockHistoryEventsCRUD creates a new mock instance.

func (*MockHistoryEventsCRUD) DeleteFromHistoryTreeAndNode added in v0.23.1

func (m *MockHistoryEventsCRUD) DeleteFromHistoryTreeAndNode(ctx context.Context, treeFilter *HistoryTreeFilter, nodeFilters []*HistoryNodeFilter) error

DeleteFromHistoryTreeAndNode mocks base method.

func (*MockHistoryEventsCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockHistoryEventsCRUD) InsertIntoHistoryTreeAndNode added in v0.23.1

func (m *MockHistoryEventsCRUD) InsertIntoHistoryTreeAndNode(ctx context.Context, treeRow *HistoryTreeRow, nodeRow *HistoryNodeRow) error

InsertIntoHistoryTreeAndNode mocks base method.

func (*MockHistoryEventsCRUD) SelectAllHistoryTrees added in v0.23.1

func (m *MockHistoryEventsCRUD) SelectAllHistoryTrees(ctx context.Context, nextPageToken []byte, pageSize int) ([]*HistoryTreeRow, []byte, error)

SelectAllHistoryTrees mocks base method.

func (*MockHistoryEventsCRUD) SelectFromHistoryNode added in v0.23.1

func (m *MockHistoryEventsCRUD) SelectFromHistoryNode(ctx context.Context, filter *HistoryNodeFilter) ([]*HistoryNodeRow, []byte, error)

SelectFromHistoryNode mocks base method.

func (*MockHistoryEventsCRUD) SelectFromHistoryTree added in v0.23.1

func (m *MockHistoryEventsCRUD) SelectFromHistoryTree(ctx context.Context, filter *HistoryTreeFilter) ([]*HistoryTreeRow, error)

SelectFromHistoryTree mocks base method.

type MockHistoryEventsCRUDMockRecorder added in v0.23.1

type MockHistoryEventsCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MockHistoryEventsCRUDMockRecorder is the mock recorder for MockHistoryEventsCRUD.

func (*MockHistoryEventsCRUDMockRecorder) DeleteFromHistoryTreeAndNode added in v0.23.1

func (mr *MockHistoryEventsCRUDMockRecorder) DeleteFromHistoryTreeAndNode(ctx, treeFilter, nodeFilters interface{}) *gomock.Call

DeleteFromHistoryTreeAndNode indicates an expected call of DeleteFromHistoryTreeAndNode.

func (*MockHistoryEventsCRUDMockRecorder) InsertIntoHistoryTreeAndNode added in v0.23.1

func (mr *MockHistoryEventsCRUDMockRecorder) InsertIntoHistoryTreeAndNode(ctx, treeRow, nodeRow interface{}) *gomock.Call

InsertIntoHistoryTreeAndNode indicates an expected call of InsertIntoHistoryTreeAndNode.

func (*MockHistoryEventsCRUDMockRecorder) SelectAllHistoryTrees added in v0.23.1

func (mr *MockHistoryEventsCRUDMockRecorder) SelectAllHistoryTrees(ctx, nextPageToken, pageSize interface{}) *gomock.Call

SelectAllHistoryTrees indicates an expected call of SelectAllHistoryTrees.

func (*MockHistoryEventsCRUDMockRecorder) SelectFromHistoryNode added in v0.23.1

func (mr *MockHistoryEventsCRUDMockRecorder) SelectFromHistoryNode(ctx, filter interface{}) *gomock.Call

SelectFromHistoryNode indicates an expected call of SelectFromHistoryNode.

func (*MockHistoryEventsCRUDMockRecorder) SelectFromHistoryTree added in v0.23.1

func (mr *MockHistoryEventsCRUDMockRecorder) SelectFromHistoryTree(ctx, filter interface{}) *gomock.Call

SelectFromHistoryTree indicates an expected call of SelectFromHistoryTree.

type MockMessageQueueCRUD added in v0.23.1

type MockMessageQueueCRUD struct {
	// contains filtered or unexported fields
}

MockMessageQueueCRUD is a mock of MessageQueueCRUD interface.

func NewMockMessageQueueCRUD added in v0.23.1

func NewMockMessageQueueCRUD(ctrl *gomock.Controller) *MockMessageQueueCRUD

NewMockMessageQueueCRUD creates a new mock instance.

func (*MockMessageQueueCRUD) DeleteMessage added in v0.23.1

func (m *MockMessageQueueCRUD) DeleteMessage(ctx context.Context, queueType persistence.QueueType, messageID int64) error

DeleteMessage mocks base method.

func (*MockMessageQueueCRUD) DeleteMessagesBefore added in v0.23.1

func (m *MockMessageQueueCRUD) DeleteMessagesBefore(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64) error

DeleteMessagesBefore mocks base method.

func (*MockMessageQueueCRUD) DeleteMessagesInRange added in v0.23.1

func (m *MockMessageQueueCRUD) DeleteMessagesInRange(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID, inclusiveEndMessageID int64) error

DeleteMessagesInRange mocks base method.

func (*MockMessageQueueCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockMessageQueueCRUD) GetQueueSize added in v0.23.1

func (m *MockMessageQueueCRUD) GetQueueSize(ctx context.Context, queueType persistence.QueueType) (int64, error)

GetQueueSize mocks base method.

func (*MockMessageQueueCRUD) InsertIntoQueue added in v0.23.1

func (m *MockMessageQueueCRUD) InsertIntoQueue(ctx context.Context, row *QueueMessageRow) error

InsertIntoQueue mocks base method.

func (*MockMessageQueueCRUD) InsertQueueMetadata added in v0.23.1

func (m *MockMessageQueueCRUD) InsertQueueMetadata(ctx context.Context, queueType persistence.QueueType, version int64) error

InsertQueueMetadata mocks base method.

func (*MockMessageQueueCRUD) SelectLastEnqueuedMessageID added in v0.23.1

func (m *MockMessageQueueCRUD) SelectLastEnqueuedMessageID(ctx context.Context, queueType persistence.QueueType) (int64, error)

SelectLastEnqueuedMessageID mocks base method.

func (*MockMessageQueueCRUD) SelectMessagesBetween added in v0.23.1

SelectMessagesBetween mocks base method.

func (*MockMessageQueueCRUD) SelectMessagesFrom added in v0.23.1

func (m *MockMessageQueueCRUD) SelectMessagesFrom(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64, maxRows int) ([]*QueueMessageRow, error)

SelectMessagesFrom mocks base method.

func (*MockMessageQueueCRUD) SelectQueueMetadata added in v0.23.1

func (m *MockMessageQueueCRUD) SelectQueueMetadata(ctx context.Context, queueType persistence.QueueType) (*QueueMetadataRow, error)

SelectQueueMetadata mocks base method.

func (*MockMessageQueueCRUD) UpdateQueueMetadataCas added in v0.23.1

func (m *MockMessageQueueCRUD) UpdateQueueMetadataCas(ctx context.Context, row QueueMetadataRow) error

UpdateQueueMetadataCas mocks base method.

type MockMessageQueueCRUDMockRecorder added in v0.23.1

type MockMessageQueueCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MockMessageQueueCRUDMockRecorder is the mock recorder for MockMessageQueueCRUD.

func (*MockMessageQueueCRUDMockRecorder) DeleteMessage added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) DeleteMessage(ctx, queueType, messageID interface{}) *gomock.Call

DeleteMessage indicates an expected call of DeleteMessage.

func (*MockMessageQueueCRUDMockRecorder) DeleteMessagesBefore added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) DeleteMessagesBefore(ctx, queueType, exclusiveBeginMessageID interface{}) *gomock.Call

DeleteMessagesBefore indicates an expected call of DeleteMessagesBefore.

func (*MockMessageQueueCRUDMockRecorder) DeleteMessagesInRange added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) DeleteMessagesInRange(ctx, queueType, exclusiveBeginMessageID, inclusiveEndMessageID interface{}) *gomock.Call

DeleteMessagesInRange indicates an expected call of DeleteMessagesInRange.

func (*MockMessageQueueCRUDMockRecorder) GetQueueSize added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) GetQueueSize(ctx, queueType interface{}) *gomock.Call

GetQueueSize indicates an expected call of GetQueueSize.

func (*MockMessageQueueCRUDMockRecorder) InsertIntoQueue added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) InsertIntoQueue(ctx, row interface{}) *gomock.Call

InsertIntoQueue indicates an expected call of InsertIntoQueue.

func (*MockMessageQueueCRUDMockRecorder) InsertQueueMetadata added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) InsertQueueMetadata(ctx, queueType, version interface{}) *gomock.Call

InsertQueueMetadata indicates an expected call of InsertQueueMetadata.

func (*MockMessageQueueCRUDMockRecorder) SelectLastEnqueuedMessageID added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) SelectLastEnqueuedMessageID(ctx, queueType interface{}) *gomock.Call

SelectLastEnqueuedMessageID indicates an expected call of SelectLastEnqueuedMessageID.

func (*MockMessageQueueCRUDMockRecorder) SelectMessagesBetween added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) SelectMessagesBetween(ctx, request interface{}) *gomock.Call

SelectMessagesBetween indicates an expected call of SelectMessagesBetween.

func (*MockMessageQueueCRUDMockRecorder) SelectMessagesFrom added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) SelectMessagesFrom(ctx, queueType, exclusiveBeginMessageID, maxRows interface{}) *gomock.Call

SelectMessagesFrom indicates an expected call of SelectMessagesFrom.

func (*MockMessageQueueCRUDMockRecorder) SelectQueueMetadata added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) SelectQueueMetadata(ctx, queueType interface{}) *gomock.Call

SelectQueueMetadata indicates an expected call of SelectQueueMetadata.

func (*MockMessageQueueCRUDMockRecorder) UpdateQueueMetadataCas added in v0.23.1

func (mr *MockMessageQueueCRUDMockRecorder) UpdateQueueMetadataCas(ctx, row interface{}) *gomock.Call

UpdateQueueMetadataCas indicates an expected call of UpdateQueueMetadataCas.

type MockPlugin added in v0.23.1

type MockPlugin struct {
	// contains filtered or unexported fields
}

MockPlugin is a mock of Plugin interface.

func NewMockPlugin added in v0.23.1

func NewMockPlugin(ctrl *gomock.Controller) *MockPlugin

NewMockPlugin creates a new mock instance.

func (*MockPlugin) CreateAdminDB added in v0.23.1

func (m *MockPlugin) CreateAdminDB(cfg *config.NoSQL, logger log.Logger, dc *persistence.DynamicConfiguration) (AdminDB, error)

CreateAdminDB mocks base method.

func (*MockPlugin) CreateDB added in v0.23.1

func (m *MockPlugin) CreateDB(cfg *config.NoSQL, logger log.Logger, dc *persistence.DynamicConfiguration) (DB, error)

CreateDB mocks base method.

func (*MockPlugin) EXPECT added in v0.23.1

func (m *MockPlugin) EXPECT() *MockPluginMockRecorder

EXPECT returns an object that allows the caller to indicate expected use.

type MockPluginMockRecorder added in v0.23.1

type MockPluginMockRecorder struct {
	// contains filtered or unexported fields
}

MockPluginMockRecorder is the mock recorder for MockPlugin.

func (*MockPluginMockRecorder) CreateAdminDB added in v0.23.1

func (mr *MockPluginMockRecorder) CreateAdminDB(cfg, logger, dc interface{}) *gomock.Call

CreateAdminDB indicates an expected call of CreateAdminDB.

func (*MockPluginMockRecorder) CreateDB added in v0.23.1

func (mr *MockPluginMockRecorder) CreateDB(cfg, logger, dc interface{}) *gomock.Call

CreateDB indicates an expected call of CreateDB.

type MockShardCRUD added in v0.23.1

type MockShardCRUD struct {
	// contains filtered or unexported fields
}

MockShardCRUD is a mock of ShardCRUD interface.

func NewMockShardCRUD added in v0.23.1

func NewMockShardCRUD(ctrl *gomock.Controller) *MockShardCRUD

NewMockShardCRUD creates a new mock instance.

func (*MockShardCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockShardCRUD) InsertShard added in v0.23.1

func (m *MockShardCRUD) InsertShard(ctx context.Context, row *ShardRow) error

InsertShard mocks base method.

func (*MockShardCRUD) SelectShard added in v0.23.1

func (m *MockShardCRUD) SelectShard(ctx context.Context, shardID int, currentClusterName string) (int64, *ShardRow, error)

SelectShard mocks base method.

func (*MockShardCRUD) UpdateRangeID added in v0.23.1

func (m *MockShardCRUD) UpdateRangeID(ctx context.Context, shardID int, rangeID, previousRangeID int64) error

UpdateRangeID mocks base method.

func (*MockShardCRUD) UpdateShard added in v0.23.1

func (m *MockShardCRUD) UpdateShard(ctx context.Context, row *ShardRow, previousRangeID int64) error

UpdateShard mocks base method.

type MockShardCRUDMockRecorder added in v0.23.1

type MockShardCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MockShardCRUDMockRecorder is the mock recorder for MockShardCRUD.

func (*MockShardCRUDMockRecorder) InsertShard added in v0.23.1

func (mr *MockShardCRUDMockRecorder) InsertShard(ctx, row interface{}) *gomock.Call

InsertShard indicates an expected call of InsertShard.

func (*MockShardCRUDMockRecorder) SelectShard added in v0.23.1

func (mr *MockShardCRUDMockRecorder) SelectShard(ctx, shardID, currentClusterName interface{}) *gomock.Call

SelectShard indicates an expected call of SelectShard.

func (*MockShardCRUDMockRecorder) UpdateRangeID added in v0.23.1

func (mr *MockShardCRUDMockRecorder) UpdateRangeID(ctx, shardID, rangeID, previousRangeID interface{}) *gomock.Call

UpdateRangeID indicates an expected call of UpdateRangeID.

func (*MockShardCRUDMockRecorder) UpdateShard added in v0.23.1

func (mr *MockShardCRUDMockRecorder) UpdateShard(ctx, row, previousRangeID interface{}) *gomock.Call

UpdateShard indicates an expected call of UpdateShard.

type MockTaskCRUD added in v0.23.1

type MockTaskCRUD struct {
	// contains filtered or unexported fields
}

MockTaskCRUD is a mock of TaskCRUD interface.

func NewMockTaskCRUD added in v0.23.1

func NewMockTaskCRUD(ctrl *gomock.Controller) *MockTaskCRUD

NewMockTaskCRUD creates a new mock instance.

func (*MockTaskCRUD) DeleteTaskList added in v0.23.1

func (m *MockTaskCRUD) DeleteTaskList(ctx context.Context, filter *TaskListFilter, previousRangeID int64) error

DeleteTaskList mocks base method.

func (*MockTaskCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockTaskCRUD) InsertTaskList added in v0.23.1

func (m *MockTaskCRUD) InsertTaskList(ctx context.Context, row *TaskListRow) error

InsertTaskList mocks base method.

func (*MockTaskCRUD) InsertTasks added in v0.23.1

func (m *MockTaskCRUD) InsertTasks(ctx context.Context, tasksToInsert []*TaskRowForInsert, tasklistCondition *TaskListRow) error

InsertTasks mocks base method.

func (*MockTaskCRUD) ListTaskList added in v0.23.1

func (m *MockTaskCRUD) ListTaskList(ctx context.Context, pageSize int, nextPageToken []byte) (*ListTaskListResult, error)

ListTaskList mocks base method.

func (*MockTaskCRUD) RangeDeleteTasks added in v0.23.1

func (m *MockTaskCRUD) RangeDeleteTasks(ctx context.Context, filter *TasksFilter) (int, error)

RangeDeleteTasks mocks base method.

func (*MockTaskCRUD) SelectTaskList added in v0.23.1

func (m *MockTaskCRUD) SelectTaskList(ctx context.Context, filter *TaskListFilter) (*TaskListRow, error)

SelectTaskList mocks base method.

func (*MockTaskCRUD) SelectTasks added in v0.23.1

func (m *MockTaskCRUD) SelectTasks(ctx context.Context, filter *TasksFilter) ([]*TaskRow, error)

SelectTasks mocks base method.

func (*MockTaskCRUD) UpdateTaskList added in v0.23.1

func (m *MockTaskCRUD) UpdateTaskList(ctx context.Context, row *TaskListRow, previousRangeID int64) error

UpdateTaskList mocks base method.

func (*MockTaskCRUD) UpdateTaskListWithTTL added in v0.23.1

func (m *MockTaskCRUD) UpdateTaskListWithTTL(ctx context.Context, ttlSeconds int64, row *TaskListRow, previousRangeID int64) error

UpdateTaskListWithTTL mocks base method.

type MockTaskCRUDMockRecorder added in v0.23.1

type MockTaskCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MockTaskCRUDMockRecorder is the mock recorder for MockTaskCRUD.

func (*MockTaskCRUDMockRecorder) DeleteTaskList added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) DeleteTaskList(ctx, filter, previousRangeID interface{}) *gomock.Call

DeleteTaskList indicates an expected call of DeleteTaskList.

func (*MockTaskCRUDMockRecorder) InsertTaskList added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) InsertTaskList(ctx, row interface{}) *gomock.Call

InsertTaskList indicates an expected call of InsertTaskList.

func (*MockTaskCRUDMockRecorder) InsertTasks added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) InsertTasks(ctx, tasksToInsert, tasklistCondition interface{}) *gomock.Call

InsertTasks indicates an expected call of InsertTasks.

func (*MockTaskCRUDMockRecorder) ListTaskList added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) ListTaskList(ctx, pageSize, nextPageToken interface{}) *gomock.Call

ListTaskList indicates an expected call of ListTaskList.

func (*MockTaskCRUDMockRecorder) RangeDeleteTasks added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) RangeDeleteTasks(ctx, filter interface{}) *gomock.Call

RangeDeleteTasks indicates an expected call of RangeDeleteTasks.

func (*MockTaskCRUDMockRecorder) SelectTaskList added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) SelectTaskList(ctx, filter interface{}) *gomock.Call

SelectTaskList indicates an expected call of SelectTaskList.

func (*MockTaskCRUDMockRecorder) SelectTasks added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) SelectTasks(ctx, filter interface{}) *gomock.Call

SelectTasks indicates an expected call of SelectTasks.

func (*MockTaskCRUDMockRecorder) UpdateTaskList added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) UpdateTaskList(ctx, row, previousRangeID interface{}) *gomock.Call

UpdateTaskList indicates an expected call of UpdateTaskList.

func (*MockTaskCRUDMockRecorder) UpdateTaskListWithTTL added in v0.23.1

func (mr *MockTaskCRUDMockRecorder) UpdateTaskListWithTTL(ctx, ttlSeconds, row, previousRangeID interface{}) *gomock.Call

UpdateTaskListWithTTL indicates an expected call of UpdateTaskListWithTTL.

type MockVisibilityCRUD added in v0.23.1

type MockVisibilityCRUD struct {
	// contains filtered or unexported fields
}

MockVisibilityCRUD is a mock of VisibilityCRUD interface.

func NewMockVisibilityCRUD added in v0.23.1

func NewMockVisibilityCRUD(ctrl *gomock.Controller) *MockVisibilityCRUD

NewMockVisibilityCRUD creates a new mock instance.

func (*MockVisibilityCRUD) DeleteVisibility added in v0.23.1

func (m *MockVisibilityCRUD) DeleteVisibility(ctx context.Context, domainID, workflowID, runID string) error

DeleteVisibility mocks base method.

func (*MockVisibilityCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockVisibilityCRUD) InsertVisibility added in v0.23.1

func (m *MockVisibilityCRUD) InsertVisibility(ctx context.Context, ttlSeconds int64, row *VisibilityRowForInsert) error

InsertVisibility mocks base method.

func (*MockVisibilityCRUD) SelectOneClosedWorkflow added in v0.23.1

func (m *MockVisibilityCRUD) SelectOneClosedWorkflow(ctx context.Context, domainID, workflowID, runID string) (*VisibilityRow, error)

SelectOneClosedWorkflow mocks base method.

func (*MockVisibilityCRUD) SelectVisibility added in v0.23.1

func (m *MockVisibilityCRUD) SelectVisibility(ctx context.Context, filter *VisibilityFilter) (*SelectVisibilityResponse, error)

SelectVisibility mocks base method.

func (*MockVisibilityCRUD) UpdateVisibility added in v0.23.1

func (m *MockVisibilityCRUD) UpdateVisibility(ctx context.Context, ttlSeconds int64, row *VisibilityRowForUpdate) error

UpdateVisibility mocks base method.

type MockVisibilityCRUDMockRecorder added in v0.23.1

type MockVisibilityCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MockVisibilityCRUDMockRecorder is the mock recorder for MockVisibilityCRUD.

func (*MockVisibilityCRUDMockRecorder) DeleteVisibility added in v0.23.1

func (mr *MockVisibilityCRUDMockRecorder) DeleteVisibility(ctx, domainID, workflowID, runID interface{}) *gomock.Call

DeleteVisibility indicates an expected call of DeleteVisibility.

func (*MockVisibilityCRUDMockRecorder) InsertVisibility added in v0.23.1

func (mr *MockVisibilityCRUDMockRecorder) InsertVisibility(ctx, ttlSeconds, row interface{}) *gomock.Call

InsertVisibility indicates an expected call of InsertVisibility.

func (*MockVisibilityCRUDMockRecorder) SelectOneClosedWorkflow added in v0.23.1

func (mr *MockVisibilityCRUDMockRecorder) SelectOneClosedWorkflow(ctx, domainID, workflowID, runID interface{}) *gomock.Call

SelectOneClosedWorkflow indicates an expected call of SelectOneClosedWorkflow.

func (*MockVisibilityCRUDMockRecorder) SelectVisibility added in v0.23.1

func (mr *MockVisibilityCRUDMockRecorder) SelectVisibility(ctx, filter interface{}) *gomock.Call

SelectVisibility indicates an expected call of SelectVisibility.

func (*MockVisibilityCRUDMockRecorder) UpdateVisibility added in v0.23.1

func (mr *MockVisibilityCRUDMockRecorder) UpdateVisibility(ctx, ttlSeconds, row interface{}) *gomock.Call

UpdateVisibility indicates an expected call of UpdateVisibility.

type MockWorkflowCRUD added in v0.23.1

type MockWorkflowCRUD struct {
	// contains filtered or unexported fields
}

MockWorkflowCRUD is a mock of WorkflowCRUD interface.

func NewMockWorkflowCRUD added in v0.23.1

func NewMockWorkflowCRUD(ctrl *gomock.Controller) *MockWorkflowCRUD

NewMockWorkflowCRUD creates a new mock instance.

func (*MockWorkflowCRUD) DeleteCrossClusterTask added in v0.23.1

func (m *MockWorkflowCRUD) DeleteCrossClusterTask(ctx context.Context, shardID int, targetCluster string, taskID int64) error

DeleteCrossClusterTask mocks base method.

func (*MockWorkflowCRUD) DeleteCurrentWorkflow added in v0.23.1

func (m *MockWorkflowCRUD) DeleteCurrentWorkflow(ctx context.Context, shardID int, domainID, workflowID, currentRunIDCondition string) error

DeleteCurrentWorkflow mocks base method.

func (*MockWorkflowCRUD) DeleteReplicationDLQTask added in v0.23.1

func (m *MockWorkflowCRUD) DeleteReplicationDLQTask(ctx context.Context, shardID int, sourceCluster string, taskID int64) error

DeleteReplicationDLQTask mocks base method.

func (*MockWorkflowCRUD) DeleteReplicationTask added in v0.23.1

func (m *MockWorkflowCRUD) DeleteReplicationTask(ctx context.Context, shardID int, taskID int64) error

DeleteReplicationTask mocks base method.

func (*MockWorkflowCRUD) DeleteTimerTask added in v0.23.1

func (m *MockWorkflowCRUD) DeleteTimerTask(ctx context.Context, shardID int, taskID int64, visibilityTimestamp time.Time) error

DeleteTimerTask mocks base method.

func (*MockWorkflowCRUD) DeleteTransferTask added in v0.23.1

func (m *MockWorkflowCRUD) DeleteTransferTask(ctx context.Context, shardID int, taskID int64) error

DeleteTransferTask mocks base method.

func (*MockWorkflowCRUD) DeleteWorkflowExecution added in v0.23.1

func (m *MockWorkflowCRUD) DeleteWorkflowExecution(ctx context.Context, shardID int, domainID, workflowID, runID string) error

DeleteWorkflowExecution mocks base method.

func (*MockWorkflowCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockWorkflowCRUD) InsertReplicationDLQTask added in v0.23.1

func (m *MockWorkflowCRUD) InsertReplicationDLQTask(ctx context.Context, shardID int, sourceCluster string, task ReplicationTask) error

InsertReplicationDLQTask mocks base method.

func (*MockWorkflowCRUD) InsertReplicationTask added in v0.23.1

func (m *MockWorkflowCRUD) InsertReplicationTask(ctx context.Context, tasks []*ReplicationTask, condition ShardCondition) error

InsertReplicationTask mocks base method.

func (*MockWorkflowCRUD) InsertWorkflowExecutionWithTasks added in v0.23.1

func (m *MockWorkflowCRUD) InsertWorkflowExecutionWithTasks(ctx context.Context, currentWorkflowRequest *CurrentWorkflowWriteRequest, execution *WorkflowExecutionRequest, transferTasks []*TransferTask, crossClusterTasks []*CrossClusterTask, replicationTasks []*ReplicationTask, timerTasks []*TimerTask, shardCondition *ShardCondition) error

InsertWorkflowExecutionWithTasks mocks base method.

func (*MockWorkflowCRUD) IsWorkflowExecutionExists added in v0.23.1

func (m *MockWorkflowCRUD) IsWorkflowExecutionExists(ctx context.Context, shardID int, domainID, workflowID, runID string) (bool, error)

IsWorkflowExecutionExists mocks base method.

func (*MockWorkflowCRUD) RangeDeleteCrossClusterTasks added in v0.23.1

func (m *MockWorkflowCRUD) RangeDeleteCrossClusterTasks(ctx context.Context, shardID int, targetCluster string, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteCrossClusterTasks mocks base method.

func (*MockWorkflowCRUD) RangeDeleteReplicationDLQTasks added in v0.23.1

func (m *MockWorkflowCRUD) RangeDeleteReplicationDLQTasks(ctx context.Context, shardID int, sourceCluster string, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteReplicationDLQTasks mocks base method.

func (*MockWorkflowCRUD) RangeDeleteReplicationTasks added in v0.23.1

func (m *MockWorkflowCRUD) RangeDeleteReplicationTasks(ctx context.Context, shardID int, inclusiveEndTaskID int64) error

RangeDeleteReplicationTasks mocks base method.

func (*MockWorkflowCRUD) RangeDeleteTimerTasks added in v0.23.1

func (m *MockWorkflowCRUD) RangeDeleteTimerTasks(ctx context.Context, shardID int, inclusiveMinTime, exclusiveMaxTime time.Time) error

RangeDeleteTimerTasks mocks base method.

func (*MockWorkflowCRUD) RangeDeleteTransferTasks added in v0.23.1

func (m *MockWorkflowCRUD) RangeDeleteTransferTasks(ctx context.Context, shardID int, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteTransferTasks mocks base method.

func (*MockWorkflowCRUD) SelectAllCurrentWorkflows added in v0.23.1

func (m *MockWorkflowCRUD) SelectAllCurrentWorkflows(ctx context.Context, shardID int, pageToken []byte, pageSize int) ([]*persistence.CurrentWorkflowExecution, []byte, error)

SelectAllCurrentWorkflows mocks base method.

func (*MockWorkflowCRUD) SelectAllWorkflowExecutions added in v0.23.1

func (m *MockWorkflowCRUD) SelectAllWorkflowExecutions(ctx context.Context, shardID int, pageToken []byte, pageSize int) ([]*persistence.InternalListConcreteExecutionsEntity, []byte, error)

SelectAllWorkflowExecutions mocks base method.

func (*MockWorkflowCRUD) SelectCrossClusterTasksOrderByTaskID added in v0.23.1

func (m *MockWorkflowCRUD) SelectCrossClusterTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, targetCluster string, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*CrossClusterTask, []byte, error)

SelectCrossClusterTasksOrderByTaskID mocks base method.

func (*MockWorkflowCRUD) SelectCurrentWorkflow added in v0.23.1

func (m *MockWorkflowCRUD) SelectCurrentWorkflow(ctx context.Context, shardID int, domainID, workflowID string) (*CurrentWorkflowRow, error)

SelectCurrentWorkflow mocks base method.

func (*MockWorkflowCRUD) SelectReplicationDLQTasksCount added in v0.23.1

func (m *MockWorkflowCRUD) SelectReplicationDLQTasksCount(ctx context.Context, shardID int, sourceCluster string) (int64, error)

SelectReplicationDLQTasksCount mocks base method.

func (*MockWorkflowCRUD) SelectReplicationDLQTasksOrderByTaskID added in v0.23.1

func (m *MockWorkflowCRUD) SelectReplicationDLQTasksOrderByTaskID(ctx context.Context, shardID int, sourceCluster string, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*ReplicationTask, []byte, error)

SelectReplicationDLQTasksOrderByTaskID mocks base method.

func (*MockWorkflowCRUD) SelectReplicationTasksOrderByTaskID added in v0.23.1

func (m *MockWorkflowCRUD) SelectReplicationTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*ReplicationTask, []byte, error)

SelectReplicationTasksOrderByTaskID mocks base method.

func (*MockWorkflowCRUD) SelectTimerTasksOrderByVisibilityTime added in v0.23.1

func (m *MockWorkflowCRUD) SelectTimerTasksOrderByVisibilityTime(ctx context.Context, shardID, pageSize int, pageToken []byte, inclusiveMinTime, exclusiveMaxTime time.Time) ([]*TimerTask, []byte, error)

SelectTimerTasksOrderByVisibilityTime mocks base method.

func (*MockWorkflowCRUD) SelectTransferTasksOrderByTaskID added in v0.23.1

func (m *MockWorkflowCRUD) SelectTransferTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*TransferTask, []byte, error)

SelectTransferTasksOrderByTaskID mocks base method.

func (*MockWorkflowCRUD) SelectWorkflowExecution added in v0.23.1

func (m *MockWorkflowCRUD) SelectWorkflowExecution(ctx context.Context, shardID int, domainID, workflowID, runID string) (*WorkflowExecution, error)

SelectWorkflowExecution mocks base method.

func (*MockWorkflowCRUD) UpdateWorkflowExecutionWithTasks added in v0.23.1

func (m *MockWorkflowCRUD) UpdateWorkflowExecutionWithTasks(ctx context.Context, currentWorkflowRequest *CurrentWorkflowWriteRequest, mutatedExecution, insertedExecution, resetExecution *WorkflowExecutionRequest, transferTasks []*TransferTask, crossClusterTasks []*CrossClusterTask, replicationTasks []*ReplicationTask, timerTasks []*TimerTask, shardCondition *ShardCondition) error

UpdateWorkflowExecutionWithTasks mocks base method.

type MockWorkflowCRUDMockRecorder added in v0.23.1

type MockWorkflowCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MockWorkflowCRUDMockRecorder is the mock recorder for MockWorkflowCRUD.

func (*MockWorkflowCRUDMockRecorder) DeleteCrossClusterTask added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) DeleteCrossClusterTask(ctx, shardID, targetCluster, taskID interface{}) *gomock.Call

DeleteCrossClusterTask indicates an expected call of DeleteCrossClusterTask.

func (*MockWorkflowCRUDMockRecorder) DeleteCurrentWorkflow added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) DeleteCurrentWorkflow(ctx, shardID, domainID, workflowID, currentRunIDCondition interface{}) *gomock.Call

DeleteCurrentWorkflow indicates an expected call of DeleteCurrentWorkflow.

func (*MockWorkflowCRUDMockRecorder) DeleteReplicationDLQTask added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) DeleteReplicationDLQTask(ctx, shardID, sourceCluster, taskID interface{}) *gomock.Call

DeleteReplicationDLQTask indicates an expected call of DeleteReplicationDLQTask.

func (*MockWorkflowCRUDMockRecorder) DeleteReplicationTask added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) DeleteReplicationTask(ctx, shardID, taskID interface{}) *gomock.Call

DeleteReplicationTask indicates an expected call of DeleteReplicationTask.

func (*MockWorkflowCRUDMockRecorder) DeleteTimerTask added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) DeleteTimerTask(ctx, shardID, taskID, visibilityTimestamp interface{}) *gomock.Call

DeleteTimerTask indicates an expected call of DeleteTimerTask.

func (*MockWorkflowCRUDMockRecorder) DeleteTransferTask added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) DeleteTransferTask(ctx, shardID, taskID interface{}) *gomock.Call

DeleteTransferTask indicates an expected call of DeleteTransferTask.

func (*MockWorkflowCRUDMockRecorder) DeleteWorkflowExecution added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) DeleteWorkflowExecution(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

DeleteWorkflowExecution indicates an expected call of DeleteWorkflowExecution.

func (*MockWorkflowCRUDMockRecorder) InsertReplicationDLQTask added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) InsertReplicationDLQTask(ctx, shardID, sourceCluster, task interface{}) *gomock.Call

InsertReplicationDLQTask indicates an expected call of InsertReplicationDLQTask.

func (*MockWorkflowCRUDMockRecorder) InsertReplicationTask added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) InsertReplicationTask(ctx, tasks, condition interface{}) *gomock.Call

InsertReplicationTask indicates an expected call of InsertReplicationTask.

func (*MockWorkflowCRUDMockRecorder) InsertWorkflowExecutionWithTasks added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) InsertWorkflowExecutionWithTasks(ctx, currentWorkflowRequest, execution, transferTasks, crossClusterTasks, replicationTasks, timerTasks, shardCondition interface{}) *gomock.Call

InsertWorkflowExecutionWithTasks indicates an expected call of InsertWorkflowExecutionWithTasks.

func (*MockWorkflowCRUDMockRecorder) IsWorkflowExecutionExists added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) IsWorkflowExecutionExists(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

IsWorkflowExecutionExists indicates an expected call of IsWorkflowExecutionExists.

func (*MockWorkflowCRUDMockRecorder) RangeDeleteCrossClusterTasks added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) RangeDeleteCrossClusterTasks(ctx, shardID, targetCluster, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteCrossClusterTasks indicates an expected call of RangeDeleteCrossClusterTasks.

func (*MockWorkflowCRUDMockRecorder) RangeDeleteReplicationDLQTasks added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) RangeDeleteReplicationDLQTasks(ctx, shardID, sourceCluster, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteReplicationDLQTasks indicates an expected call of RangeDeleteReplicationDLQTasks.

func (*MockWorkflowCRUDMockRecorder) RangeDeleteReplicationTasks added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) RangeDeleteReplicationTasks(ctx, shardID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteReplicationTasks indicates an expected call of RangeDeleteReplicationTasks.

func (*MockWorkflowCRUDMockRecorder) RangeDeleteTimerTasks added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) RangeDeleteTimerTasks(ctx, shardID, inclusiveMinTime, exclusiveMaxTime interface{}) *gomock.Call

RangeDeleteTimerTasks indicates an expected call of RangeDeleteTimerTasks.

func (*MockWorkflowCRUDMockRecorder) RangeDeleteTransferTasks added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) RangeDeleteTransferTasks(ctx, shardID, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteTransferTasks indicates an expected call of RangeDeleteTransferTasks.

func (*MockWorkflowCRUDMockRecorder) SelectAllCurrentWorkflows added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectAllCurrentWorkflows(ctx, shardID, pageToken, pageSize interface{}) *gomock.Call

SelectAllCurrentWorkflows indicates an expected call of SelectAllCurrentWorkflows.

func (*MockWorkflowCRUDMockRecorder) SelectAllWorkflowExecutions added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectAllWorkflowExecutions(ctx, shardID, pageToken, pageSize interface{}) *gomock.Call

SelectAllWorkflowExecutions indicates an expected call of SelectAllWorkflowExecutions.

func (*MockWorkflowCRUDMockRecorder) SelectCrossClusterTasksOrderByTaskID added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectCrossClusterTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, targetCluster, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectCrossClusterTasksOrderByTaskID indicates an expected call of SelectCrossClusterTasksOrderByTaskID.

func (*MockWorkflowCRUDMockRecorder) SelectCurrentWorkflow added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectCurrentWorkflow(ctx, shardID, domainID, workflowID interface{}) *gomock.Call

SelectCurrentWorkflow indicates an expected call of SelectCurrentWorkflow.

func (*MockWorkflowCRUDMockRecorder) SelectReplicationDLQTasksCount added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectReplicationDLQTasksCount(ctx, shardID, sourceCluster interface{}) *gomock.Call

SelectReplicationDLQTasksCount indicates an expected call of SelectReplicationDLQTasksCount.

func (*MockWorkflowCRUDMockRecorder) SelectReplicationDLQTasksOrderByTaskID added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectReplicationDLQTasksOrderByTaskID(ctx, shardID, sourceCluster, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectReplicationDLQTasksOrderByTaskID indicates an expected call of SelectReplicationDLQTasksOrderByTaskID.

func (*MockWorkflowCRUDMockRecorder) SelectReplicationTasksOrderByTaskID added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectReplicationTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectReplicationTasksOrderByTaskID indicates an expected call of SelectReplicationTasksOrderByTaskID.

func (*MockWorkflowCRUDMockRecorder) SelectTimerTasksOrderByVisibilityTime added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectTimerTasksOrderByVisibilityTime(ctx, shardID, pageSize, pageToken, inclusiveMinTime, exclusiveMaxTime interface{}) *gomock.Call

SelectTimerTasksOrderByVisibilityTime indicates an expected call of SelectTimerTasksOrderByVisibilityTime.

func (*MockWorkflowCRUDMockRecorder) SelectTransferTasksOrderByTaskID added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectTransferTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectTransferTasksOrderByTaskID indicates an expected call of SelectTransferTasksOrderByTaskID.

func (*MockWorkflowCRUDMockRecorder) SelectWorkflowExecution added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) SelectWorkflowExecution(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

SelectWorkflowExecution indicates an expected call of SelectWorkflowExecution.

func (*MockWorkflowCRUDMockRecorder) UpdateWorkflowExecutionWithTasks added in v0.23.1

func (mr *MockWorkflowCRUDMockRecorder) UpdateWorkflowExecutionWithTasks(ctx, currentWorkflowRequest, mutatedExecution, insertedExecution, resetExecution, transferTasks, crossClusterTasks, replicationTasks, timerTasks, shardCondition interface{}) *gomock.Call

UpdateWorkflowExecutionWithTasks indicates an expected call of UpdateWorkflowExecutionWithTasks.

type MocktableCRUD added in v0.23.1

type MocktableCRUD struct {
	// contains filtered or unexported fields
}

MocktableCRUD is a mock of tableCRUD interface.

func NewMocktableCRUD added in v0.23.1

func NewMocktableCRUD(ctrl *gomock.Controller) *MocktableCRUD

NewMocktableCRUD creates a new mock instance.

func (*MocktableCRUD) DeleteCrossClusterTask added in v0.23.1

func (m *MocktableCRUD) DeleteCrossClusterTask(ctx context.Context, shardID int, targetCluster string, taskID int64) error

DeleteCrossClusterTask mocks base method.

func (*MocktableCRUD) DeleteCurrentWorkflow added in v0.23.1

func (m *MocktableCRUD) DeleteCurrentWorkflow(ctx context.Context, shardID int, domainID, workflowID, currentRunIDCondition string) error

DeleteCurrentWorkflow mocks base method.

func (*MocktableCRUD) DeleteDomain added in v0.23.1

func (m *MocktableCRUD) DeleteDomain(ctx context.Context, domainID, domainName *string) error

DeleteDomain mocks base method.

func (*MocktableCRUD) DeleteFromHistoryTreeAndNode added in v0.23.1

func (m *MocktableCRUD) DeleteFromHistoryTreeAndNode(ctx context.Context, treeFilter *HistoryTreeFilter, nodeFilters []*HistoryNodeFilter) error

DeleteFromHistoryTreeAndNode mocks base method.

func (*MocktableCRUD) DeleteMessage added in v0.23.1

func (m *MocktableCRUD) DeleteMessage(ctx context.Context, queueType persistence.QueueType, messageID int64) error

DeleteMessage mocks base method.

func (*MocktableCRUD) DeleteMessagesBefore added in v0.23.1

func (m *MocktableCRUD) DeleteMessagesBefore(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64) error

DeleteMessagesBefore mocks base method.

func (*MocktableCRUD) DeleteMessagesInRange added in v0.23.1

func (m *MocktableCRUD) DeleteMessagesInRange(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID, inclusiveEndMessageID int64) error

DeleteMessagesInRange mocks base method.

func (*MocktableCRUD) DeleteReplicationDLQTask added in v0.23.1

func (m *MocktableCRUD) DeleteReplicationDLQTask(ctx context.Context, shardID int, sourceCluster string, taskID int64) error

DeleteReplicationDLQTask mocks base method.

func (*MocktableCRUD) DeleteReplicationTask added in v0.23.1

func (m *MocktableCRUD) DeleteReplicationTask(ctx context.Context, shardID int, taskID int64) error

DeleteReplicationTask mocks base method.

func (*MocktableCRUD) DeleteTaskList added in v0.23.1

func (m *MocktableCRUD) DeleteTaskList(ctx context.Context, filter *TaskListFilter, previousRangeID int64) error

DeleteTaskList mocks base method.

func (*MocktableCRUD) DeleteTimerTask added in v0.23.1

func (m *MocktableCRUD) DeleteTimerTask(ctx context.Context, shardID int, taskID int64, visibilityTimestamp time.Time) error

DeleteTimerTask mocks base method.

func (*MocktableCRUD) DeleteTransferTask added in v0.23.1

func (m *MocktableCRUD) DeleteTransferTask(ctx context.Context, shardID int, taskID int64) error

DeleteTransferTask mocks base method.

func (*MocktableCRUD) DeleteVisibility added in v0.23.1

func (m *MocktableCRUD) DeleteVisibility(ctx context.Context, domainID, workflowID, runID string) error

DeleteVisibility mocks base method.

func (*MocktableCRUD) DeleteWorkflowExecution added in v0.23.1

func (m *MocktableCRUD) DeleteWorkflowExecution(ctx context.Context, shardID int, domainID, workflowID, runID string) error

DeleteWorkflowExecution mocks base method.

func (*MocktableCRUD) EXPECT added in v0.23.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MocktableCRUD) GetQueueSize added in v0.23.1

func (m *MocktableCRUD) GetQueueSize(ctx context.Context, queueType persistence.QueueType) (int64, error)

GetQueueSize mocks base method.

func (*MocktableCRUD) InsertConfig added in v0.23.1

InsertConfig mocks base method.

func (*MocktableCRUD) InsertDomain added in v0.23.1

func (m *MocktableCRUD) InsertDomain(ctx context.Context, row *DomainRow) error

InsertDomain mocks base method.

func (*MocktableCRUD) InsertIntoHistoryTreeAndNode added in v0.23.1

func (m *MocktableCRUD) InsertIntoHistoryTreeAndNode(ctx context.Context, treeRow *HistoryTreeRow, nodeRow *HistoryNodeRow) error

InsertIntoHistoryTreeAndNode mocks base method.

func (*MocktableCRUD) InsertIntoQueue added in v0.23.1

func (m *MocktableCRUD) InsertIntoQueue(ctx context.Context, row *QueueMessageRow) error

InsertIntoQueue mocks base method.

func (*MocktableCRUD) InsertQueueMetadata added in v0.23.1

func (m *MocktableCRUD) InsertQueueMetadata(ctx context.Context, queueType persistence.QueueType, version int64) error

InsertQueueMetadata mocks base method.

func (*MocktableCRUD) InsertReplicationDLQTask added in v0.23.1

func (m *MocktableCRUD) InsertReplicationDLQTask(ctx context.Context, shardID int, sourceCluster string, task ReplicationTask) error

InsertReplicationDLQTask mocks base method.

func (*MocktableCRUD) InsertReplicationTask added in v0.23.1

func (m *MocktableCRUD) InsertReplicationTask(ctx context.Context, tasks []*ReplicationTask, condition ShardCondition) error

InsertReplicationTask mocks base method.

func (*MocktableCRUD) InsertShard added in v0.23.1

func (m *MocktableCRUD) InsertShard(ctx context.Context, row *ShardRow) error

InsertShard mocks base method.

func (*MocktableCRUD) InsertTaskList added in v0.23.1

func (m *MocktableCRUD) InsertTaskList(ctx context.Context, row *TaskListRow) error

InsertTaskList mocks base method.

func (*MocktableCRUD) InsertTasks added in v0.23.1

func (m *MocktableCRUD) InsertTasks(ctx context.Context, tasksToInsert []*TaskRowForInsert, tasklistCondition *TaskListRow) error

InsertTasks mocks base method.

func (*MocktableCRUD) InsertVisibility added in v0.23.1

func (m *MocktableCRUD) InsertVisibility(ctx context.Context, ttlSeconds int64, row *VisibilityRowForInsert) error

InsertVisibility mocks base method.

func (*MocktableCRUD) InsertWorkflowExecutionWithTasks added in v0.23.1

func (m *MocktableCRUD) InsertWorkflowExecutionWithTasks(ctx context.Context, currentWorkflowRequest *CurrentWorkflowWriteRequest, execution *WorkflowExecutionRequest, transferTasks []*TransferTask, crossClusterTasks []*CrossClusterTask, replicationTasks []*ReplicationTask, timerTasks []*TimerTask, shardCondition *ShardCondition) error

InsertWorkflowExecutionWithTasks mocks base method.

func (*MocktableCRUD) IsWorkflowExecutionExists added in v0.23.1

func (m *MocktableCRUD) IsWorkflowExecutionExists(ctx context.Context, shardID int, domainID, workflowID, runID string) (bool, error)

IsWorkflowExecutionExists mocks base method.

func (*MocktableCRUD) ListTaskList added in v0.23.1

func (m *MocktableCRUD) ListTaskList(ctx context.Context, pageSize int, nextPageToken []byte) (*ListTaskListResult, error)

ListTaskList mocks base method.

func (*MocktableCRUD) RangeDeleteCrossClusterTasks added in v0.23.1

func (m *MocktableCRUD) RangeDeleteCrossClusterTasks(ctx context.Context, shardID int, targetCluster string, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteCrossClusterTasks mocks base method.

func (*MocktableCRUD) RangeDeleteReplicationDLQTasks added in v0.23.1

func (m *MocktableCRUD) RangeDeleteReplicationDLQTasks(ctx context.Context, shardID int, sourceCluster string, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteReplicationDLQTasks mocks base method.

func (*MocktableCRUD) RangeDeleteReplicationTasks added in v0.23.1

func (m *MocktableCRUD) RangeDeleteReplicationTasks(ctx context.Context, shardID int, inclusiveEndTaskID int64) error

RangeDeleteReplicationTasks mocks base method.

func (*MocktableCRUD) RangeDeleteTasks added in v0.23.1

func (m *MocktableCRUD) RangeDeleteTasks(ctx context.Context, filter *TasksFilter) (int, error)

RangeDeleteTasks mocks base method.

func (*MocktableCRUD) RangeDeleteTimerTasks added in v0.23.1

func (m *MocktableCRUD) RangeDeleteTimerTasks(ctx context.Context, shardID int, inclusiveMinTime, exclusiveMaxTime time.Time) error

RangeDeleteTimerTasks mocks base method.

func (*MocktableCRUD) RangeDeleteTransferTasks added in v0.23.1

func (m *MocktableCRUD) RangeDeleteTransferTasks(ctx context.Context, shardID int, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

RangeDeleteTransferTasks mocks base method.

func (*MocktableCRUD) SelectAllCurrentWorkflows added in v0.23.1

func (m *MocktableCRUD) SelectAllCurrentWorkflows(ctx context.Context, shardID int, pageToken []byte, pageSize int) ([]*persistence.CurrentWorkflowExecution, []byte, error)

SelectAllCurrentWorkflows mocks base method.

func (*MocktableCRUD) SelectAllDomains added in v0.23.1

func (m *MocktableCRUD) SelectAllDomains(ctx context.Context, pageSize int, pageToken []byte) ([]*DomainRow, []byte, error)

SelectAllDomains mocks base method.

func (*MocktableCRUD) SelectAllHistoryTrees added in v0.23.1

func (m *MocktableCRUD) SelectAllHistoryTrees(ctx context.Context, nextPageToken []byte, pageSize int) ([]*HistoryTreeRow, []byte, error)

SelectAllHistoryTrees mocks base method.

func (*MocktableCRUD) SelectAllWorkflowExecutions added in v0.23.1

func (m *MocktableCRUD) SelectAllWorkflowExecutions(ctx context.Context, shardID int, pageToken []byte, pageSize int) ([]*persistence.InternalListConcreteExecutionsEntity, []byte, error)

SelectAllWorkflowExecutions mocks base method.

func (*MocktableCRUD) SelectCrossClusterTasksOrderByTaskID added in v0.23.1

func (m *MocktableCRUD) SelectCrossClusterTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, targetCluster string, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*CrossClusterTask, []byte, error)

SelectCrossClusterTasksOrderByTaskID mocks base method.

func (*MocktableCRUD) SelectCurrentWorkflow added in v0.23.1

func (m *MocktableCRUD) SelectCurrentWorkflow(ctx context.Context, shardID int, domainID, workflowID string) (*CurrentWorkflowRow, error)

SelectCurrentWorkflow mocks base method.

func (*MocktableCRUD) SelectDomain added in v0.23.1

func (m *MocktableCRUD) SelectDomain(ctx context.Context, domainID, domainName *string) (*DomainRow, error)

SelectDomain mocks base method.

func (*MocktableCRUD) SelectDomainMetadata added in v0.23.1

func (m *MocktableCRUD) SelectDomainMetadata(ctx context.Context) (int64, error)

SelectDomainMetadata mocks base method.

func (*MocktableCRUD) SelectFromHistoryNode added in v0.23.1

func (m *MocktableCRUD) SelectFromHistoryNode(ctx context.Context, filter *HistoryNodeFilter) ([]*HistoryNodeRow, []byte, error)

SelectFromHistoryNode mocks base method.

func (*MocktableCRUD) SelectFromHistoryTree added in v0.23.1

func (m *MocktableCRUD) SelectFromHistoryTree(ctx context.Context, filter *HistoryTreeFilter) ([]*HistoryTreeRow, error)

SelectFromHistoryTree mocks base method.

func (*MocktableCRUD) SelectLastEnqueuedMessageID added in v0.23.1

func (m *MocktableCRUD) SelectLastEnqueuedMessageID(ctx context.Context, queueType persistence.QueueType) (int64, error)

SelectLastEnqueuedMessageID mocks base method.

func (*MocktableCRUD) SelectLatestConfig added in v0.23.1

func (m *MocktableCRUD) SelectLatestConfig(ctx context.Context, rowType int) (*persistence.InternalConfigStoreEntry, error)

SelectLatestConfig mocks base method.

func (*MocktableCRUD) SelectMessagesBetween added in v0.23.1

SelectMessagesBetween mocks base method.

func (*MocktableCRUD) SelectMessagesFrom added in v0.23.1

func (m *MocktableCRUD) SelectMessagesFrom(ctx context.Context, queueType persistence.QueueType, exclusiveBeginMessageID int64, maxRows int) ([]*QueueMessageRow, error)

SelectMessagesFrom mocks base method.

func (*MocktableCRUD) SelectOneClosedWorkflow added in v0.23.1

func (m *MocktableCRUD) SelectOneClosedWorkflow(ctx context.Context, domainID, workflowID, runID string) (*VisibilityRow, error)

SelectOneClosedWorkflow mocks base method.

func (*MocktableCRUD) SelectQueueMetadata added in v0.23.1

func (m *MocktableCRUD) SelectQueueMetadata(ctx context.Context, queueType persistence.QueueType) (*QueueMetadataRow, error)

SelectQueueMetadata mocks base method.

func (*MocktableCRUD) SelectReplicationDLQTasksCount added in v0.23.1

func (m *MocktableCRUD) SelectReplicationDLQTasksCount(ctx context.Context, shardID int, sourceCluster string) (int64, error)

SelectReplicationDLQTasksCount mocks base method.

func (*MocktableCRUD) SelectReplicationDLQTasksOrderByTaskID added in v0.23.1

func (m *MocktableCRUD) SelectReplicationDLQTasksOrderByTaskID(ctx context.Context, shardID int, sourceCluster string, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*ReplicationTask, []byte, error)

SelectReplicationDLQTasksOrderByTaskID mocks base method.

func (*MocktableCRUD) SelectReplicationTasksOrderByTaskID added in v0.23.1

func (m *MocktableCRUD) SelectReplicationTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*ReplicationTask, []byte, error)

SelectReplicationTasksOrderByTaskID mocks base method.

func (*MocktableCRUD) SelectShard added in v0.23.1

func (m *MocktableCRUD) SelectShard(ctx context.Context, shardID int, currentClusterName string) (int64, *ShardRow, error)

SelectShard mocks base method.

func (*MocktableCRUD) SelectTaskList added in v0.23.1

func (m *MocktableCRUD) SelectTaskList(ctx context.Context, filter *TaskListFilter) (*TaskListRow, error)

SelectTaskList mocks base method.

func (*MocktableCRUD) SelectTasks added in v0.23.1

func (m *MocktableCRUD) SelectTasks(ctx context.Context, filter *TasksFilter) ([]*TaskRow, error)

SelectTasks mocks base method.

func (*MocktableCRUD) SelectTimerTasksOrderByVisibilityTime added in v0.23.1

func (m *MocktableCRUD) SelectTimerTasksOrderByVisibilityTime(ctx context.Context, shardID, pageSize int, pageToken []byte, inclusiveMinTime, exclusiveMaxTime time.Time) ([]*TimerTask, []byte, error)

SelectTimerTasksOrderByVisibilityTime mocks base method.

func (*MocktableCRUD) SelectTransferTasksOrderByTaskID added in v0.23.1

func (m *MocktableCRUD) SelectTransferTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*TransferTask, []byte, error)

SelectTransferTasksOrderByTaskID mocks base method.

func (*MocktableCRUD) SelectVisibility added in v0.23.1

func (m *MocktableCRUD) SelectVisibility(ctx context.Context, filter *VisibilityFilter) (*SelectVisibilityResponse, error)

SelectVisibility mocks base method.

func (*MocktableCRUD) SelectWorkflowExecution added in v0.23.1

func (m *MocktableCRUD) SelectWorkflowExecution(ctx context.Context, shardID int, domainID, workflowID, runID string) (*WorkflowExecution, error)

SelectWorkflowExecution mocks base method.

func (*MocktableCRUD) UpdateDomain added in v0.23.1

func (m *MocktableCRUD) UpdateDomain(ctx context.Context, row *DomainRow) error

UpdateDomain mocks base method.

func (*MocktableCRUD) UpdateQueueMetadataCas added in v0.23.1

func (m *MocktableCRUD) UpdateQueueMetadataCas(ctx context.Context, row QueueMetadataRow) error

UpdateQueueMetadataCas mocks base method.

func (*MocktableCRUD) UpdateRangeID added in v0.23.1

func (m *MocktableCRUD) UpdateRangeID(ctx context.Context, shardID int, rangeID, previousRangeID int64) error

UpdateRangeID mocks base method.

func (*MocktableCRUD) UpdateShard added in v0.23.1

func (m *MocktableCRUD) UpdateShard(ctx context.Context, row *ShardRow, previousRangeID int64) error

UpdateShard mocks base method.

func (*MocktableCRUD) UpdateTaskList added in v0.23.1

func (m *MocktableCRUD) UpdateTaskList(ctx context.Context, row *TaskListRow, previousRangeID int64) error

UpdateTaskList mocks base method.

func (*MocktableCRUD) UpdateTaskListWithTTL added in v0.23.1

func (m *MocktableCRUD) UpdateTaskListWithTTL(ctx context.Context, ttlSeconds int64, row *TaskListRow, previousRangeID int64) error

UpdateTaskListWithTTL mocks base method.

func (*MocktableCRUD) UpdateVisibility added in v0.23.1

func (m *MocktableCRUD) UpdateVisibility(ctx context.Context, ttlSeconds int64, row *VisibilityRowForUpdate) error

UpdateVisibility mocks base method.

func (*MocktableCRUD) UpdateWorkflowExecutionWithTasks added in v0.23.1

func (m *MocktableCRUD) UpdateWorkflowExecutionWithTasks(ctx context.Context, currentWorkflowRequest *CurrentWorkflowWriteRequest, mutatedExecution, insertedExecution, resetExecution *WorkflowExecutionRequest, transferTasks []*TransferTask, crossClusterTasks []*CrossClusterTask, replicationTasks []*ReplicationTask, timerTasks []*TimerTask, shardCondition *ShardCondition) error

UpdateWorkflowExecutionWithTasks mocks base method.

type MocktableCRUDMockRecorder added in v0.23.1

type MocktableCRUDMockRecorder struct {
	// contains filtered or unexported fields
}

MocktableCRUDMockRecorder is the mock recorder for MocktableCRUD.

func (*MocktableCRUDMockRecorder) DeleteCrossClusterTask added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteCrossClusterTask(ctx, shardID, targetCluster, taskID interface{}) *gomock.Call

DeleteCrossClusterTask indicates an expected call of DeleteCrossClusterTask.

func (*MocktableCRUDMockRecorder) DeleteCurrentWorkflow added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteCurrentWorkflow(ctx, shardID, domainID, workflowID, currentRunIDCondition interface{}) *gomock.Call

DeleteCurrentWorkflow indicates an expected call of DeleteCurrentWorkflow.

func (*MocktableCRUDMockRecorder) DeleteDomain added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteDomain(ctx, domainID, domainName interface{}) *gomock.Call

DeleteDomain indicates an expected call of DeleteDomain.

func (*MocktableCRUDMockRecorder) DeleteFromHistoryTreeAndNode added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteFromHistoryTreeAndNode(ctx, treeFilter, nodeFilters interface{}) *gomock.Call

DeleteFromHistoryTreeAndNode indicates an expected call of DeleteFromHistoryTreeAndNode.

func (*MocktableCRUDMockRecorder) DeleteMessage added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteMessage(ctx, queueType, messageID interface{}) *gomock.Call

DeleteMessage indicates an expected call of DeleteMessage.

func (*MocktableCRUDMockRecorder) DeleteMessagesBefore added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteMessagesBefore(ctx, queueType, exclusiveBeginMessageID interface{}) *gomock.Call

DeleteMessagesBefore indicates an expected call of DeleteMessagesBefore.

func (*MocktableCRUDMockRecorder) DeleteMessagesInRange added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteMessagesInRange(ctx, queueType, exclusiveBeginMessageID, inclusiveEndMessageID interface{}) *gomock.Call

DeleteMessagesInRange indicates an expected call of DeleteMessagesInRange.

func (*MocktableCRUDMockRecorder) DeleteReplicationDLQTask added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteReplicationDLQTask(ctx, shardID, sourceCluster, taskID interface{}) *gomock.Call

DeleteReplicationDLQTask indicates an expected call of DeleteReplicationDLQTask.

func (*MocktableCRUDMockRecorder) DeleteReplicationTask added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteReplicationTask(ctx, shardID, taskID interface{}) *gomock.Call

DeleteReplicationTask indicates an expected call of DeleteReplicationTask.

func (*MocktableCRUDMockRecorder) DeleteTaskList added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteTaskList(ctx, filter, previousRangeID interface{}) *gomock.Call

DeleteTaskList indicates an expected call of DeleteTaskList.

func (*MocktableCRUDMockRecorder) DeleteTimerTask added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteTimerTask(ctx, shardID, taskID, visibilityTimestamp interface{}) *gomock.Call

DeleteTimerTask indicates an expected call of DeleteTimerTask.

func (*MocktableCRUDMockRecorder) DeleteTransferTask added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteTransferTask(ctx, shardID, taskID interface{}) *gomock.Call

DeleteTransferTask indicates an expected call of DeleteTransferTask.

func (*MocktableCRUDMockRecorder) DeleteVisibility added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteVisibility(ctx, domainID, workflowID, runID interface{}) *gomock.Call

DeleteVisibility indicates an expected call of DeleteVisibility.

func (*MocktableCRUDMockRecorder) DeleteWorkflowExecution added in v0.23.1

func (mr *MocktableCRUDMockRecorder) DeleteWorkflowExecution(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

DeleteWorkflowExecution indicates an expected call of DeleteWorkflowExecution.

func (*MocktableCRUDMockRecorder) GetQueueSize added in v0.23.1

func (mr *MocktableCRUDMockRecorder) GetQueueSize(ctx, queueType interface{}) *gomock.Call

GetQueueSize indicates an expected call of GetQueueSize.

func (*MocktableCRUDMockRecorder) InsertConfig added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertConfig(ctx, row interface{}) *gomock.Call

InsertConfig indicates an expected call of InsertConfig.

func (*MocktableCRUDMockRecorder) InsertDomain added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertDomain(ctx, row interface{}) *gomock.Call

InsertDomain indicates an expected call of InsertDomain.

func (*MocktableCRUDMockRecorder) InsertIntoHistoryTreeAndNode added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertIntoHistoryTreeAndNode(ctx, treeRow, nodeRow interface{}) *gomock.Call

InsertIntoHistoryTreeAndNode indicates an expected call of InsertIntoHistoryTreeAndNode.

func (*MocktableCRUDMockRecorder) InsertIntoQueue added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertIntoQueue(ctx, row interface{}) *gomock.Call

InsertIntoQueue indicates an expected call of InsertIntoQueue.

func (*MocktableCRUDMockRecorder) InsertQueueMetadata added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertQueueMetadata(ctx, queueType, version interface{}) *gomock.Call

InsertQueueMetadata indicates an expected call of InsertQueueMetadata.

func (*MocktableCRUDMockRecorder) InsertReplicationDLQTask added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertReplicationDLQTask(ctx, shardID, sourceCluster, task interface{}) *gomock.Call

InsertReplicationDLQTask indicates an expected call of InsertReplicationDLQTask.

func (*MocktableCRUDMockRecorder) InsertReplicationTask added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertReplicationTask(ctx, tasks, condition interface{}) *gomock.Call

InsertReplicationTask indicates an expected call of InsertReplicationTask.

func (*MocktableCRUDMockRecorder) InsertShard added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertShard(ctx, row interface{}) *gomock.Call

InsertShard indicates an expected call of InsertShard.

func (*MocktableCRUDMockRecorder) InsertTaskList added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertTaskList(ctx, row interface{}) *gomock.Call

InsertTaskList indicates an expected call of InsertTaskList.

func (*MocktableCRUDMockRecorder) InsertTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertTasks(ctx, tasksToInsert, tasklistCondition interface{}) *gomock.Call

InsertTasks indicates an expected call of InsertTasks.

func (*MocktableCRUDMockRecorder) InsertVisibility added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertVisibility(ctx, ttlSeconds, row interface{}) *gomock.Call

InsertVisibility indicates an expected call of InsertVisibility.

func (*MocktableCRUDMockRecorder) InsertWorkflowExecutionWithTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) InsertWorkflowExecutionWithTasks(ctx, currentWorkflowRequest, execution, transferTasks, crossClusterTasks, replicationTasks, timerTasks, shardCondition interface{}) *gomock.Call

InsertWorkflowExecutionWithTasks indicates an expected call of InsertWorkflowExecutionWithTasks.

func (*MocktableCRUDMockRecorder) IsWorkflowExecutionExists added in v0.23.1

func (mr *MocktableCRUDMockRecorder) IsWorkflowExecutionExists(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

IsWorkflowExecutionExists indicates an expected call of IsWorkflowExecutionExists.

func (*MocktableCRUDMockRecorder) ListTaskList added in v0.23.1

func (mr *MocktableCRUDMockRecorder) ListTaskList(ctx, pageSize, nextPageToken interface{}) *gomock.Call

ListTaskList indicates an expected call of ListTaskList.

func (*MocktableCRUDMockRecorder) RangeDeleteCrossClusterTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) RangeDeleteCrossClusterTasks(ctx, shardID, targetCluster, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteCrossClusterTasks indicates an expected call of RangeDeleteCrossClusterTasks.

func (*MocktableCRUDMockRecorder) RangeDeleteReplicationDLQTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) RangeDeleteReplicationDLQTasks(ctx, shardID, sourceCluster, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteReplicationDLQTasks indicates an expected call of RangeDeleteReplicationDLQTasks.

func (*MocktableCRUDMockRecorder) RangeDeleteReplicationTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) RangeDeleteReplicationTasks(ctx, shardID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteReplicationTasks indicates an expected call of RangeDeleteReplicationTasks.

func (*MocktableCRUDMockRecorder) RangeDeleteTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) RangeDeleteTasks(ctx, filter interface{}) *gomock.Call

RangeDeleteTasks indicates an expected call of RangeDeleteTasks.

func (*MocktableCRUDMockRecorder) RangeDeleteTimerTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) RangeDeleteTimerTasks(ctx, shardID, inclusiveMinTime, exclusiveMaxTime interface{}) *gomock.Call

RangeDeleteTimerTasks indicates an expected call of RangeDeleteTimerTasks.

func (*MocktableCRUDMockRecorder) RangeDeleteTransferTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) RangeDeleteTransferTasks(ctx, shardID, exclusiveBeginTaskID, inclusiveEndTaskID interface{}) *gomock.Call

RangeDeleteTransferTasks indicates an expected call of RangeDeleteTransferTasks.

func (*MocktableCRUDMockRecorder) SelectAllCurrentWorkflows added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectAllCurrentWorkflows(ctx, shardID, pageToken, pageSize interface{}) *gomock.Call

SelectAllCurrentWorkflows indicates an expected call of SelectAllCurrentWorkflows.

func (*MocktableCRUDMockRecorder) SelectAllDomains added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectAllDomains(ctx, pageSize, pageToken interface{}) *gomock.Call

SelectAllDomains indicates an expected call of SelectAllDomains.

func (*MocktableCRUDMockRecorder) SelectAllHistoryTrees added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectAllHistoryTrees(ctx, nextPageToken, pageSize interface{}) *gomock.Call

SelectAllHistoryTrees indicates an expected call of SelectAllHistoryTrees.

func (*MocktableCRUDMockRecorder) SelectAllWorkflowExecutions added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectAllWorkflowExecutions(ctx, shardID, pageToken, pageSize interface{}) *gomock.Call

SelectAllWorkflowExecutions indicates an expected call of SelectAllWorkflowExecutions.

func (*MocktableCRUDMockRecorder) SelectCrossClusterTasksOrderByTaskID added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectCrossClusterTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, targetCluster, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectCrossClusterTasksOrderByTaskID indicates an expected call of SelectCrossClusterTasksOrderByTaskID.

func (*MocktableCRUDMockRecorder) SelectCurrentWorkflow added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectCurrentWorkflow(ctx, shardID, domainID, workflowID interface{}) *gomock.Call

SelectCurrentWorkflow indicates an expected call of SelectCurrentWorkflow.

func (*MocktableCRUDMockRecorder) SelectDomain added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectDomain(ctx, domainID, domainName interface{}) *gomock.Call

SelectDomain indicates an expected call of SelectDomain.

func (*MocktableCRUDMockRecorder) SelectDomainMetadata added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectDomainMetadata(ctx interface{}) *gomock.Call

SelectDomainMetadata indicates an expected call of SelectDomainMetadata.

func (*MocktableCRUDMockRecorder) SelectFromHistoryNode added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectFromHistoryNode(ctx, filter interface{}) *gomock.Call

SelectFromHistoryNode indicates an expected call of SelectFromHistoryNode.

func (*MocktableCRUDMockRecorder) SelectFromHistoryTree added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectFromHistoryTree(ctx, filter interface{}) *gomock.Call

SelectFromHistoryTree indicates an expected call of SelectFromHistoryTree.

func (*MocktableCRUDMockRecorder) SelectLastEnqueuedMessageID added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectLastEnqueuedMessageID(ctx, queueType interface{}) *gomock.Call

SelectLastEnqueuedMessageID indicates an expected call of SelectLastEnqueuedMessageID.

func (*MocktableCRUDMockRecorder) SelectLatestConfig added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectLatestConfig(ctx, rowType interface{}) *gomock.Call

SelectLatestConfig indicates an expected call of SelectLatestConfig.

func (*MocktableCRUDMockRecorder) SelectMessagesBetween added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectMessagesBetween(ctx, request interface{}) *gomock.Call

SelectMessagesBetween indicates an expected call of SelectMessagesBetween.

func (*MocktableCRUDMockRecorder) SelectMessagesFrom added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectMessagesFrom(ctx, queueType, exclusiveBeginMessageID, maxRows interface{}) *gomock.Call

SelectMessagesFrom indicates an expected call of SelectMessagesFrom.

func (*MocktableCRUDMockRecorder) SelectOneClosedWorkflow added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectOneClosedWorkflow(ctx, domainID, workflowID, runID interface{}) *gomock.Call

SelectOneClosedWorkflow indicates an expected call of SelectOneClosedWorkflow.

func (*MocktableCRUDMockRecorder) SelectQueueMetadata added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectQueueMetadata(ctx, queueType interface{}) *gomock.Call

SelectQueueMetadata indicates an expected call of SelectQueueMetadata.

func (*MocktableCRUDMockRecorder) SelectReplicationDLQTasksCount added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectReplicationDLQTasksCount(ctx, shardID, sourceCluster interface{}) *gomock.Call

SelectReplicationDLQTasksCount indicates an expected call of SelectReplicationDLQTasksCount.

func (*MocktableCRUDMockRecorder) SelectReplicationDLQTasksOrderByTaskID added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectReplicationDLQTasksOrderByTaskID(ctx, shardID, sourceCluster, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectReplicationDLQTasksOrderByTaskID indicates an expected call of SelectReplicationDLQTasksOrderByTaskID.

func (*MocktableCRUDMockRecorder) SelectReplicationTasksOrderByTaskID added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectReplicationTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectReplicationTasksOrderByTaskID indicates an expected call of SelectReplicationTasksOrderByTaskID.

func (*MocktableCRUDMockRecorder) SelectShard added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectShard(ctx, shardID, currentClusterName interface{}) *gomock.Call

SelectShard indicates an expected call of SelectShard.

func (*MocktableCRUDMockRecorder) SelectTaskList added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectTaskList(ctx, filter interface{}) *gomock.Call

SelectTaskList indicates an expected call of SelectTaskList.

func (*MocktableCRUDMockRecorder) SelectTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectTasks(ctx, filter interface{}) *gomock.Call

SelectTasks indicates an expected call of SelectTasks.

func (*MocktableCRUDMockRecorder) SelectTimerTasksOrderByVisibilityTime added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectTimerTasksOrderByVisibilityTime(ctx, shardID, pageSize, pageToken, inclusiveMinTime, exclusiveMaxTime interface{}) *gomock.Call

SelectTimerTasksOrderByVisibilityTime indicates an expected call of SelectTimerTasksOrderByVisibilityTime.

func (*MocktableCRUDMockRecorder) SelectTransferTasksOrderByTaskID added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectTransferTasksOrderByTaskID(ctx, shardID, pageSize, pageToken, exclusiveMinTaskID, inclusiveMaxTaskID interface{}) *gomock.Call

SelectTransferTasksOrderByTaskID indicates an expected call of SelectTransferTasksOrderByTaskID.

func (*MocktableCRUDMockRecorder) SelectVisibility added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectVisibility(ctx, filter interface{}) *gomock.Call

SelectVisibility indicates an expected call of SelectVisibility.

func (*MocktableCRUDMockRecorder) SelectWorkflowExecution added in v0.23.1

func (mr *MocktableCRUDMockRecorder) SelectWorkflowExecution(ctx, shardID, domainID, workflowID, runID interface{}) *gomock.Call

SelectWorkflowExecution indicates an expected call of SelectWorkflowExecution.

func (*MocktableCRUDMockRecorder) UpdateDomain added in v0.23.1

func (mr *MocktableCRUDMockRecorder) UpdateDomain(ctx, row interface{}) *gomock.Call

UpdateDomain indicates an expected call of UpdateDomain.

func (*MocktableCRUDMockRecorder) UpdateQueueMetadataCas added in v0.23.1

func (mr *MocktableCRUDMockRecorder) UpdateQueueMetadataCas(ctx, row interface{}) *gomock.Call

UpdateQueueMetadataCas indicates an expected call of UpdateQueueMetadataCas.

func (*MocktableCRUDMockRecorder) UpdateRangeID added in v0.23.1

func (mr *MocktableCRUDMockRecorder) UpdateRangeID(ctx, shardID, rangeID, previousRangeID interface{}) *gomock.Call

UpdateRangeID indicates an expected call of UpdateRangeID.

func (*MocktableCRUDMockRecorder) UpdateShard added in v0.23.1

func (mr *MocktableCRUDMockRecorder) UpdateShard(ctx, row, previousRangeID interface{}) *gomock.Call

UpdateShard indicates an expected call of UpdateShard.

func (*MocktableCRUDMockRecorder) UpdateTaskList added in v0.23.1

func (mr *MocktableCRUDMockRecorder) UpdateTaskList(ctx, row, previousRangeID interface{}) *gomock.Call

UpdateTaskList indicates an expected call of UpdateTaskList.

func (*MocktableCRUDMockRecorder) UpdateTaskListWithTTL added in v0.23.1

func (mr *MocktableCRUDMockRecorder) UpdateTaskListWithTTL(ctx, ttlSeconds, row, previousRangeID interface{}) *gomock.Call

UpdateTaskListWithTTL indicates an expected call of UpdateTaskListWithTTL.

func (*MocktableCRUDMockRecorder) UpdateVisibility added in v0.23.1

func (mr *MocktableCRUDMockRecorder) UpdateVisibility(ctx, ttlSeconds, row interface{}) *gomock.Call

UpdateVisibility indicates an expected call of UpdateVisibility.

func (*MocktableCRUDMockRecorder) UpdateWorkflowExecutionWithTasks added in v0.23.1

func (mr *MocktableCRUDMockRecorder) UpdateWorkflowExecutionWithTasks(ctx, currentWorkflowRequest, mutatedExecution, insertedExecution, resetExecution, transferTasks, crossClusterTasks, replicationTasks, timerTasks, shardCondition interface{}) *gomock.Call

UpdateWorkflowExecutionWithTasks indicates an expected call of UpdateWorkflowExecutionWithTasks.

type NoSQLInternalDomainConfig added in v0.17.0

type NoSQLInternalDomainConfig struct {
	Retention                time.Duration
	EmitMetric               bool                 // deprecated
	ArchivalBucket           string               // deprecated
	ArchivalStatus           types.ArchivalStatus // deprecated
	HistoryArchivalStatus    types.ArchivalStatus
	HistoryArchivalURI       string
	VisibilityArchivalStatus types.ArchivalStatus
	VisibilityArchivalURI    string
	BadBinaries              *persistence.DataBlob
}

NoSQLInternalDomainConfig defines the struct for the domainConfig

type Plugin added in v0.23.1

type Plugin interface {
	CreateDB(cfg *config.NoSQL, logger log.Logger, dc *persistence.DynamicConfiguration) (DB, error)
	CreateAdminDB(cfg *config.NoSQL, logger log.Logger, dc *persistence.DynamicConfiguration) (AdminDB, error)
}

Plugin defines the interface for any NoSQL database that needs to implement

type QueueMessageRow

type QueueMessageRow struct {
	QueueType persistence.QueueType
	ID        int64
	Payload   []byte
}

QueueMessageRow defines the row struct for queue message

type QueueMetadataRow

type QueueMetadataRow struct {
	QueueType        persistence.QueueType
	ClusterAckLevels map[string]int64
	Version          int64
}

QueueMetadataRow defines the row struct for metadata

type ReplicationTask added in v0.22.0

type ReplicationTask = persistence.InternalReplicationTaskInfo

ReplicationTask is for replication

type SelectMessagesBetweenRequest

type SelectMessagesBetweenRequest struct {
	QueueType               persistence.QueueType
	ExclusiveBeginMessageID int64
	InclusiveEndMessageID   int64
	PageSize                int
	NextPageToken           []byte
}

SelectMessagesBetweenRequest is a request struct for SelectMessagesBetween

type SelectMessagesBetweenResponse

type SelectMessagesBetweenResponse struct {
	Rows          []QueueMessageRow
	NextPageToken []byte
}

SelectMessagesBetweenResponse is a response struct for SelectMessagesBetween

type SelectVisibilityResponse added in v0.22.0

type SelectVisibilityResponse struct {
	Executions    []*VisibilityRow
	NextPageToken []byte
}

type ShardCRUD added in v0.23.1

type ShardCRUD interface {
	// InsertShard creates a new shard.
	// Return error is there is any thing wrong
	// Return the ShardOperationConditionFailure when doesn't meet the condition
	InsertShard(ctx context.Context, row *ShardRow) error
	// SelectShard gets a shard, rangeID is the current rangeID in shard row
	SelectShard(ctx context.Context, shardID int, currentClusterName string) (rangeID int64, shard *ShardRow, err error)
	// UpdateRangeID updates the rangeID
	// Return error is there is any thing wrong
	// Return the ShardOperationConditionFailure when doesn't meet the condition
	UpdateRangeID(ctx context.Context, shardID int, rangeID int64, previousRangeID int64) error
	// UpdateShard updates a shard
	// Return error is there is any thing wrong
	// Return the ShardOperationConditionFailure when doesn't meet the condition
	UpdateShard(ctx context.Context, row *ShardRow, previousRangeID int64) error
}

*

  • ShardCRUD is for shard storage of workflow execution.
  • Recommendation: use one table if database support batch conditional update on multiple tables, otherwise combine with WorkflowCRUD (likeCassandra) *
  • Significant columns:
  • domain: partition key(shardID), range key(N/A), local secondary index(domainID), query condition column(rangeID) *
  • Note 1: shard will be required to run conditional update with WorkflowCRUD. So in some nosql database like Cassandra,
  • ShardCRUD and WorkflowCRUD must be implemented within the same table. Because Cassandra only allows LightWeight transaction
  • executed within a single table.
  • Note 2: unlike Cassandra, most NoSQL databases don't return the previous rows when conditional write fails. In this case,
  • an extra read query is needed to get the previous row.

type ShardCondition added in v0.22.0

type ShardCondition struct {
	ShardID int
	RangeID int64
}

ShardCondition is the condition for making changes within a shard

type ShardOperationConditionFailure added in v0.22.0

type ShardOperationConditionFailure struct {
	RangeID int64
	Details string // detail info for logging
}

Condition Errors for NoSQL interfaces

func (*ShardOperationConditionFailure) Error added in v0.22.0

type ShardRow added in v0.22.0

type ShardRow = persistence.InternalShardInfo

ShardRow is the same as persistence.InternalShardInfo Separate them later when there is a need.

type TaskCRUD added in v0.23.1

type TaskCRUD interface {
	// SelectTaskList returns a single tasklist row.
	// Return IsNotFoundError if the row doesn't exist
	SelectTaskList(ctx context.Context, filter *TaskListFilter) (*TaskListRow, error)
	// InsertTaskList insert a single tasklist row
	// Return TaskOperationConditionFailure if the row already exists
	InsertTaskList(ctx context.Context, row *TaskListRow) error
	// UpdateTaskList updates a single tasklist row
	// Return TaskOperationConditionFailure if the condition doesn't meet
	UpdateTaskList(ctx context.Context, row *TaskListRow, previousRangeID int64) error
	// UpdateTaskList updates a single tasklist row, and set an TTL on the record
	// Return TaskOperationConditionFailure if the condition doesn't meet
	// Ignore TTL if it's not supported, which becomes exactly the same as UpdateTaskList, but ListTaskList must be
	// implemented for TaskListScavenger
	UpdateTaskListWithTTL(ctx context.Context, ttlSeconds int64, row *TaskListRow, previousRangeID int64) error
	// ListTaskList returns all tasklists.
	// Noop if TTL is already implemented in other methods
	ListTaskList(ctx context.Context, pageSize int, nextPageToken []byte) (*ListTaskListResult, error)
	// DeleteTaskList deletes a single tasklist row
	// Return TaskOperationConditionFailure if the condition doesn't meet
	DeleteTaskList(ctx context.Context, filter *TaskListFilter, previousRangeID int64) error
	// InsertTasks inserts a batch of tasks
	// Return TaskOperationConditionFailure if the condition doesn't meet
	InsertTasks(ctx context.Context, tasksToInsert []*TaskRowForInsert, tasklistCondition *TaskListRow) error
	// SelectTasks return tasks that associated to a tasklist
	SelectTasks(ctx context.Context, filter *TasksFilter) ([]*TaskRow, error)
	// DeleteTask delete a batch of tasks
	// Also return the number of rows deleted -- if it's not supported then ignore the batchSize, and return persistence.UnknownNumRowsAffected
	RangeDeleteTasks(ctx context.Context, filter *TasksFilter) (rowsDeleted int, err error)
}

*

  • TaskCRUD is for tasklist and worker tasks storage
  • The task here is only referred to workflow/activity worker tasks. `Task` is a overloaded term in Cadence.
  • There is another 'task' storage which is for internal purpose only in WorkflowCRUD. *
  • Recommendation: use two tables(tasklist + task) to implement
  • tasklist table stores the metadata mainly for
  • * rangeID: ownership management, and taskID management everytime a matching host claim ownership of a tasklist,
  • it must increase the value succesfully . also used as base section of the taskID. E.g, if rangeID is 1,
  • then allowed taskID ranged will be [100K, 2*100K-1].
  • * ackLevel: max taskID that can be safely deleted.
  • Any task record is associated with a tasklist. Any updates on a task should use rangeID of the associated tasklist as condition. *
  • Significant columns:
  • tasklist: partition key(domainID, taskListName, taskListType), range key(N/A), query condition column(rangeID)
  • task:partition key(domainID, taskListName, taskListType), range key(taskID), query condition column(rangeID) *
  • NOTE 1: Cassandra implementation uses the same table for tasklist and task, because Cassandra only allows
  • batch conditional updates(LightWeight transaction) executed within a single table.
  • NOTE 2: TTL(time to live records) is for auto-deleting task and some tasklists records. For databases that don't
  • support TTL, please implement ListTaskList method, and allows TaskListScavenger like MySQL/Postgres.
  • If TTL is supported, then ListTaskList can be a noop.

type TaskListFilter added in v0.22.0

type TaskListFilter struct {
	DomainID     string
	TaskListName string
	TaskListType int
}

TaskListFilter is for filtering tasklist

type TaskListRow added in v0.22.0

type TaskListRow struct {
	DomainID     string
	TaskListName string
	TaskListType int

	RangeID         int64
	TaskListKind    int
	AckLevel        int64
	LastUpdatedTime time.Time
}

TaskListRow is a tasklist row

type TaskOperationConditionFailure added in v0.22.0

type TaskOperationConditionFailure struct {
	RangeID int64
	Details string // detail info for logging
}

Condition Errors for NoSQL interfaces

func (*TaskOperationConditionFailure) Error added in v0.22.0

type TaskRow added in v0.22.0

type TaskRow struct {
	DomainID     string
	TaskListName string
	TaskListType int
	TaskID       int64

	WorkflowID  string
	RunID       string
	ScheduledID int64
	CreatedTime time.Time
}

TaskRow represent a task row

type TaskRowForInsert added in v0.22.0

type TaskRowForInsert struct {
	TaskRow
	// <= 0 means no TTL
	TTLSeconds int
}

TaskRowForInsert is the struct to inserting task

type TasksFilter added in v0.22.0

type TasksFilter struct {
	TaskListFilter
	// Exclusive
	MinTaskID int64
	// Inclusive
	MaxTaskID int64
	BatchSize int
}

TasksFilter is for filtering tasks

type TimerTask added in v0.22.0

type TimerTask = persistence.TimerTaskInfo

TimerTask is background timer task

type TransferTask added in v0.22.0

type TransferTask = persistence.TransferTaskInfo

TransferTask is for regular transfer task

type VisibilityCRUD added in v0.23.1

type VisibilityCRUD interface {
	InsertVisibility(ctx context.Context, ttlSeconds int64, row *VisibilityRowForInsert) error
	UpdateVisibility(ctx context.Context, ttlSeconds int64, row *VisibilityRowForUpdate) error
	SelectVisibility(ctx context.Context, filter *VisibilityFilter) (*SelectVisibilityResponse, error)
	DeleteVisibility(ctx context.Context, domainID, workflowID, runID string) error
	// TODO deprecated this in the future in favor of SelectVisibility
	// Special case: return nil,nil if not found(since we will deprecate it, it's not worth refactor to be consistent)
	SelectOneClosedWorkflow(ctx context.Context, domainID, workflowID, runID string) (*VisibilityRow, error)
}

*

  • VisibilityCRUD is for visibility using database.
  • Database visibility usually is no longer recommended. AdvancedVisibility(with Kafka+ElasticSearch) is more powerful and scalable.
  • Feel free to skip this interface for any NoSQL plugin(use TODO() in the implementation) *
  • Recommendation: use one table with multiple indexes *
  • Significant columns:
  • domain: partition key(domainID), range key(workflowID, runID),
  • local secondary index #1(startTime),
  • local secondary index #2(closedTime),
  • local secondary index #3(workflowType, startTime),
  • local secondary index #4(workflowType, closedTime),
  • local secondary index #5(workflowID, startTime),
  • local secondary index #6(workflowID, closedTime),
  • local secondary index #7(closeStatus, closedTime), *
  • NOTE 1: Cassandra implementation of visibility uses three tables: open_executions, closed_executions and closed_executions_v2,
  • because Cassandra doesn't support cross-partition indexing.
  • Records in open_executions and closed_executions are clustered by start_time. Records in closed_executions_v2 are by close_time.
  • This optimizes the performance, but introduce a lot of complexity.
  • In some other databases, this may be be necessary. Please refer to MySQL/Postgres implementation which uses only
  • one table with multiple indexes. *
  • NOTE 2: TTL(time to live records) is for auto-deleting expired records in visibility. For databases that don't support TTL,
  • please implement DeleteVisibility method. If TTL is supported, then DeleteVisibility can be a noop.

type VisibilityFilter added in v0.22.0

type VisibilityFilter struct {
	ListRequest  persistence.InternalListWorkflowExecutionsRequest
	FilterType   VisibilityFilterType
	SortType     VisibilitySortType
	WorkflowType string
	WorkflowID   string
	CloseStatus  int32
}

VisibilityFilter contains the column names within executions_visibility table that can be used to filter results through a WHERE clause

type VisibilityFilterType added in v0.22.0

type VisibilityFilterType int
const (
	AllOpen VisibilityFilterType = iota
	AllClosed
	OpenByWorkflowType
	ClosedByWorkflowType
	OpenByWorkflowID
	ClosedByWorkflowID
	ClosedByClosedStatus
)

type VisibilityRow added in v0.22.0

TODO separate in the future when need it

type VisibilityRowForInsert added in v0.22.0

type VisibilityRowForInsert struct {
	VisibilityRow
	DomainID string
}

type VisibilityRowForUpdate added in v0.22.0

type VisibilityRowForUpdate struct {
	VisibilityRow
	DomainID string
	// NOTE: this is only for some implementation (e.g. Cassandra) that uses multiple tables,
	// they needs to delete record from the open execution table. Ignore this field if not need it
	UpdateOpenToClose bool
	//  Similar as UpdateOpenToClose
	UpdateCloseToOpen bool
}

type VisibilitySortType added in v0.22.0

type VisibilitySortType int
const (
	SortByStartTime VisibilitySortType = iota
	SortByClosedTime
)

enums of VisibilitySortType

type WorkflowCRUD added in v0.23.1

type WorkflowCRUD interface {
	// InsertWorkflowExecutionWithTasks is for creating a new workflow execution record. Within a transaction, it also:
	// 1. Create or update the record of current_workflow with the same workflowID, based on CurrentWorkflowExecutionWriteMode,
	//		and also check if the condition is met.
	// 2. Create the workflow_execution record, including basic info and 6 maps(activityInfoMap, timerInfoMap,
	//		childWorkflowInfoMap, signalInfoMap and signalRequestedIDs)
	// 3. Create transfer tasks
	// 4. Create timer tasks
	// 5. Create replication tasks
	// 6. Create crossCluster tasks
	// 7. Check if the condition of shard rangeID is met
	// The API returns error if there is any. If any of the condition is not met, returns WorkflowOperationConditionFailure
	InsertWorkflowExecutionWithTasks(
		ctx context.Context,
		currentWorkflowRequest *CurrentWorkflowWriteRequest,
		execution *WorkflowExecutionRequest,
		transferTasks []*TransferTask,
		crossClusterTasks []*CrossClusterTask,
		replicationTasks []*ReplicationTask,
		timerTasks []*TimerTask,
		shardCondition *ShardCondition,
	) error

	// UpdateWorkflowExecutionWithTasks is for updating a new workflow execution record.
	// Within a transaction, it also:
	// 1. If currentWorkflowRequest is not nil, Update the record of current_workflow with the same workflowID, based on CurrentWorkflowExecutionWriteMode,
	//		and also check if the condition is met.
	// 2. Update mutatedExecution as workflow_execution record, including basic info and 6 maps(activityInfoMap, timerInfoMap,
	//		childWorkflowInfoMap, signalInfoMap and signalRequestedIDs)
	// 3. if insertedExecution is not nil, then also insert a new workflow_execution record including basic info and add to 6 maps(activityInfoMap, timerInfoMap,
	//		childWorkflowInfoMap, signalInfoMap and signalRequestedIDs
	// 4. if resetExecution is not nil, then also update the workflow_execution record including basic info and reset/override 6 maps(activityInfoMap, timerInfoMap,
	//		childWorkflowInfoMap, signalInfoMap and signalRequestedIDs
	// 5. Create transfer tasks
	// 6. Create timer tasks
	// 7. Create replication tasks
	// 8. Create crossCluster tasks
	// 9. Check if the condition of shard rangeID is met
	// The API returns error if there is any. If any of the condition is not met, returns WorkflowOperationConditionFailure
	UpdateWorkflowExecutionWithTasks(
		ctx context.Context,
		currentWorkflowRequest *CurrentWorkflowWriteRequest,
		mutatedExecution *WorkflowExecutionRequest,
		insertedExecution *WorkflowExecutionRequest,
		resetExecution *WorkflowExecutionRequest,
		transferTasks []*TransferTask,
		crossClusterTasks []*CrossClusterTask,
		replicationTasks []*ReplicationTask,
		timerTasks []*TimerTask,
		shardCondition *ShardCondition,
	) error

	// current_workflow table
	// Return the current_workflow row
	SelectCurrentWorkflow(ctx context.Context, shardID int, domainID, workflowID string) (*CurrentWorkflowRow, error)
	// Paging through all current_workflow rows in a shard
	SelectAllCurrentWorkflows(ctx context.Context, shardID int, pageToken []byte, pageSize int) ([]*persistence.CurrentWorkflowExecution, []byte, error)
	// Delete the current_workflow row, if currentRunIDCondition is met
	DeleteCurrentWorkflow(ctx context.Context, shardID int, domainID, workflowID, currentRunIDCondition string) error

	// workflow_execution table
	// Return the workflow execution row
	SelectWorkflowExecution(ctx context.Context, shardID int, domainID, workflowID, runID string) (*WorkflowExecution, error)
	// Paging through all  workflow execution rows in a shard
	SelectAllWorkflowExecutions(ctx context.Context, shardID int, pageToken []byte, pageSize int) ([]*persistence.InternalListConcreteExecutionsEntity, []byte, error)
	// Return whether or not an execution is existing.
	IsWorkflowExecutionExists(ctx context.Context, shardID int, domainID, workflowID, runID string) (bool, error)
	// Delete the workflow execution row
	DeleteWorkflowExecution(ctx context.Context, shardID int, domainID, workflowID, runID string) error

	// transfer_task table
	// within a shard, paging through transfer tasks order by taskID(ASC), filtered by minTaskID(exclusive) and maxTaskID(inclusive)
	SelectTransferTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*TransferTask, []byte, error)
	// delete a single transfer task
	DeleteTransferTask(ctx context.Context, shardID int, taskID int64) error
	// delete a range of transfer tasks
	RangeDeleteTransferTasks(ctx context.Context, shardID int, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

	// timer_task table
	// within a shard, paging through timer tasks order by taskID(ASC), filtered by visibilityTimestamp
	SelectTimerTasksOrderByVisibilityTime(ctx context.Context, shardID, pageSize int, pageToken []byte, inclusiveMinTime, exclusiveMaxTime time.Time) ([]*TimerTask, []byte, error)
	// delete a single timer task
	DeleteTimerTask(ctx context.Context, shardID int, taskID int64, visibilityTimestamp time.Time) error
	// delete a range of timer tasks
	RangeDeleteTimerTasks(ctx context.Context, shardID int, inclusiveMinTime, exclusiveMaxTime time.Time) error

	// replication_task table
	// within a shard, paging through replication tasks order by taskID(ASC), filtered by minTaskID(exclusive) and maxTaskID(inclusive)
	SelectReplicationTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*ReplicationTask, []byte, error)
	// delete a single replication task
	DeleteReplicationTask(ctx context.Context, shardID int, taskID int64) error
	// delete a range of replication tasks
	RangeDeleteReplicationTasks(ctx context.Context, shardID int, inclusiveEndTaskID int64) error
	// insert replication task with shard condition check
	InsertReplicationTask(ctx context.Context, tasks []*ReplicationTask, condition ShardCondition) error

	// cross_cluster_task table
	// within a shard, paging through replication tasks order by taskID(ASC), filtered by minTaskID(exclusive) and maxTaskID(inclusive)
	SelectCrossClusterTasksOrderByTaskID(ctx context.Context, shardID, pageSize int, pageToken []byte, targetCluster string, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*CrossClusterTask, []byte, error)
	// delete a single transfer task
	DeleteCrossClusterTask(ctx context.Context, shardID int, targetCluster string, taskID int64) error
	// delete a range of transfer tasks
	RangeDeleteCrossClusterTasks(ctx context.Context, shardID int, targetCluster string, exclusiveBeginTaskID, inclusiveEndTaskID int64) error

	// replication_dlq_task
	// insert a new replication task to DLQ
	InsertReplicationDLQTask(ctx context.Context, shardID int, sourceCluster string, task ReplicationTask) error
	// within a shard, for a sourceCluster, paging through replication tasks order by taskID(ASC), filtered by minTaskID(exclusive) and maxTaskID(inclusive)
	SelectReplicationDLQTasksOrderByTaskID(ctx context.Context, shardID int, sourceCluster string, pageSize int, pageToken []byte, exclusiveMinTaskID, inclusiveMaxTaskID int64) ([]*ReplicationTask, []byte, error)
	// return the DLQ size
	SelectReplicationDLQTasksCount(ctx context.Context, shardID int, sourceCluster string) (int64, error)
	// delete a single replication DLQ task
	DeleteReplicationDLQTask(ctx context.Context, shardID int, sourceCluster string, taskID int64) error
	// delete a range of replication DLQ tasks
	RangeDeleteReplicationDLQTasks(ctx context.Context, shardID int, sourceCluster string, exclusiveBeginTaskID, inclusiveEndTaskID int64) error
}

*

  • WorkflowCRUD is for core data models of workflow execution. *
  • Recommendation: If possible, use 8 tables(current_workflow, workflow_execution, transfer_task, replication_task, cross_cluster_task, timer_task, buffered_event_list, replication_dlq_task) to implement
  • current_workflow is to track the currentRunID of a workflowID for ensuring the ID-Uniqueness of Cadence workflows.
  • Each record is for one workflowID
  • workflow_execution is to store the core data of workflow execution.
  • Each record is for one runID(workflow execution run).
  • Different from TaskCRUD, transfer_task, replication_task, cross_cluster_task, timer_task are all internal background tasks within Cadence server.
  • transfer_task is to store the background tasks that need to be processed by historyEngine, right after the transaction.
  • There are lots of usage in historyEngine, like creating activity/childWF/etc task, and updating search attributes, etc.
  • replication_task is to store also background tasks that need to be processed right after the transaction,
  • but only for CrossDC(XDC) replication feature. Each record is a replication task generated from a source cluster.
  • Replication task stores a reference to a batch of history events(see historyCRUD).
  • timer_task is to store the durable timers that will fire in the future. Therefore this table should be indexed by the firingTime.
  • The durable timers are not only for workflow timers, but also for all kinds of timeouts, and workflow deletion, etc.
  • cross_cluster_task is to store also background tasks that need to be processed right after the transaction, and only for
  • but only for cross cluster feature. Each record is a cross cluster task generated for a target cluster.
  • CrossCluster task stores information similar to TransferTask.
  • buffered_event_list is to store the buffered event of a workflow execution
  • The above 7 tables will be required to execute transaction write with the condition of shard record from ShardCRUD.
  • replication_dlq_task is DeadLetterQueue when target cluster pulling and applying replication task. Each record represents
  • a task for a target cluster. *
  • Significant columns:
  • current_workflow: partition key(shardID), range key(domainID, workflowID), query condition column(currentRunID, lastWriteVersion, state)
  • workflow_execution: partition key(shardID), range key(domainID, workflowID, runID), query condition column(nextEventID)
  • transfer_task: partition key(shardID), range key(taskID)
  • replication_task: partition key(shardID), range key(taskID)
  • cross_cluster_task: partition key(shardID), range key(clusterName, taskID)
  • timer_task: partition key(shardID), range key(visibilityTimestamp)
  • buffered_event_list: partition key(shardID), range key(domainID, workflowID, runID)
  • replication_dlq_task: partition key(shardID), range key(clusterName, taskID) *
  • NOTE: Cassandra limits lightweight transaction to execute within one table. So the 6 tables + shard table are implemented
  • via a single table `execution` in Cassandra, using `rowType` to differentiate the 7 tables, and using `permanentRunID`
  • to differentiate current_workflow and workflow_execution
  • NOTE: Cassandra implementation uses 6 maps to store activityInfo, timerInfo, childWorkflowInfo, requestCancels,
  • signalInfo and signalRequestedInfo.Those should be fine to be stored in the same record as its workflow_execution.
  • However, signalInfo stores the in progress signal data. It may be too big for a single record. For example, DynamoDB
  • requires 400KB of a record. In that case, it may be better to have a separate table for signalInfo.
  • NOTE: Cassandra implementation of workflow_execution uses maps without "frozen". This has the advantage of deleting activity/timer/childWF/etc
  • by keys. The equivalent of this may require a read before overwriting the existing. Eg. [ "act1": <some data>, "act2": <some data>]
  • When deleting "act1", Cassandra implementation can delete without read. If storing in the same record of workflwo_execution,
  • it will require to read the whole activityInfo map for deleting.
  • NOTE: Optional optimization: taskID that are writing into internal tasks(transfer/replication/crossCluster) are immutable and always increasing.
  • So it is possible to write the tasks in a single record, indexing by the lowest or highest taskID.
  • This approach can't be used by timerTasks as timers are ordered by visibilityTimestamp.
  • This is useful for DynamoDB because a transaction cannot contain more than 25 unique items. *

type WorkflowExecution added in v0.23.1

type WorkflowExecution = persistence.InternalWorkflowMutableState

WorkflowExecution stores workflow execution metadata

type WorkflowExecutionAlreadyExists added in v0.22.0

type WorkflowExecutionAlreadyExists struct {
	RunID            string
	CreateRequestID  string
	State            int
	CloseStatus      int
	LastWriteVersion int64
	OtherInfo        string
}

Condition Errors for NoSQL interfaces

type WorkflowExecutionMapsWriteMode added in v0.23.1

type WorkflowExecutionMapsWriteMode int

WorkflowExecutionMapsWriteMode controls how to write WorkflowExecutionMaps

const (
	// WorkflowExecutionMapsWriteModeCreate will upsert new entry to maps
	WorkflowExecutionMapsWriteModeCreate WorkflowExecutionMapsWriteMode = iota
	// WorkflowExecutionMapsWriteModeUpdate will upsert new entry to maps and also delete entries from maps
	WorkflowExecutionMapsWriteModeUpdate
	// WorkflowExecutionMapsWriteModeReset will reset(override) the whole maps
	WorkflowExecutionMapsWriteModeReset
)

enums of WorkflowExecutionMapsWriteMode

type WorkflowExecutionRequest added in v0.23.1

type WorkflowExecutionRequest struct {
	// basic information/data
	persistence.InternalWorkflowExecutionInfo
	VersionHistories *persistence.DataBlob
	Checksums        *checksum.Checksum
	LastWriteVersion int64
	// condition checking for updating execution info
	PreviousNextEventIDCondition *int64

	// MapsWriteMode controls how to write into the six maps(activityInfoMap, timerInfoMap, childWorkflowInfoMap, signalInfoMap and signalRequestedIDs)
	MapsWriteMode WorkflowExecutionMapsWriteMode

	// For WorkflowExecutionMapsWriteMode of create, update and reset
	ActivityInfos      map[int64]*persistence.InternalActivityInfo
	TimerInfos         map[string]*persistence.TimerInfo
	ChildWorkflowInfos map[int64]*persistence.InternalChildExecutionInfo
	RequestCancelInfos map[int64]*persistence.RequestCancelInfo
	SignalInfos        map[int64]*persistence.SignalInfo
	SignalRequestedIDs []string // This map has no value, hence use array to store keys

	// For WorkflowExecutionMapsWriteMode of update only
	ActivityInfoKeysToDelete       []int64
	TimerInfoKeysToDelete          []string
	ChildWorkflowInfoKeysToDelete  []int64
	RequestCancelInfoKeysToDelete  []int64
	SignalInfoKeysToDelete         []int64
	SignalRequestedIDsKeysToDelete []string

	// EventBufferWriteMode controls how to write into the buffered event list
	// only needed for UpdateWorkflowExecutionWithTasks API
	EventBufferWriteMode EventBufferWriteMode
	// the batch of event to be appended, only for EventBufferWriteModeAppend
	NewBufferedEventBatch *persistence.DataBlob
}

WorkflowExecutionRequest is for creating/updating a workflow execution

type WorkflowOperationConditionFailure added in v0.22.0

type WorkflowOperationConditionFailure struct {
	UnknownConditionFailureDetails   *string // return some info for logging
	ShardRangeIDNotMatch             *int64  // return the previous shardRangeID
	WorkflowExecutionAlreadyExists   *WorkflowExecutionAlreadyExists
	CurrentWorkflowConditionFailInfo *string // return the logging info if fail on condition of CurrentWorkflow
}

Only one of the fields must be non-nil

func (*WorkflowOperationConditionFailure) Error added in v0.22.0

Directories

Path Synopsis
gocql
Package gocql is a generated GoMock package.
Package gocql is a generated GoMock package.

Jump to

Keyboard shortcuts

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