common

package
v1.3.2 Latest Latest
Warning

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

Go to latest
Published: Jun 24, 2025 License: Apache-2.0 Imports: 27 Imported by: 68

Documentation

Overview

Package common is a generated GoMock package.

Package common is a generated GoMock package.

Index

Constants

View Source
const (

	// DaemonStatusInitialized coroutine pool initialized
	DaemonStatusInitialized int32 = 0
	// DaemonStatusStarted coroutine pool started
	DaemonStatusStarted int32 = 1
	// DaemonStatusStopped coroutine pool stopped
	DaemonStatusStopped int32 = 2
)
View Source
const (
	// LibraryVersionHeaderName refers to the name of the
	// tchannel / http header that contains the client
	// library version
	LibraryVersionHeaderName = "cadence-client-library-version"

	// FeatureVersionHeaderName refers to the name of the
	// tchannel / http header that contains the client
	// feature version
	// the feature version sent from client represents the
	// feature set of the cadence client library support.
	// This can be used for client capibility check, on
	// Cadence server, for backward compatibility
	FeatureVersionHeaderName = "cadence-client-feature-version"

	// Header name to pass the feature flags from customer to client or server
	ClientFeatureFlagsHeaderName = "cadence-client-feature-flags"

	// ClientImplHeaderName refers to the name of the
	// header that contains the client implementation
	ClientImplHeaderName = "cadence-client-name"
	// AuthorizationTokenHeaderName refers to the jwt token in the request
	AuthorizationTokenHeaderName = "cadence-authorization"

	// AutoforwardingClusterHeaderName refers to the name of the header that contains the source cluster of the auto-forwarding request
	AutoforwardingClusterHeaderName = "cadence-forwarding-cluster"

	// PartitionConfigHeaderName refers to the name of the header that contains the json encoded partition config of the request
	PartitionConfigHeaderName = "cadence-workflow-partition-config"
	// IsolationGroupHeaderName refers to the name of the header that contains the isolation group of the client
	IsolationGroupHeaderName = "cadence-worker-isolation-group"

	// ClientIsolationGroupHeaderName refers to the name of the header that contains the isolation group which the client request is from
	ClientIsolationGroupHeaderName = "cadence-client-isolation-group"
)
View Source
const (

	// FailureReasonCompleteResultExceedsLimit is failureReason for complete result exceeds limit
	FailureReasonCompleteResultExceedsLimit = "COMPLETE_RESULT_EXCEEDS_LIMIT"
	// FailureReasonFailureDetailsExceedsLimit is failureReason for failure details exceeds limit
	FailureReasonFailureDetailsExceedsLimit = "FAILURE_DETAILS_EXCEEDS_LIMIT"
	// FailureReasonCancelDetailsExceedsLimit is failureReason for cancel details exceeds limit
	FailureReasonCancelDetailsExceedsLimit = "CANCEL_DETAILS_EXCEEDS_LIMIT"
	// FailureReasonHeartbeatExceedsLimit is failureReason for heartbeat exceeds limit
	FailureReasonHeartbeatExceedsLimit = "HEARTBEAT_EXCEEDS_LIMIT"
	// FailureReasonDecisionBlobSizeExceedsLimit is the failureReason for decision blob exceeds size limit
	FailureReasonDecisionBlobSizeExceedsLimit = "DECISION_BLOB_SIZE_EXCEEDS_LIMIT"
	// FailureReasonSizeExceedsLimit is reason to fail workflow when history size or count exceed limit
	FailureReasonSizeExceedsLimit = "HISTORY_EXCEEDS_LIMIT"
	// FailureReasonTransactionSizeExceedsLimit is the failureReason for when transaction cannot be committed because it exceeds size limit
	FailureReasonTransactionSizeExceedsLimit = "TRANSACTION_SIZE_EXCEEDS_LIMIT"
	// FailureReasonDecisionAttemptsExceedsLimit is reason to fail workflow when decision attempts fail too many times
	FailureReasonDecisionAttemptsExceedsLimit = "DECISION_ATTEMPTS_EXCEEDS_LIMIT"
)

Variables

