resource

package
v1.2.14-prerelease07 Latest Latest
Warning

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

Go to latest
Published: Oct 8, 2024 License: MIT Imports: 50 Imported by: 1

Documentation

Overview

Package resource is a generated GoMock package.

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type Impl

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

Impl contains all common resources shared across frontend / matching / history / worker

func New

func New(
	params *Params,
	serviceName string,
	serviceConfig *service.Config,
) (impl *Impl, retError error)

New create a new resource containing common dependencies

func (*Impl) GetArchivalMetadata

func (h *Impl) GetArchivalMetadata() archiver.ArchivalMetadata

GetArchivalMetadata return archival metadata

func (*Impl) GetArchiverProvider

func (h *Impl) GetArchiverProvider() provider.ArchiverProvider

GetArchiverProvider return archival provider

func (*Impl) GetAsyncWorkflowQueueProvider added in v1.2.8

func (h *Impl) GetAsyncWorkflowQueueProvider() queue.Provider

GetAsyncWorkflowQueueProvider returns the async workflow queue provider

func (*Impl) GetBlobstoreClient added in v0.13.0

func (h *Impl) GetBlobstoreClient() blobstore.Client

GetBlobstoreClient returns blobstore client

func (*Impl) GetClientBean

func (h *Impl) GetClientBean() client.Bean

GetClientBean return RPC client bean

func (*Impl) GetClusterMetadata

func (h *Impl) GetClusterMetadata() cluster.Metadata

GetClusterMetadata return cluster metadata

func (*Impl) GetDispatcher

func (h *Impl) GetDispatcher() *yarpc.Dispatcher

GetDispatcher return YARPC dispatcher, used for registering handlers

func (*Impl) GetDomainCache

func (h *Impl) GetDomainCache() cache.DomainCache

GetDomainCache return domain cache

func (*Impl) GetDomainManager added in v0.22.0

func (h *Impl) GetDomainManager() persistence.DomainManager

GetMetadataManager return metadata manager

func (*Impl) GetDomainMetricsScopeCache added in v0.14.0

func (h *Impl) GetDomainMetricsScopeCache() cache.DomainMetricsScopeCache

GetDomainMetricsScopeCache return domainMetricsScope cache

func (*Impl) GetDomainReplicationQueue

func (h *Impl) GetDomainReplicationQueue() domain.ReplicationQueue

GetDomainReplicationQueue return domain replication queue

func (*Impl) GetExecutionManager

func (h *Impl) GetExecutionManager(
	shardID int,
) (persistence.ExecutionManager, error)

GetExecutionManager return execution manager for given shard ID

func (*Impl) GetFrontendClient

func (h *Impl) GetFrontendClient() frontend.Client

GetFrontendClient return frontend client with retry policy

func (*Impl) GetFrontendRawClient

func (h *Impl) GetFrontendRawClient() frontend.Client

GetFrontendRawClient return frontend client without retry policy

func (*Impl) GetHistoryClient

func (h *Impl) GetHistoryClient() history.Client

GetHistoryClient return history client with retry policy

func (*Impl) GetHistoryManager

func (h *Impl) GetHistoryManager() persistence.HistoryManager

GetHistoryManager return history manager

func (*Impl) GetHistoryRawClient

func (h *Impl) GetHistoryRawClient() history.Client

GetHistoryRawClient return history client without retry policy

func (*Impl) GetHostInfo

func (h *Impl) GetHostInfo() membership.HostInfo

GetHostInfo return host info

func (*Impl) GetHostName

func (h *Impl) GetHostName() string

func (*Impl) GetIsolationGroupState added in v1.2.1

func (h *Impl) GetIsolationGroupState() isolationgroup.State

GetIsolationGroupState returns the isolationGroupState

func (*Impl) GetIsolationGroupStore added in v1.2.1

func (h *Impl) GetIsolationGroupStore() configstore.Client

GetIsolationGroupStore returns the isolation group configuration store or nil

func (*Impl) GetLogger

func (h *Impl) GetLogger() log.Logger

GetLogger return logger

func (*Impl) GetMatchingClient

func (h *Impl) GetMatchingClient() matching.Client

GetMatchingClient return matching client with retry policy

func (*Impl) GetMatchingRawClient

func (h *Impl) GetMatchingRawClient() matching.Client

GetMatchingRawClient return matching client without retry policy

func (*Impl) GetMembershipResolver added in v0.24.0

func (h *Impl) GetMembershipResolver() membership.Resolver

GetMembershipResolver return the membership resolver

func (*Impl) GetMessagingClient

func (h *Impl) GetMessagingClient() messaging.Client

GetMessagingClient return messaging client

func (*Impl) GetMetricsClient

func (h *Impl) GetMetricsClient() metrics.Client

GetMetricsClient return metrics client

func (*Impl) GetPartitioner added in v1.2.1

func (h *Impl) GetPartitioner() partition.Partitioner

GetPartitioner returns the partitioner

func (*Impl) GetPayloadSerializer

func (h *Impl) GetPayloadSerializer() persistence.PayloadSerializer

GetPayloadSerializer return binary payload serializer

func (*Impl) GetPersistenceBean

func (h *Impl) GetPersistenceBean() persistenceClient.Bean

GetPersistenceBean return persistence bean

func (*Impl) GetRatelimiterAggregatorsClient added in v1.2.12

func (h *Impl) GetRatelimiterAggregatorsClient() rpc.Client

func (*Impl) GetRemoteAdminClient

func (h *Impl) GetRemoteAdminClient(
	cluster string,
) admin.Client

GetRemoteAdminClient return remote admin client for given cluster name

func (*Impl) GetRemoteFrontendClient

func (h *Impl) GetRemoteFrontendClient(
	cluster string,
) frontend.Client

GetRemoteFrontendClient return remote frontend client for given cluster name

func (*Impl) GetSDKClient

func (h *Impl) GetSDKClient() workflowserviceclient.Interface

GetSDKClient return sdk client

func (*Impl) GetServiceName

func (h *Impl) GetServiceName() string

GetServiceName return service name

func (*Impl) GetShardManager

func (h *Impl) GetShardManager() persistence.ShardManager

GetShardManager return shard manager

func (*Impl) GetTaskManager

func (h *Impl) GetTaskManager() persistence.TaskManager

GetTaskManager return task manager

func (*Impl) GetThrottledLogger

func (h *Impl) GetThrottledLogger() log.Logger

GetThrottledLogger return throttled logger

func (*Impl) GetTimeSource

func (h *Impl) GetTimeSource() clock.TimeSource

GetTimeSource return time source

func (*Impl) GetVisibilityManager

func (h *Impl) GetVisibilityManager() persistence.VisibilityManager

GetVisibilityManager return visibility manager

func (*Impl) Start

func (h *Impl) Start()

Start all resources

func (*Impl) Stop

func (h *Impl) Stop()

Stop stops all resources

type MockResource

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

MockResource is a mock of Resource interface.

func NewMockResource

func NewMockResource(ctrl *gomock.Controller) *MockResource

NewMockResource creates a new mock instance.

func (*MockResource) EXPECT

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

func (*MockResource) GetArchivalMetadata

func (m *MockResource) GetArchivalMetadata() archiver.ArchivalMetadata

GetArchivalMetadata mocks base method.

func (*MockResource) GetArchiverProvider

func (m *MockResource) GetArchiverProvider() provider.ArchiverProvider

GetArchiverProvider mocks base method.

func (*MockResource) GetAsyncWorkflowQueueProvider

func (m *MockResource) GetAsyncWorkflowQueueProvider() queue.Provider

GetAsyncWorkflowQueueProvider mocks base method.

func (*MockResource) GetBlobstoreClient

func (m *MockResource) GetBlobstoreClient() blobstore.Client

GetBlobstoreClient mocks base method.

func (*MockResource) GetClientBean

func (m *MockResource) GetClientBean() client.Bean

GetClientBean mocks base method.

func (*MockResource) GetClusterMetadata

func (m *MockResource) GetClusterMetadata() cluster.Metadata

GetClusterMetadata mocks base method.

func (*MockResource) GetDispatcher

func (m *MockResource) GetDispatcher() *yarpc.Dispatcher

GetDispatcher mocks base method.

func (*MockResource) GetDomainCache

func (m *MockResource) GetDomainCache() cache.DomainCache

GetDomainCache mocks base method.

func (*MockResource) GetDomainManager

func (m *MockResource) GetDomainManager() persistence.DomainManager

GetDomainManager mocks base method.

func (*MockResource) GetDomainMetricsScopeCache

func (m *MockResource) GetDomainMetricsScopeCache() cache.DomainMetricsScopeCache

GetDomainMetricsScopeCache mocks base method.

func (*MockResource) GetDomainReplicationQueue

func (m *MockResource) GetDomainReplicationQueue() domain.ReplicationQueue

GetDomainReplicationQueue mocks base method.

func (*MockResource) GetExecutionManager

func (m *MockResource) GetExecutionManager(arg0 int) (persistence.ExecutionManager, error)

GetExecutionManager mocks base method.