View Source
var (
	// ErrBlobSizeExceedsLimit is error for event blob size exceeds limit
	ErrBlobSizeExceedsLimit = &types.BadRequestError{Message: "Blob data size exceeds limit."}
	// ErrContextTimeoutTooShort is error for setting a very short context timeout when calling a long poll API
	ErrContextTimeoutTooShort = &types.BadRequestError{Message: "Context timeout is too short."}
	// ErrContextTimeoutNotSet is error for not setting a context timeout when calling a long poll API
	ErrContextTimeoutNotSet = &types.BadRequestError{Message: "Context timeout is not set."}
	// ErrDecisionResultCountTooLarge error for decision result count exceeds limit
	ErrDecisionResultCountTooLarge = &types.BadRequestError{Message: "Decision result count exceeds limit."}
)

Functions

func ActivityTypePtr

func ActivityTypePtr(v s.ActivityType) *s.ActivityType

ActivityTypePtr makes a copy and returns the pointer to a ActivityType.

func ArchivalStatusPtr added in v0.5.0

func ArchivalStatusPtr(t s.ArchivalStatus) *s.ArchivalStatus

ArchivalStatusPtr makes a copy and returns the pointer to an ArchivalStatus.

func AwaitWaitGroup

func AwaitWaitGroup(wg *sync.WaitGroup, timeout time.Duration) bool

AwaitWaitGroup calls Wait on the given wait Returns true if the Wait() call succeeded before the timeout Returns false if the Wait() did not return before the timeout

func BoolDefault added in v0.3.2

func BoolDefault(v *bool) bool

BoolDefault returns value if bool pointer is set otherwise default value of bool

func BoolPtr

func BoolPtr(v bool) *bool

BoolPtr makes a copy and returns the pointer to a bool.

func CancelExternalWorkflowExecutionFailedCausePtr added in v0.3.2

func CancelExternalWorkflowExecutionFailedCausePtr(t s.CancelExternalWorkflowExecutionFailedCause) *s.CancelExternalWorkflowExecutionFailedCause

CancelExternalWorkflowExecutionFailedCausePtr makes a copy and returns the pointer to a CancelExternalWorkflowExecutionFailedCause.

func CheckDecisionResultLimit added in v0.23.1

func CheckDecisionResultLimit(
	actualSize int,
	limit int,
	scope metrics.Scope,
) error

CheckDecisionResultLimit checks if decision result count exceeds limits.

func CheckEventBlobSizeLimit added in v0.5.0

func CheckEventBlobSizeLimit(
	actualSize int,
	warnLimit int,
	errorLimit int,
	domainID string,
	domainName string,
	workflowID string,
	runID string,
	scope metrics.Scope,
	logger log.Logger,
	blobSizeViolationOperationTag tag.Tag,
) error

CheckEventBlobSizeLimit checks if a blob data exceeds limits. It logs a warning if it exceeds warnLimit, and return ErrBlobSizeExceedsLimit if it exceeds errorLimit.

func ChildWorkflowExecutionFailedCausePtr added in v0.3.2

func ChildWorkflowExecutionFailedCausePtr(t s.ChildWorkflowExecutionFailedCause) *s.ChildWorkflowExecutionFailedCause

ChildWorkflowExecutionFailedCausePtr makes a copy and returns the pointer to a ChildWorkflowExecutionFailedCause.

func ClientArchivalStatusPtr added in v0.5.7

func ClientArchivalStatusPtr(t shared.ArchivalStatus) *shared.ArchivalStatus

ClientArchivalStatusPtr makes a copy and returns the pointer to a client ArchivalStatus.

func ConvertErrToGetTaskFailedCause added in v0.23.1

func ConvertErrToGetTaskFailedCause(err error) types.GetTaskFailedCause

ConvertErrToGetTaskFailedCause converts error to GetTaskFailedCause

func ConvertGetTaskFailedCauseToErr added in v0.24.0

func ConvertGetTaskFailedCauseToErr(failedCause types.GetTaskFailedCause) error

ConvertGetTaskFailedCauseToErr converts GetTaskFailedCause to error

func ConvertIndexedValueTypeToInternalType added in v1.0.0

func ConvertIndexedValueTypeToInternalType(fieldType interface{}, logger log.Logger) types.IndexedValueType

ConvertIndexedValueTypeToInternalType takes fieldType as interface{} and convert to IndexedValueType. Because different implementation of dynamic config client may lead to different types

func CreateAdminServiceRetryPolicy added in v0.5.0