func (*MockResource) GetFrontendClient

func (m *MockResource) GetFrontendClient() frontend.Client

GetFrontendClient mocks base method.

func (*MockResource) GetFrontendRawClient

func (m *MockResource) GetFrontendRawClient() frontend.Client

GetFrontendRawClient mocks base method.

func (*MockResource) GetHistoryClient

func (m *MockResource) GetHistoryClient() history.Client

GetHistoryClient mocks base method.

func (*MockResource) GetHistoryManager

func (m *MockResource) GetHistoryManager() persistence.HistoryManager

GetHistoryManager mocks base method.

func (*MockResource) GetHistoryRawClient

func (m *MockResource) GetHistoryRawClient() history.Client

GetHistoryRawClient mocks base method.

func (*MockResource) GetHostInfo

func (m *MockResource) GetHostInfo() membership.HostInfo

GetHostInfo mocks base method.

func (*MockResource) GetHostName

func (m *MockResource) GetHostName() string

GetHostName mocks base method.

func (*MockResource) GetIsolationGroupState

func (m *MockResource) GetIsolationGroupState() isolationgroup.State

GetIsolationGroupState mocks base method.

func (*MockResource) GetIsolationGroupStore

func (m *MockResource) GetIsolationGroupStore() configstore.Client

GetIsolationGroupStore mocks base method.

func (*MockResource) GetLogger

func (m *MockResource) GetLogger() log.Logger

GetLogger mocks base method.

func (*MockResource) GetMatchingClient

func (m *MockResource) GetMatchingClient() matching.Client

GetMatchingClient mocks base method.

func (*MockResource) GetMatchingRawClient

func (m *MockResource) GetMatchingRawClient() matching.Client

GetMatchingRawClient mocks base method.

func (*MockResource) GetMembershipResolver

func (m *MockResource) GetMembershipResolver() membership.Resolver

GetMembershipResolver mocks base method.

func (*MockResource) GetMessagingClient

func (m *MockResource) GetMessagingClient() messaging.Client

GetMessagingClient mocks base method.

func (*MockResource) GetMetricsClient

func (m *MockResource) GetMetricsClient() metrics.Client

GetMetricsClient mocks base method.

func (*MockResource) GetPartitioner

func (m *MockResource) GetPartitioner() partition.Partitioner

GetPartitioner mocks base method.

func (*MockResource) GetPayloadSerializer

func (m *MockResource) GetPayloadSerializer() persistence.PayloadSerializer

GetPayloadSerializer mocks base method.

func (*MockResource) GetPersistenceBean

func (m *MockResource) GetPersistenceBean() client0.Bean

GetPersistenceBean mocks base method.

func (*MockResource) GetRatelimiterAggregatorsClient

func (m *MockResource) GetRatelimiterAggregatorsClient() rpc.Client

GetRatelimiterAggregatorsClient mocks base method.

func (*MockResource) GetRemoteAdminClient

func (m *MockResource) GetRemoteAdminClient(cluster string) admin.Client

GetRemoteAdminClient mocks base method.

func (*MockResource) GetRemoteFrontendClient

func (m *MockResource) GetRemoteFrontendClient(cluster string) frontend.Client

GetRemoteFrontendClient mocks base method.

func (*MockResource) GetSDKClient

func (m *MockResource) GetSDKClient() workflowserviceclient.Interface

GetSDKClient mocks base method.

func (*MockResource) GetServiceName

func (m *MockResource) GetServiceName() string

GetServiceName mocks base method.

func (*MockResource) GetShardManager

func (m *MockResource) GetShardManager() persistence.ShardManager

GetShardManager mocks base method.

func (*MockResource) GetTaskManager

func (m *MockResource) GetTaskManager() persistence.TaskManager

GetTaskManager mocks base method.

func (*MockResource) GetThrottledLogger

func (m *MockResource) GetThrottledLogger() log.Logger

GetThrottledLogger mocks base method.

func (*MockResource) GetTimeSource

func (m *MockResource) GetTimeSource() clock.TimeSource

GetTimeSource mocks base method.

func (*MockResource) GetVisibilityManager

func (m *MockResource) GetVisibilityManager() persistence.VisibilityManager

GetVisibilityManager mocks base method.

func (*MockResource) Start

func (m *MockResource) Start()

Start mocks base method.

func (*MockResource) Stop

func (m *MockResource) Stop()

Stop mocks base method.

type MockResourceFactory

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

MockResourceFactory is a mock of ResourceFactory interface.

func NewMockResourceFactory

func NewMockResourceFactory(ctrl *gomock.Controller) *MockResourceFactory