func CreateAdminServiceRetryPolicy() backoff.RetryPolicy

CreateAdminServiceRetryPolicy creates a retry policy for calls to matching service

func CreateChildContext added in v0.23.1

func CreateChildContext(
	parent context.Context,
	tailroom float64,
) (context.Context, context.CancelFunc)

CreateChildContext creates a child context which shorted context timeout from the given parent context tailroom must be in range [0, 1] and (1-tailroom) * parent timeout will be the new child context timeout if tailroom is less 0, tailroom will be considered as 0 if tailroom is greater than 1, tailroom wil be considered as 1

func CreateDlqPublishRetryPolicy added in v0.18.0

func CreateDlqPublishRetryPolicy() backoff.RetryPolicy

CreateDlqPublishRetryPolicy creates a retry policy for kafka operation

func CreateDomainCacheRetryPolicy added in v1.2.18

func CreateDomainCacheRetryPolicy() backoff.RetryPolicy

CreateDomainCacheRetryPolicy creates a retry policy to handle domain cache refresh failures

func CreateFrontendServiceRetryPolicy added in v0.3.11

func CreateFrontendServiceRetryPolicy() backoff.RetryPolicy

CreateFrontendServiceRetryPolicy creates a retry policy for calls to frontend service

func CreateHistoryServiceRetryPolicy

func CreateHistoryServiceRetryPolicy() backoff.RetryPolicy

CreateHistoryServiceRetryPolicy creates a retry policy for calls to history service

func CreateHistoryStartWorkflowRequest added in v0.4.0

func CreateHistoryStartWorkflowRequest(
	domainID string,
	startRequest *types.StartWorkflowExecutionRequest,
	now time.Time,
	partitionConfig map[string]string,
) (*types.HistoryStartWorkflowExecutionRequest, error)

CreateHistoryStartWorkflowRequest create a start workflow request for history

func CreateMatchingPollForDecisionTaskResponse added in v0.3.12

func CreateMatchingPollForDecisionTaskResponse(historyResponse *types.RecordDecisionTaskStartedResponse, workflowExecution *types.WorkflowExecution, token []byte) *types.MatchingPollForDecisionTaskResponse

CreateMatchingPollForDecisionTaskResponse create response for matching's PollForDecisionTask

func CreateMatchingServiceRetryPolicy added in v0.5.0

func CreateMatchingServiceRetryPolicy() backoff.RetryPolicy

CreateMatchingServiceRetryPolicy creates a retry policy for calls to matching service

func CreatePersistenceRetryPolicy added in v0.13.0

func CreatePersistenceRetryPolicy() backoff.RetryPolicy

CreatePersistenceRetryPolicy creates a retry policy for persistence layer operations

func CreateReplicationServiceBusyRetryPolicy added in v0.14.0

func CreateReplicationServiceBusyRetryPolicy() backoff.RetryPolicy

CreateReplicationServiceBusyRetryPolicy creates a retry policy to handle replication service busy

func CreateShardDistributorServiceRetryPolicy added in v1.2.16

func CreateShardDistributorServiceRetryPolicy() backoff.RetryPolicy

func CreateTaskCompleterRetryPolicy added in v1.2.15

func CreateTaskCompleterRetryPolicy() backoff.RetryPolicy

CreateTaskCompleterRetryPolicy creates a retry policy to handle tasks not being started

func CreateTaskProcessingRetryPolicy added in v0.13.0

func CreateTaskProcessingRetryPolicy() backoff.RetryPolicy

CreateTaskProcessingRetryPolicy creates a retry policy for task processing

func DaysToDuration added in v0.17.0

func DaysToDuration(d int32) time.Duration

DaysToDuration converts number of 24 hour days to time.Duration

func DecisionTaskFailedCausePtr added in v0.3.2

func DecisionTaskFailedCausePtr(t s.DecisionTaskFailedCause) *s.DecisionTaskFailedCause

DecisionTaskFailedCausePtr makes a copy and returns the pointer to a DecisionTaskFailedCause.

func DecisionTypePtr

func DecisionTypePtr(t s.DecisionType) *s.DecisionType

DecisionTypePtr makes a copy and returns the pointer to a DecisionType.

func DeserializeSearchAttributeValue added in v0.12.0

func DeserializeSearchAttributeValue(value []byte, valueType types.IndexedValueType) (interface{}, error)

DeserializeSearchAttributeValue takes json encoded search attribute value and it's type as input, then unmarshal the value into a concrete type and return the value

func DomainIDToHistoryShard added in v0.14.0

func DomainIDToHistoryShard(domainID string, numberOfShards int) int

DomainIDToHistoryShard is used to map a domainID to a shardID

func DurationPtr added in v0.18.0

func DurationPtr(v time.Duration) *time.Duration

DurationPtr makes a copy and returns the pointer to a duration

func DurationToDays added in v0.17.0

func DurationToDays(d time.Duration) int32

DurationToDays converts time.Duration to number of 24 hour days

func DurationToSeconds added in v0.17.0

func DurationToSeconds(d time.Duration) int64

DurationToSeconds converts time.Duration to number of seconds

func EventTypePtr

func EventTypePtr(t s.EventType) *s.EventType

EventTypePtr makes a copy and returns the pointer to a EventType.

func Float64Ptr

func Float64Ptr(v float64) *float64

Float64Ptr makes a copy and returns the pointer to an int64.

func FrontendRetry added in v1.2.9

func FrontendRetry(err error) bool

HistoryRetryFuncFrontendExceptions checks if an error should be retried in a call from frontend

func GenerateRandomString added in v0.3.12

func GenerateRandomString(n int) string

GenerateRandomString is used for generate test string

func GetSizeOfHistoryEvent added in v0.14.0

func GetSizeOfHistoryEvent(event *types.HistoryEvent) uint64

GetSizeOfHistoryEvent returns approximate size in bytes of the history event taking into account byte arrays only now

func GetSizeOfMapStringToByteArray added in v0.5.7

func GetSizeOfMapStringToByteArray(input map[string][]byte) int

GetSizeOfMapStringToByteArray get size of map[string][]byte

func Int16Ptr added in v0.5.7

func Int16Ptr(v int16) *int16

Int16Ptr makes a copy and returns the pointer to an int16.

func Int32Default added in v0.3.2

func Int32Default(v *int32) int32

Int32Default returns value if int32 pointer is set otherwise default value of int32

func Int32Ptr

func Int32Ptr(v int32) *int32

Int32Ptr makes a copy and returns the pointer to an int32.

func Int64Default added in v0.3.2

func Int64Default(v *int64) int64

Int64Default returns value if int64 pointer is set otherwise default value of int64

func Int64Ptr

func Int64Ptr(v int64) *int64

Int64Ptr makes a copy and returns the pointer to an int64.

func IntPtr

func IntPtr(v int) *int

IntPtr makes a copy and returns the pointer to an int.

func IntersectionStringSlice added in v1.2.1

func IntersectionStringSlice(a, b []string) []string

IntersectionStringSlice get the intersection of 2 string slices

func IsAdvancedVisibilityReadingEnabled added in v0.25.0

func IsAdvancedVisibilityReadingEnabled(isAdvancedVisReadEnabled, isAdvancedVisConfigExist bool) bool

IsAdvancedVisibilityReadingEnabled returns true if we should read from advanced visibility

func IsAdvancedVisibilityWritingEnabled added in v0.25.0

func IsAdvancedVisibilityWritingEnabled(advancedVisibilityWritingMode string, isAdvancedVisConfigExist bool) bool

IsAdvancedVisibilityWritingEnabled returns true if we should write to advanced visibility

func IsContextTimeoutError added in v0.14.0

func IsContextTimeoutError(err error) bool

IsContextTimeoutError checks if the error is context timeout error

func IsEntityNotExistsError added in v0.21.2

func IsEntityNotExistsError(err error) bool

IsEntityNotExistsError checks if the error is an entity not exists error.

func IsExpectedError added in v1.2.11

func IsExpectedError(err error) bool

IsExpectedError checks if an error is expected to happen in normal operation of the system

func IsJustOrderByClause added in v0.5.9

func IsJustOrderByClause(clause string) bool

IsJustOrderByClause return true is query start with order by

func IsServiceBusyError added in v0.14.0

func IsServiceBusyError(err error) bool

IsServiceBusyError checks if the error is a service busy error.

func IsServiceTransientError added in v0.3.11

func IsServiceTransientError(err error) bool

IsServiceTransientError checks if the error is a transient error.

func IsStickyTaskConditionError added in v0.14.0