NewMockResourceFactory creates a new mock instance.

func (*MockResourceFactory) EXPECT

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

func (*MockResourceFactory) NewResource

func (m *MockResourceFactory) NewResource(params *Params, serviceName string, serviceConfig *service.Config) (Resource, error)

NewResource mocks base method.

type MockResourceFactoryMockRecorder

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

MockResourceFactoryMockRecorder is the mock recorder for MockResourceFactory.

func (*MockResourceFactoryMockRecorder) NewResource

func (mr *MockResourceFactoryMockRecorder) NewResource(params, serviceName, serviceConfig interface{}) *gomock.Call

NewResource indicates an expected call of NewResource.

type MockResourceMockRecorder

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

MockResourceMockRecorder is the mock recorder for MockResource.

func (*MockResourceMockRecorder) GetArchivalMetadata

func (mr *MockResourceMockRecorder) GetArchivalMetadata() *gomock.Call

GetArchivalMetadata indicates an expected call of GetArchivalMetadata.

func (*MockResourceMockRecorder) GetArchiverProvider

func (mr *MockResourceMockRecorder) GetArchiverProvider() *gomock.Call

GetArchiverProvider indicates an expected call of GetArchiverProvider.

func (*MockResourceMockRecorder) GetAsyncWorkflowQueueProvider

func (mr *MockResourceMockRecorder) GetAsyncWorkflowQueueProvider() *gomock.Call

GetAsyncWorkflowQueueProvider indicates an expected call of GetAsyncWorkflowQueueProvider.

func (*MockResourceMockRecorder) GetBlobstoreClient

func (mr *MockResourceMockRecorder) GetBlobstoreClient() *gomock.Call

GetBlobstoreClient indicates an expected call of GetBlobstoreClient.

func (*MockResourceMockRecorder) GetClientBean

func (mr *MockResourceMockRecorder) GetClientBean() *gomock.Call

GetClientBean indicates an expected call of GetClientBean.

func (*MockResourceMockRecorder) GetClusterMetadata

func (mr *MockResourceMockRecorder) GetClusterMetadata() *gomock.Call

GetClusterMetadata indicates an expected call of GetClusterMetadata.

func (*MockResourceMockRecorder) GetDispatcher

func (mr *MockResourceMockRecorder) GetDispatcher() *gomock.Call

GetDispatcher indicates an expected call of GetDispatcher.

func (*MockResourceMockRecorder) GetDomainCache

func (mr *MockResourceMockRecorder) GetDomainCache() *gomock.Call

GetDomainCache indicates an expected call of GetDomainCache.

func (*MockResourceMockRecorder) GetDomainManager

func (mr *MockResourceMockRecorder) GetDomainManager() *gomock.Call

GetDomainManager indicates an expected call of GetDomainManager.

func (*MockResourceMockRecorder) GetDomainMetricsScopeCache

func (mr *MockResourceMockRecorder) GetDomainMetricsScopeCache() *gomock.Call

GetDomainMetricsScopeCache indicates an expected call of GetDomainMetricsScopeCache.

func (*MockResourceMockRecorder) GetDomainReplicationQueue

func (mr *MockResourceMockRecorder) GetDomainReplicationQueue() *gomock.Call

GetDomainReplicationQueue indicates an expected call of GetDomainReplicationQueue.

func (*MockResourceMockRecorder) GetExecutionManager

func (mr *MockResourceMockRecorder) GetExecutionManager(arg0 interface{}) *gomock.Call

GetExecutionManager indicates an expected call of GetExecutionManager.

func (*MockResourceMockRecorder) GetFrontendClient

func (mr *MockResourceMockRecorder) GetFrontendClient() *gomock.Call

GetFrontendClient indicates an expected call of GetFrontendClient.

func (*MockResourceMockRecorder) GetFrontendRawClient

func (mr *MockResourceMockRecorder) GetFrontendRawClient() *gomock.Call

GetFrontendRawClient indicates an expected call of GetFrontendRawClient.

func (*MockResourceMockRecorder) GetHistoryClient

func (mr *MockResourceMockRecorder) GetHistoryClient() *gomock.Call

GetHistoryClient indicates an expected call of GetHistoryClient.

func (*MockResourceMockRecorder) GetHistoryManager

func (mr *MockResourceMockRecorder) GetHistoryManager() *gomock.Call

GetHistoryManager indicates an expected call of GetHistoryManager.

func (*MockResourceMockRecorder) GetHistoryRawClient

func (mr *MockResourceMockRecorder) GetHistoryRawClient() *gomock.Call

GetHistoryRawClient indicates an expected call of GetHistoryRawClient.