func IsStickyTaskConditionError(err error) bool

IsStickyTaskConditionError is error from matching engine

func IsValidContext

func IsValidContext(ctx context.Context) error

IsValidContext checks that the thrift context is not expired on cancelled. Returns nil if the context is still valid. Otherwise, returns the result of ctx.Err()

func IsValidIDLength added in v1.2.7

func IsValidIDLength(
	id string,
	scope metrics.Scope,
	warnLimit int,
	errorLimit int,
	metricsCounter int,
	domainName string,
	logger log.Logger,
	idTypeViolationTag tag.Tag,
) bool

IsValidIDLength checks if id is valid according to its length

func LoadRSAPrivateKey added in v0.23.1

func LoadRSAPrivateKey(path string) (*rsa.PrivateKey, error)

func LoadRSAPublicKey added in v0.23.1

func LoadRSAPublicKey(path string) (*rsa.PublicKey, error)

func NewPerTaskListScope added in v1.2.13

func NewPerTaskListScope(
	domainName string,
	taskListName string,
	taskListKind types.TaskListKind,
	client metrics.Client,
	scopeIdx int,
) metrics.Scope

NewPerTaskListScope creates a tasklist metrics scope

func ParentClosePolicyPtr added in v0.9.0

func ParentClosePolicyPtr(t s.ParentClosePolicy) *s.ParentClosePolicy

ParentClosePolicyPtr makes a copy and returns the pointer to a DecisionType.

func Ptr added in v1.2.9

func Ptr[T any](v T) *T

Returns a pointer to the given value. todo (david.porter) Remove the remaining helpers here which are now obsolete

func QueryConsistencyLevelPtr added in v0.11.0

func QueryConsistencyLevelPtr(t s.QueryConsistencyLevel) *s.QueryConsistencyLevel

QueryConsistencyLevelPtr makes a copy and returns the pointer to a QueryConsistencyLevel

func QueryRejectConditionPtr added in v0.11.0

func QueryRejectConditionPtr(t s.QueryRejectCondition) *s.QueryRejectCondition

QueryRejectConditionPtr makes a copy and returns the pointer to a QueryRejectCondition

func QueryResultTypePtr added in v0.11.0

func QueryResultTypePtr(t s.QueryResultType) *s.QueryResultType

QueryResultTypePtr makes a copy and returns the pointer to a QueryResultType

func QueryTaskCompletedTypePtr added in v0.10.1

func QueryTaskCompletedTypePtr(t s.QueryTaskCompletedType) *s.QueryTaskCompletedType

QueryTaskCompletedTypePtr makes a copy and returns the pointer to a QueryTaskCompletedType

func SecondsToDuration added in v0.17.0

func SecondsToDuration(d int64) time.Duration

SecondsToDuration converts number of seconds to time.Duration

func SignalExternalWorkflowExecutionFailedCausePtr added in v0.3.6

func SignalExternalWorkflowExecutionFailedCausePtr(t s.SignalExternalWorkflowExecutionFailedCause) *s.SignalExternalWorkflowExecutionFailedCause

SignalExternalWorkflowExecutionFailedCausePtr makes a copy and returns the pointer to a SignalExternalWorkflowExecutionFailedCause.

func SleepWithMinDuration added in v0.23.1

func SleepWithMinDuration(desired time.Duration, available time.Duration) time.Duration

SleepWithMinDuration sleeps for the minimum of desired and available duration returns the remaining available time duration

func StringDefault added in v0.3.2

func StringDefault(v *string) string

StringDefault returns value if string pointer is set otherwise default value of string

func StringPtr

func StringPtr(v string) *string

StringPtr makes a copy and returns the pointer to a string.

func TaskListKindPtr added in v0.3.6

func TaskListKindPtr(t s.TaskListKind) *s.TaskListKind

TaskListKindPtr makes a copy and returns the pointer to a TaskListKind.

func TaskListPtr

func TaskListPtr(v s.TaskList) *s.TaskList

TaskListPtr makes a copy and returns the pointer to a TaskList.

func TaskListTypePtr added in v0.4.0

func TaskListTypePtr(t s.TaskListType) *s.TaskListType

TaskListTypePtr makes a copy and returns the pointer to a TaskListKind.

func TimeNowNanosPtr added in v0.5.7

func TimeNowNanosPtr() *int64

TimeNowNanosPtr returns an int64 ptr to current time in unix nanos

func TimePtr added in v0.17.0

func TimePtr(v time.Time) *time.Time

TimePtr makes a copy and returns the pointer to a time

func TimeoutTypePtr added in v0.3.2

func TimeoutTypePtr(t s.TimeoutType) *s.TimeoutType

TimeoutTypePtr makes a copy and returns the pointer to a TimeoutType.

func ToServiceTransientError added in v0.25.0

func ToServiceTransientError(err error) error

ToServiceTransientError converts an error to ServiceTransientError

func Uint32Ptr

func Uint32Ptr(v uint32) *uint32

Uint32Ptr makes a copy and returns the pointer to a uint32.

func Uint64Ptr

func Uint64Ptr(v uint64) *uint64

Uint64Ptr makes a copy and returns the pointer to a uint64.

func ValidateDomainUUID added in v0.20.0

func ValidateDomainUUID(
	domainUUID string,
) error

ValidateDomainUUID checks if the given domainID string is a valid UUID

func ValidateLongPollContextTimeout added in v0.5.7

func ValidateLongPollContextTimeout(
	ctx context.Context,
	handlerName string,
	logger log.Logger,
) error

ValidateLongPollContextTimeout check if the context timeout for a long poll handler is too short or below a normal value. If the timeout is not set or too short, it logs an error, and return ErrContextTimeoutNotSet or ErrContextTimeoutTooShort accordingly. If the timeout is only below a normal value, it just logs an info and return nil.

func ValidateLongPollContextTimeoutIsSet added in v0.8.6

func ValidateLongPollContextTimeoutIsSet(
	ctx context.Context,
	handlerName string,
	logger log.Logger,
) (time.Time, error)

ValidateLongPollContextTimeoutIsSet checks if the context timeout is set for long poll requests.

func ValidateRetryPolicy added in v0.4.0

func ValidateRetryPolicy(policy *types.RetryPolicy) error

ValidateRetryPolicy validates a retry policy

func WorkflowIDToHistoryShard

func WorkflowIDToHistoryShard(workflowID string, numberOfShards int) int

WorkflowIDToHistoryShard is used to map a workflowID to a shardID

func WorkflowTypePtr

func WorkflowTypePtr(t s.WorkflowType) *s.WorkflowType

WorkflowTypePtr makes a copy and returns the pointer to a WorkflowType.

Types

type Daemon

type Daemon interface {
	Start()
	Stop()
}

Daemon is the base interfaces implemented by background tasks within Cadence

type KeyType added in v0.23.1

type KeyType string
const (
	KeyTypePrivate KeyType = "private key"

	KeyTypePublic KeyType = "public key"
)

type MockPProfInitializer added in v1.2.15

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

MockPProfInitializer is a mock of PProfInitializer interface.

func NewMockPProfInitializer added in v1.2.15

func NewMockPProfInitializer(ctrl *gomock.Controller) *MockPProfInitializer

NewMockPProfInitializer creates a new mock instance.

func (*MockPProfInitializer) EXPECT added in v1.2.15

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

func (*MockPProfInitializer) Start added in v1.2.15

func (m *MockPProfInitializer) Start() error

Start mocks base method.

type MockPProfInitializerMockRecorder added in v1.2.15

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

MockPProfInitializerMockRecorder is the mock recorder for MockPProfInitializer.

func (*MockPProfInitializerMockRecorder) Start added in v1.2.15

Start indicates an expected call of Start.

type MockTaskTokenSerializer added in v1.2.9

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

MockTaskTokenSerializer is a mock of TaskTokenSerializer interface.

func NewMockTaskTokenSerializer added in v1.2.9

func NewMockTaskTokenSerializer(ctrl *gomock.Controller) *MockTaskTokenSerializer

NewMockTaskTokenSerializer creates a new mock instance.

func (*MockTaskTokenSerializer) Deserialize added in v1.2.9

func (m *MockTaskTokenSerializer) Deserialize(data []byte) (*TaskToken, error)

Deserialize mocks base method.

func (*MockTaskTokenSerializer) DeserializeQueryTaskToken added in v1.2.9

func (m *MockTaskTokenSerializer) DeserializeQueryTaskToken(data []byte) (*QueryTaskToken, error)