func (*MockResourceMockRecorder) GetHostInfo

func (mr *MockResourceMockRecorder) GetHostInfo() *gomock.Call

GetHostInfo indicates an expected call of GetHostInfo.

func (*MockResourceMockRecorder) GetHostName

func (mr *MockResourceMockRecorder) GetHostName() *gomock.Call

GetHostName indicates an expected call of GetHostName.

func (*MockResourceMockRecorder) GetIsolationGroupState

func (mr *MockResourceMockRecorder) GetIsolationGroupState() *gomock.Call

GetIsolationGroupState indicates an expected call of GetIsolationGroupState.

func (*MockResourceMockRecorder) GetIsolationGroupStore

func (mr *MockResourceMockRecorder) GetIsolationGroupStore() *gomock.Call

GetIsolationGroupStore indicates an expected call of GetIsolationGroupStore.

func (*MockResourceMockRecorder) GetLogger

func (mr *MockResourceMockRecorder) GetLogger() *gomock.Call

GetLogger indicates an expected call of GetLogger.

func (*MockResourceMockRecorder) GetMatchingClient

func (mr *MockResourceMockRecorder) GetMatchingClient() *gomock.Call

GetMatchingClient indicates an expected call of GetMatchingClient.

func (*MockResourceMockRecorder) GetMatchingRawClient

func (mr *MockResourceMockRecorder) GetMatchingRawClient() *gomock.Call

GetMatchingRawClient indicates an expected call of GetMatchingRawClient.

func (*MockResourceMockRecorder) GetMembershipResolver

func (mr *MockResourceMockRecorder) GetMembershipResolver() *gomock.Call

GetMembershipResolver indicates an expected call of GetMembershipResolver.

func (*MockResourceMockRecorder) GetMessagingClient

func (mr *MockResourceMockRecorder) GetMessagingClient() *gomock.Call

GetMessagingClient indicates an expected call of GetMessagingClient.

func (*MockResourceMockRecorder) GetMetricsClient

func (mr *MockResourceMockRecorder) GetMetricsClient() *gomock.Call

GetMetricsClient indicates an expected call of GetMetricsClient.

func (*MockResourceMockRecorder) GetPartitioner

func (mr *MockResourceMockRecorder) GetPartitioner() *gomock.Call

GetPartitioner indicates an expected call of GetPartitioner.

func (*MockResourceMockRecorder) GetPayloadSerializer

func (mr *MockResourceMockRecorder) GetPayloadSerializer() *gomock.Call

GetPayloadSerializer indicates an expected call of GetPayloadSerializer.

func (*MockResourceMockRecorder) GetPersistenceBean

func (mr *MockResourceMockRecorder) GetPersistenceBean() *gomock.Call

GetPersistenceBean indicates an expected call of GetPersistenceBean.

func (*MockResourceMockRecorder) GetRatelimiterAggregatorsClient

func (mr *MockResourceMockRecorder) GetRatelimiterAggregatorsClient() *gomock.Call

GetRatelimiterAggregatorsClient indicates an expected call of GetRatelimiterAggregatorsClient.

func (*MockResourceMockRecorder) GetRemoteAdminClient

func (mr *MockResourceMockRecorder) GetRemoteAdminClient(cluster interface{}) *gomock.Call

GetRemoteAdminClient indicates an expected call of GetRemoteAdminClient.

func (*MockResourceMockRecorder) GetRemoteFrontendClient

func (mr *MockResourceMockRecorder) GetRemoteFrontendClient(cluster interface{}) *gomock.Call

GetRemoteFrontendClient indicates an expected call of GetRemoteFrontendClient.

func (*MockResourceMockRecorder) GetSDKClient

func (mr *MockResourceMockRecorder) GetSDKClient() *gomock.Call

GetSDKClient indicates an expected call of GetSDKClient.

func (*MockResourceMockRecorder) GetServiceName

func (mr *MockResourceMockRecorder) GetServiceName() *gomock.Call

GetServiceName indicates an expected call of GetServiceName.

func (*MockResourceMockRecorder) GetShardManager

func (mr *MockResourceMockRecorder) GetShardManager() *gomock.Call

GetShardManager indicates an expected call of GetShardManager.

func (*MockResourceMockRecorder) GetTaskManager

func (mr *MockResourceMockRecorder) GetTaskManager() *gomock.Call

GetTaskManager indicates an expected call of GetTaskManager.

func (*MockResourceMockRecorder) GetThrottledLogger

func (mr *MockResourceMockRecorder) GetThrottledLogger() *gomock.Call