DeserializeQueryTaskToken mocks base method.

func (*MockTaskTokenSerializer) EXPECT added in v1.2.9

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

func (*MockTaskTokenSerializer) Serialize added in v1.2.9

func (m *MockTaskTokenSerializer) Serialize(token *TaskToken) ([]byte, error)

Serialize mocks base method.

func (*MockTaskTokenSerializer) SerializeQueryTaskToken added in v1.2.9

func (m *MockTaskTokenSerializer) SerializeQueryTaskToken(token *QueryTaskToken) ([]byte, error)

SerializeQueryTaskToken mocks base method.

type MockTaskTokenSerializerMockRecorder added in v1.2.9

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

MockTaskTokenSerializerMockRecorder is the mock recorder for MockTaskTokenSerializer.

func (*MockTaskTokenSerializerMockRecorder) Deserialize added in v1.2.9

func (mr *MockTaskTokenSerializerMockRecorder) Deserialize(data any) *gomock.Call

Deserialize indicates an expected call of Deserialize.

func (*MockTaskTokenSerializerMockRecorder) DeserializeQueryTaskToken added in v1.2.9

func (mr *MockTaskTokenSerializerMockRecorder) DeserializeQueryTaskToken(data any) *gomock.Call

DeserializeQueryTaskToken indicates an expected call of DeserializeQueryTaskToken.

func (*MockTaskTokenSerializerMockRecorder) Serialize added in v1.2.9

func (mr *MockTaskTokenSerializerMockRecorder) Serialize(token any) *gomock.Call

Serialize indicates an expected call of Serialize.

func (*MockTaskTokenSerializerMockRecorder) SerializeQueryTaskToken added in v1.2.9

func (mr *MockTaskTokenSerializerMockRecorder) SerializeQueryTaskToken(token any) *gomock.Call

SerializeQueryTaskToken indicates an expected call of SerializeQueryTaskToken.

type PProfInitializer added in v0.3.5

type PProfInitializer interface {
	Start() error
}

PProfInitializer initialize the pprof based on config

type QueryTaskToken added in v0.3.2

type QueryTaskToken struct {
	DomainID   string `json:"domainId"`
	WorkflowID string `json:"workflowId"`
	RunID      string `json:"runId"`
	TaskList   string `json:"taskList"`
	TaskID     string `json:"taskId"`
}

QueryTaskToken identifies a query task

func (QueryTaskToken) GetDomainID added in v1.2.9

func (t QueryTaskToken) GetDomainID() string

type TaskToken

type TaskToken struct {
	DomainID        string `json:"domainId"`
	WorkflowID      string `json:"workflowId"`
	WorkflowType    string `json:"workflowType"`
	RunID           string `json:"runId"`
	ScheduleID      int64  `json:"scheduleId"`
	ScheduleAttempt int64  `json:"scheduleAttempt"`
	ActivityID      string `json:"activityId"`
	ActivityType    string `json:"activityType"`
}

TaskToken identifies a task

func (TaskToken) GetDomainID added in v1.2.9

func (t TaskToken) GetDomainID() string

type TaskTokenSerializer

type TaskTokenSerializer interface {
	Serialize(token *TaskToken) ([]byte, error)
	Deserialize(data []byte) (*TaskToken, error)
	SerializeQueryTaskToken(token *QueryTaskToken) ([]byte, error)
	DeserializeQueryTaskToken(data []byte) (*QueryTaskToken, error)
}

TaskTokenSerializer serializes task tokens

func NewJSONTaskTokenSerializer

func NewJSONTaskTokenSerializer() TaskTokenSerializer

NewJSONTaskTokenSerializer creates a new instance of TaskTokenSerializer

Directories