GetThrottledLogger indicates an expected call of GetThrottledLogger.

func (*MockResourceMockRecorder) GetTimeSource

func (mr *MockResourceMockRecorder) GetTimeSource() *gomock.Call

GetTimeSource indicates an expected call of GetTimeSource.

func (*MockResourceMockRecorder) GetVisibilityManager

func (mr *MockResourceMockRecorder) GetVisibilityManager() *gomock.Call

GetVisibilityManager indicates an expected call of GetVisibilityManager.

func (*MockResourceMockRecorder) Start

func (mr *MockResourceMockRecorder) Start() *gomock.Call

Start indicates an expected call of Start.

func (*MockResourceMockRecorder) Stop

func (mr *MockResourceMockRecorder) Stop() *gomock.Call

Stop indicates an expected call of Stop.

type Params added in v0.24.0

type Params struct {
	Name               string
	InstanceID         string
	Logger             log.Logger
	ThrottledLogger    log.Logger
	HostName           string
	GetIsolationGroups func() []string

	MetricScope        tally.Scope
	MembershipResolver membership.Resolver
	RPCFactory         common.RPCFactory
	PProfInitializer   common.PProfInitializer
	PersistenceConfig  config.Persistence
	ClusterMetadata    cluster.Metadata
	ReplicatorConfig   config.Replicator
	MetricsClient      metrics.Client
	MessagingClient    messaging.Client
	BlobstoreClient    blobstore.Client
	ESClient           es.GenericClient
	ESConfig           *config.ElasticSearchConfig

	DynamicConfig              dynamicconfig.Client
	ClusterRedirectionPolicy   *config.ClusterRedirectionPolicy
	PublicClient               workflowserviceclient.Interface
	ArchivalMetadata           archiver.ArchivalMetadata
	ArchiverProvider           provider.ArchiverProvider
	Authorizer                 authorization.Authorizer // NOTE: this can be nil. If nil, AccessControlledHandlerImpl will initiate one with config.Authorization
	AuthorizationConfig        config.Authorization     // NOTE: empty(default) struct will get a authorization.NoopAuthorizer
	IsolationGroupStore        configstore.Client       // This can be nil, the default config store will be created if so
	IsolationGroupState        isolationgroup.State     // This can be nil, the default state store will be chosen if so
	Partitioner                partition.Partitioner
	PinotConfig                *config.PinotVisibilityConfig
	KafkaConfig                config.KafkaConfig
	PinotClient                pinot.GenericClient
	OSClient                   es.GenericClient
	OSConfig                   *config.ElasticSearchConfig
	AsyncWorkflowQueueProvider queue.Provider
	TimeSource                 clock.TimeSource
	// HistoryClientFn is used by integration tests to mock a history client
	HistoryClientFn func() history.Client
}

Params holds the set of parameters needed to initialize common service resources

type Resource

type Resource interface {
	common.Daemon

	GetServiceName() string
	GetHostInfo() membership.HostInfo
	GetArchivalMetadata() archiver.ArchivalMetadata
	GetClusterMetadata() cluster.Metadata

	GetDomainCache() cache.DomainCache
	GetDomainMetricsScopeCache() cache.DomainMetricsScopeCache
	GetTimeSource() clock.TimeSource
	GetPayloadSerializer() persistence.PayloadSerializer
	GetMetricsClient() metrics.Client
	GetArchiverProvider() provider.ArchiverProvider
	GetMessagingClient() messaging.Client
	GetBlobstoreClient() blobstore.Client
	GetDomainReplicationQueue() domain.ReplicationQueue

	// membership infos
	GetMembershipResolver() membership.Resolver

	GetSDKClient() workflowserviceclient.Interface
	GetFrontendRawClient() frontend.Client
	GetFrontendClient() frontend.Client
	GetMatchingRawClient() matching.Client
	GetMatchingClient() matching.Client
	GetHistoryRawClient() history.Client
	GetHistoryClient() history.Client
	GetRatelimiterAggregatorsClient() rpc.Client
	GetRemoteAdminClient(cluster string) admin.Client
	GetRemoteFrontendClient(cluster string) frontend.Client
	GetClientBean() client.Bean

	// persistence clients
	GetDomainManager() persistence.DomainManager
	GetTaskManager() persistence.TaskManager
	GetVisibilityManager() persistence.VisibilityManager
	GetShardManager() persistence.ShardManager
	GetHistoryManager() persistence.HistoryManager
	GetExecutionManager(int) (persistence.ExecutionManager, error)
	GetPersistenceBean() persistenceClient.Bean

	// GetHostName get host name
	GetHostName() string

	// loggers
	GetLogger() log.Logger
	GetThrottledLogger() log.Logger

	// for registering handlers
	GetDispatcher() *yarpc.Dispatcher

	// GetIsolationGroupState returns the isolationGroupState
	GetIsolationGroupState() isolationgroup.State
	GetPartitioner() partition.Partitioner
	GetIsolationGroupStore() configstore.Client

	GetAsyncWorkflowQueueProvider() queue.Provider
}