Path Synopsis
Package activecluster is a generated GoMock package.
Package activecluster is a generated GoMock package.
Package archiver is a generated GoMock package.
Package archiver is a generated GoMock package.
filestore
Package filestore is a generated GoMock package.
Package filestore is a generated GoMock package.
s3store
Package s3store is a generated GoMock package.
Package s3store is a generated GoMock package.
gcloud Module
asyncworkflow
queue
Package queue is a generated GoMock package.
Package queue is a generated GoMock package.
queue/provider
Package provider is a generated GoMock package.
Package provider is a generated GoMock package.
queueconfigapi
Package queueconfigapi is a generated GoMock package.
Package queueconfigapi is a generated GoMock package.
Package authorization is a generated GoMock package.
Package authorization is a generated GoMock package.
Package client is a generated GoMock package.
Package client is a generated GoMock package.
Package clock is a generated GoMock package.
Package clock is a generated GoMock package.
Package codec is a generated GoMock package.
Package codec is a generated GoMock package.
gob
Package domain is a generated GoMock package.
Package domain is a generated GoMock package.
Package dynamicconfig is a generated GoMock package.
Package dynamicconfig is a generated GoMock package.
configstore
Package configstore is a generated GoMock package.
Package configstore is a generated GoMock package.
Package isolationgroup is a generated GoMock package.
Package isolationgroup is a generated GoMock package.
isolationgroupapi
Package isolationgroupapi is a generated GoMock package.
Package isolationgroupapi is a generated GoMock package.
log
tag
types
Package types is a generated GoMock package.
Package types is a generated GoMock package.
Package membership is a generated GoMock package.
Package membership is a generated GoMock package.
Package messaging is a generated GoMock package.
Package messaging is a generated GoMock package.
Package ndc is a generated GoMock package.
Package ndc is a generated GoMock package.
Package pagination is a generated GoMock package.
Package pagination is a generated GoMock package.
Package persistence is a generated GoMock package.
Package persistence is a generated GoMock package.
client
Package client is a generated GoMock package.
Package client is a generated GoMock package.
nosql
Package nosql is a generated GoMock package.
Package nosql is a generated GoMock package.
nosql/nosqlplugin
Package nosqlplugin is a generated GoMock package.
Package nosqlplugin is a generated GoMock package.
nosql/nosqlplugin/cassandra/gocql
Package gocql is a generated GoMock package.
Package gocql is a generated GoMock package.
serialization
Package serialization is a generated GoMock package.
Package serialization is a generated GoMock package.
sql
sql/sqldriver
Package sqldriver is a generated GoMock package.
Package sqldriver is a generated GoMock package.
sql/sqlplugin
Package sqlplugin is a generated GoMock package.
Package sqlplugin is a generated GoMock package.
Package pinot is a generated GoMock package.
Package pinot is a generated GoMock package.
Package quotas is a generated GoMock package.
Package quotas is a generated GoMock package.
global
Package global contains a global-load-balance-aware ratelimiter (when complete).
Package global contains a global-load-balance-aware ratelimiter (when complete).
global/algorithm
Package algorithm contains a running-weighted-average calculator for ratelimits, and some associated types to prevent accidental confusion between the various floats/ints/etc involved.
Package algorithm contains a running-weighted-average calculator for ratelimits, and some associated types to prevent accidental confusion between the various floats/ints/etc involved.
global/collection
Package collection contains the limiting-host ratelimit usage tracking and enforcing logic, which acts as a quotas.Collection.
Package collection contains the limiting-host ratelimit usage tracking and enforcing logic, which acts as a quotas.Collection.
global/collection/internal
Package internal protects these types' concurrency primitives and other internals from accidental misuse.
Package internal protects these types' concurrency primitives and other internals from accidental misuse.
global/rpc
Package rpc contains a concurrent RPC client, and handles mapping to/from the Any-typed request details so other packages do not have to concern themselves with those details.
Package rpc contains a concurrent RPC client, and handles mapping to/from the Any-typed request details so other packages do not have to concern themselves with those details.
global/shared
Package shared holds some types that are used between multiple global-ratelimiter packages, and need to be broken out to prevent import cycles.
Package shared holds some types that are used between multiple global-ratelimiter packages, and need to be broken out to prevent import cycles.
invariant
Package invariant is a generated GoMock package.
Package invariant is a generated GoMock package.
store
Package store is a generated GoMock package.
Package store is a generated GoMock package.
Package resource is a generated GoMock package.
Package resource is a generated GoMock package.
rpc
Package rpc is a generated GoMock package.
Package rpc is a generated GoMock package.
Package stats is a generated GoMock package.
Package stats is a generated GoMock package.
Package task is a generated GoMock package.
Package task is a generated GoMock package.
Package taskvalidator provides a Work in Progress service for workflow validations.
Package taskvalidator provides a Work in Progress service for workflow validations.

Jump to

Keyboard shortcuts

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