Resource is the interface which expose common resources

type ResourceFactory

type ResourceFactory interface {
	NewResource(params *Params,
		serviceName string,
		serviceConfig *service.Config,
	) (resource Resource, err error)
}

func NewResourceFactory

func NewResourceFactory() ResourceFactory

type Test

type Test struct {
	MetricsScope    tally.TestScope
	ClusterMetadata cluster.Metadata

	DomainCache             *cache.MockDomainCache
	DomainMetricsScopeCache cache.DomainMetricsScopeCache
	DomainReplicationQueue  *domain.MockReplicationQueue
	TimeSource              clock.TimeSource
	PayloadSerializer       persistence.PayloadSerializer
	MetricsClient           metrics.Client
	ArchivalMetadata        *archiver.MockArchivalMetadata
	ArchiverProvider        *provider.MockArchiverProvider
	BlobstoreClient         *blobstore.MockClient
	MockPayloadSerializer   *persistence.MockPayloadSerializer

	// membership infos
	MembershipResolver *membership.MockResolver

	SDKClient            *publicservicetest.MockClient
	FrontendClient       *frontend.MockClient
	MatchingClient       *matching.MockClient
	HistoryClient        *history.MockClient
	RemoteAdminClient    *admin.MockClient
	RemoteFrontendClient *frontend.MockClient
	ClientBean           *client.MockBean

	MetadataMgr     *mocks.MetadataManager
	TaskMgr         *mocks.TaskManager
	VisibilityMgr   *mocks.VisibilityManager
	ShardMgr        *mocks.ShardManager
	HistoryMgr      *mocks.HistoryV2Manager
	ExecutionMgr    *mocks.ExecutionManager
	PersistenceBean *persistenceClient.MockBean

	IsolationGroups     *isolationgroup.MockState
	IsolationGroupStore *configstore.MockClient
	Partitioner         *partition.MockPartitioner
	HostName            string
	Logger              log.Logger

	AsyncWorkflowQueueProvider *queue.MockProvider

	RatelimiterAggregatorClient rpc.Client
	// contains filtered or unexported fields
}

Test is the test implementation used for testing

func NewTest

func NewTest(
	t *testing.T,
	controller *gomock.Controller,
	serviceMetricsIndex metrics.ServiceIdx,
) *Test

NewTest returns a new test resource instance

func (*Test) Finish

func (s *Test) Finish(
	t mock.TestingT,
)

Finish checks whether expectations are met

func (*Test) GetArchivalMetadata

func (s *Test) GetArchivalMetadata() archiver.ArchivalMetadata

GetArchivalMetadata for testing

func (*Test) GetArchiverProvider

func (s *Test) GetArchiverProvider() provider.ArchiverProvider

GetArchiverProvider for testing

func (*Test) GetAsyncWorkflowQueueProvider added in v1.2.8

func (s *Test) GetAsyncWorkflowQueueProvider() queue.Provider

func (*Test) GetBlobstoreClient added in v0.13.0

func (s *Test) GetBlobstoreClient() blobstore.Client

GetBlobstoreClient for testing

func (*Test) GetClientBean

func (s *Test) GetClientBean() client.Bean

GetClientBean for testing

func (*Test) GetClusterMetadata

func (s *Test) GetClusterMetadata() cluster.Metadata

GetClusterMetadata for testing

func (*Test) GetDispatcher

func (s *Test) GetDispatcher() *yarpc.Dispatcher

GetDispatcher for testing

func (*Test) GetDomainCache

func (s *Test) GetDomainCache() cache.DomainCache

GetDomainCache for testing

func (*Test) GetDomainManager added in v0.22.0

func (s *Test) GetDomainManager() persistence.DomainManager

GetMetadataManager for testing

func (*Test) GetDomainMetricsScopeCache added in v0.14.0

func (s *Test) GetDomainMetricsScopeCache() cache.DomainMetricsScopeCache

GetDomainMetricsScopeCache for testing

func (*Test) GetDomainReplicationQueue

func (s *Test) GetDomainReplicationQueue() domain.ReplicationQueue

GetDomainReplicationQueue for testing

func (*Test) GetExecutionManager

func (s *Test) GetExecutionManager(
	shardID int,
) (persistence.ExecutionManager, error)

GetExecutionManager for testing

func (*Test) GetFrontendClient

func (s *Test) GetFrontendClient() frontend.Client

GetFrontendClient for testing

func (*Test) GetFrontendRawClient

func (s *Test) GetFrontendRawClient() frontend.Client

GetFrontendRawClient for testing

func (*Test) GetHistoryClient

func (s *Test) GetHistoryClient() history.Client

GetHistoryClient for testing

func (*Test) GetHistoryManager

func (s *Test) GetHistoryManager() persistence.HistoryManager

GetHistoryManager for testing

func (*Test) GetHistoryRawClient

func (s *Test) GetHistoryRawClient() history.Client

GetHistoryRawClient for testing

func (*Test) GetHostInfo

func (s *Test) GetHostInfo() membership.HostInfo

GetHostInfo for testing

func (*Test) GetHostName

func (s *Test) GetHostName() string

GetHostName for testing

func (*Test) GetIsolationGroupState added in v1.2.1

func (s *Test) GetIsolationGroupState() isolationgroup.State

GetIsolationGroupState returns the isolationGroupState for testing

func (*Test) GetIsolationGroupStore added in v1.2.1

func (s *Test) GetIsolationGroupStore() configstore.Client

GetIsolationGroupStore returns the config store for their isolation-group stores

func (*Test) GetLogger

func (s *Test) GetLogger() log.Logger

GetLogger for testing

func (*Test) GetMatchingClient

func (s *Test) GetMatchingClient() matching.Client

GetMatchingClient for testing

func (*Test) GetMatchingRawClient

func (s *Test) GetMatchingRawClient() matching.Client

GetMatchingRawClient for testing

func (*Test) GetMembershipResolver added in v0.24.0

func (s *Test) GetMembershipResolver() membership.Resolver

GetMembershipResolver for testing

func (*Test) GetMessagingClient

func (s *Test) GetMessagingClient() messaging.Client

GetMessagingClient for testing

func (*Test) GetMetricsClient

func (s *Test) GetMetricsClient() metrics.Client

GetMetricsClient for testing

func (*Test) GetPartitioner added in v1.2.1

func (s *Test) GetPartitioner() partition.Partitioner

GetPartitioner returns the partitioner

func (*Test) GetPayloadSerializer

func (s *Test) GetPayloadSerializer() persistence.PayloadSerializer

GetPayloadSerializer for testing

func (*Test) GetPersistenceBean

func (s *Test) GetPersistenceBean() persistenceClient.Bean

GetPersistenceBean for testing

func (*Test) GetRatelimiterAggregatorsClient added in v1.2.12

func (s *Test) GetRatelimiterAggregatorsClient() rpc.Client

func (*Test) GetRemoteAdminClient

func (s *Test) GetRemoteAdminClient(
	cluster string,
) admin.Client

GetRemoteAdminClient for testing

func (*Test) GetRemoteFrontendClient

func (s *Test) GetRemoteFrontendClient(
	cluster string,
) frontend.Client

GetRemoteFrontendClient for testing

func (*Test) GetSDKClient

func (s *Test) GetSDKClient() workflowserviceclient.Interface

GetSDKClient for testing

func (*Test) GetServiceName

func (s *Test) GetServiceName() string

GetServiceName for testing

func (*Test) GetShardManager

func (s *Test) GetShardManager() persistence.ShardManager

GetShardManager for testing

func (*Test) GetTaskManager

func (s *Test) GetTaskManager() persistence.TaskManager

GetTaskManager for testing

func (*Test) GetTaskValidator added in v1.2.6

func (s *Test) GetTaskValidator() taskvalidator.Checker

GetPayloadSerializer for testing

func (*Test) GetThrottledLogger

func (s *Test) GetThrottledLogger() log.Logger

GetThrottledLogger for testing

func (*Test) GetTimeSource

func (s *Test) GetTimeSource() clock.TimeSource

GetTimeSource for testing

func (*Test) GetVisibilityManager

func (s *Test) GetVisibilityManager() persistence.VisibilityManager

GetVisibilityManager for testing

func (*Test) Start

func (s *Test) Start()

Start for testing

func (*Test) Stop

func (s *Test) Stop()

Stop for testing

type VisibilityManagerInitializer

type VisibilityManagerInitializer func(
	persistenceBean persistenceClient.Bean,
	logger log.Logger,
) (persistence.VisibilityManager, error)

VisibilityManagerInitializer is the function each service should implement for visibility manager initialization

Jump to

Keyboard shortcuts

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