client

package
v0.4.3 Latest Latest
Warning

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

Go to latest
Published: Sep 6, 2018 License: Apache-2.0 Imports: 52 Imported by: 49

README

client Implementation details

This file lists details and design choices about the implementation of the client package.

FetchTagged/FetchTaggedIDs

First point to note, FetchTagged/FetchTaggedIDs share a majority of code, so the following applies to both. The document points out where they differ as applicable.

First a quick glossary of the types used in this flow:

  • session: the implementation backing the client.Session interface, it's topology aware and does the fan-out/coordination of the request/response lifecycle.
  • op: generic interface used by the session as a unit of work. It has a completionFn specified based on the backing implementation. It is executed by the hostQueue.
  • completionFn: the callback specified on each op to return a response to the caller.
  • hostQueue: work queue maintained per host by the session. It does the execution of a rpc request asynchronously, and executing any callbacks specified on response/timeout.
  • fetchState: struct corresponding to a single attempt of a FetchTagged rpc request.
  • fetchTaggedResultsAccumulator: struct used by a fetchState for accumulating responses and converting to the appropriate response types eventually.
  • fetchTaggedShardConsistencyResult: struct used by the fetchTaggedResultsAccumulator for response consistency calculations.
  • fetchTaggedOp: implementation of op for the FetchTagged method calls.

Easiest way to understand this is to follow the control flow for the execution of a FetchTagged method.

Sequence of steps:

  1. A user of the API calls session.FetchTagged(...)
  2. session validates the request, and converts to the rpc type; terminating early if this fails.
  3. Once the request is validated, the session retrieves a fetchState, and fetchTaggedOp from their respective pools. We create a single fetchState and fetchTaggedOp per attempt.
  4. The fetchTaggedOp is enqueued into each known host's hostQueue.
  5. The session then calls fetchState.Wait(), which is backed by a condition variable, while waiting for responses to come back. Note: the calling go-routine will keep waiting until sufficient responses have been received to fullfil the consistency requirement of the request, or if we receive responses from all hosts and are still unable to meet the constraint.
  6. In the background, each hostQueue is executing the appropriate rpc and calling the completionFn with success/error/timeout.
  7. For each execution of the completionFn, the fetchState passes the response to the fetchTaggedResultsAccumulator which does the consistency calculation and updates its internal state. The fetchTaggedResultsAccumulator returns whether it's hit a terminating condition to to the fetchState, which acts upon it and if it has, calls Signal() to indicate to the original go-routine waiting on the condition variable that a response is available.
Nuances about lifecycle
  • The fetchTaggedOp retains a reference to the fetchState, so the fetchState has to remain alive until all hosts have returned a response/timed-out.
  • The fetchState created by the session in steps during the execution of a FetchTagged() method can remain alive even after the response. This is because we can return success even if we haven't received responses from all hosts depending on the consistency requirement. As a result, the final caller to fetchState.decRef() actually cleans it up and returns it to the pool. This will be a hostQueue in case of early success, or the go-routine calling the the FetchTagged() in case of error.

Documentation

Overview

Package client is a generated GoMock package.

Index

Constants

View Source
const (
	// DefaultWriteBatchSize is the default write and write tagged batch size.
	DefaultWriteBatchSize = 128
)

Variables

View Source
var (
	// ErrClusterConnectTimeout is raised when connecting to the cluster and
	// ensuring at least each partition has an up node with a connection to it
	ErrClusterConnectTimeout = errors.New("timed out establishing min connections to cluster")
)

Functions

func IsBadRequestError

func IsBadRequestError(err error) bool

IsBadRequestError determines if the error is a bad request error

func IsInternalServerError

func IsInternalServerError(err error) bool

IsInternalServerError determines if the error is an internal server error

func IsValidFetchBlocksMetadataEndpoint

func IsValidFetchBlocksMetadataEndpoint(
	endpointVersion FetchBlocksMetadataEndpointVersion,
) bool

IsValidFetchBlocksMetadataEndpoint returns a bool indicating whether the specified endpointVersion is valid

func NumError

func NumError(err error) int

NumError returns how many nodes responded with error for a given error

func NumResponded

func NumResponded(err error) int

NumResponded returns how many nodes responded for a given error

func NumSuccess

func NumSuccess(err error) int

NumSuccess returns how many nodes responded with success for a given error

Types

type AdminClient

type AdminClient interface {
	Client

	// NewSession creates a new session
	NewAdminSession() (AdminSession, error)

	// DefaultAdminSession creates a default admin session that gets reused
	DefaultAdminSession() (AdminSession, error)
}

AdminClient can create administration sessions

func NewAdminClient

func NewAdminClient(opts AdminOptions) (AdminClient, error)

NewAdminClient creates a new administrative client

type AdminOptions

type AdminOptions interface {
	Options

	// SetOrigin sets the current host originating requests from
	SetOrigin(value topology.Host) AdminOptions

	// Origin gets the current host originating requests from
	Origin() topology.Host

	// SetBootstrapConsistencyLevel sets the bootstrap consistency level
	SetBootstrapConsistencyLevel(value topology.ReadConsistencyLevel) AdminOptions

	// BootstrapConsistencyLevel returns the bootstrap consistency level
	BootstrapConsistencyLevel() topology.ReadConsistencyLevel

	// SetFetchSeriesBlocksMaxBlockRetries sets the max retries for fetching series blocks
	SetFetchSeriesBlocksMaxBlockRetries(value int) AdminOptions

	// FetchSeriesBlocksMaxBlockRetries gets the max retries for fetching series blocks
	FetchSeriesBlocksMaxBlockRetries() int

	// SetFetchSeriesBlocksBatchSize sets the batch size for fetching series blocks in batch
	SetFetchSeriesBlocksBatchSize(value int) AdminOptions

	// FetchSeriesBlocksBatchSize gets the batch size for fetching series blocks in batch
	FetchSeriesBlocksBatchSize() int

	// SetFetchSeriesBlocksMetadataBatchTimeout sets the timeout for fetching series blocks metadata in batch
	SetFetchSeriesBlocksMetadataBatchTimeout(value time.Duration) AdminOptions

	// FetchSeriesBlocksMetadataBatchTimeout gets the timeout for fetching series blocks metadata in batch
	FetchSeriesBlocksMetadataBatchTimeout() time.Duration

	// SetFetchSeriesBlocksBatchTimeout sets the timeout for fetching series blocks in batch
	SetFetchSeriesBlocksBatchTimeout(value time.Duration) AdminOptions

	// FetchSeriesBlocksBatchTimeout gets the timeout for fetching series blocks in batch
	FetchSeriesBlocksBatchTimeout() time.Duration

	// SetFetchSeriesBlocksBatchConcurrency sets the concurrency for fetching series blocks in batch
	SetFetchSeriesBlocksBatchConcurrency(value int) AdminOptions

	// FetchSeriesBlocksBatchConcurrency gets the concurrency for fetching series blocks in batch
	FetchSeriesBlocksBatchConcurrency() int

	// SetStreamBlocksRetrier sets the retrier for streaming blocks
	SetStreamBlocksRetrier(value xretry.Retrier) AdminOptions

	// StreamBlocksRetrier returns the retrier for streaming blocks
	StreamBlocksRetrier() xretry.Retrier
}

AdminOptions is a set of administration client options

func NewAdminOptions

func NewAdminOptions() AdminOptions

NewAdminOptions creates a new set of administration client options with defaults

type AdminSession

type AdminSession interface {
	Session

	// Origin returns the host that initiated the session
	Origin() topology.Host

	// Replicas returns the replication factor
	Replicas() int

	// TopologyMap returns the current topology map
	TopologyMap() (topology.Map, error)

	// Truncate will truncate the namespace for a given shard
	Truncate(namespace ident.ID) (int64, error)

	// FetchBootstrapBlocksFromPeers will fetch the most fulfilled block
	// for each series using the runtime configurable bootstrap level consistency
	FetchBootstrapBlocksFromPeers(
		namespace namespace.Metadata,
		shard uint32,
		start, end time.Time,
		opts result.Options,
		version FetchBlocksMetadataEndpointVersion,
	) (result.ShardResult, error)

	// FetchBootstrapBlocksMetadataFromPeers will fetch the blocks metadata from
	// available peers using the runtime configurable bootstrap level consistency
	FetchBootstrapBlocksMetadataFromPeers(
		namespace ident.ID,
		shard uint32,
		start, end time.Time,
		result result.Options,
		version FetchBlocksMetadataEndpointVersion,
	) (PeerBlockMetadataIter, error)

	// FetchBlocksMetadataFromPeers will fetch the blocks metadata from
	// available peers
	FetchBlocksMetadataFromPeers(
		namespace ident.ID,
		shard uint32,
		start, end time.Time,
		consistencyLevel topology.ReadConsistencyLevel,
		result result.Options,
		version FetchBlocksMetadataEndpointVersion,
	) (PeerBlockMetadataIter, error)

	// FetchBlocksFromPeers will fetch the required blocks from the
	// peers specified
	FetchBlocksFromPeers(
		namespace namespace.Metadata,
		shard uint32,
		consistencyLevel topology.ReadConsistencyLevel,
		metadatas []block.ReplicaMetadata,
		opts result.Options,
	) (PeerBlocksIter, error)
}

AdminSession can perform administrative and node-to-node operations

type Client

type Client interface {
	// Options returns the Client Options.
	Options() Options

	// NewSession creates a new session
	NewSession() (Session, error)

	// DefaultSession creates a default session that gets reused
	DefaultSession() (Session, error)

	// DefaultSessionActive returns whether the default session is active
	DefaultSessionActive() bool
}

Client can create sessions to write and read to a cluster

func NewClient

func NewClient(opts Options) (Client, error)

NewClient creates a new client

type Configuration

type Configuration struct {
	// The environment (static or dynamic) configuration.
	EnvironmentConfig environment.Configuration `yaml:"config"`

	// WriteConsistencyLevel specifies the write consistency level.
	WriteConsistencyLevel topology.ConsistencyLevel `yaml:"writeConsistencyLevel"`

	// ReadConsistencyLevel specifies the read consistency level.
	ReadConsistencyLevel topology.ReadConsistencyLevel `yaml:"readConsistencyLevel"`

	// ConnectConsistencyLevel specifies the cluster connect consistency level.
	ConnectConsistencyLevel topology.ConnectConsistencyLevel `yaml:"connectConsistencyLevel"`

	// WriteTimeout is the write request timeout.
	WriteTimeout time.Duration `yaml:"writeTimeout" validate:"min=0"`

	// FetchTimeout is the fetch request timeout.
	FetchTimeout time.Duration `yaml:"fetchTimeout" validate:"min=0"`

	// ConnectTimeout is the cluster connect timeout.
	ConnectTimeout time.Duration `yaml:"connectTimeout" validate:"min=0"`

	// WriteRetry is the write retry config.
	WriteRetry retry.Configuration `yaml:"writeRetry"`

	// FetchRetry is the fetch retry config.
	FetchRetry retry.Configuration `yaml:"fetchRetry"`

	// BackgroundHealthCheckFailLimit is the amount of times a background check
	// must fail before a connection is taken out of consideration.
	BackgroundHealthCheckFailLimit int `yaml:"backgroundHealthCheckFailLimit" validate:"min=1,max=10"`

	// BackgroundHealthCheckFailThrottleFactor is the factor of the host connect
	// time to use when sleeping between a failed health check and the next check.
	BackgroundHealthCheckFailThrottleFactor float64 `yaml:"backgroundHealthCheckFailThrottleFactor" validate:"min=0,max=10"`

	// HashingConfiguration is the configuration for hashing of IDs to shards.
	HashingConfiguration HashingConfiguration `yaml:"hashing"`
}

Configuration is a configuration that can be used to construct a client.

func (Configuration) NewAdminClient

func (c Configuration) NewAdminClient(
	params ConfigurationParameters,
	custom ...CustomAdminOption,
) (AdminClient, error)

NewAdminClient creates a new M3DB admin client using specified params and custom options.

func (Configuration) NewClient

func (c Configuration) NewClient(
	params ConfigurationParameters,
	custom ...CustomOption,
) (Client, error)

NewClient creates a new M3DB client using specified params and custom options.

type ConfigurationParameters

type ConfigurationParameters struct {
	// InstrumentOptions is a required argument when
	// constructing a client from configuration.
	InstrumentOptions instrument.Options

	// TopologyInitializer is an optional argument when
	// constructing a client from configuration.
	TopologyInitializer topology.Initializer

	// EncodingOptions is an optional argument when
	// constructing a client from configuration.
	EncodingOptions encoding.Options
}

ConfigurationParameters are optional parameters that can be specified when creating a client from configuration, this is specified using a struct so that adding fields do not cause breaking changes to callers.

type CustomAdminOption

type CustomAdminOption func(v AdminOptions) AdminOptions

CustomAdminOption is a programatic method for setting a client admin option after all the options have been set by configuration.

type CustomOption

type CustomOption func(v Options) Options

CustomOption is a programatic method for setting a client option after all the options have been set by configuration.

type FetchBlocksMetadataEndpointVersion

type FetchBlocksMetadataEndpointVersion int

FetchBlocksMetadataEndpointVersion represents an endpoint version for the fetch blocks metadata endpoint

const (
	// FetchBlocksMetadataEndpointDefault represents to use the default fetch blocks metadata endpoint
	FetchBlocksMetadataEndpointDefault FetchBlocksMetadataEndpointVersion = iota
	// FetchBlocksMetadataEndpointV1 represents v1 of the fetch blocks metadata endpoint
	FetchBlocksMetadataEndpointV1
	// FetchBlocksMetadataEndpointV2 represents v2 of the fetch blocks metadata endpoint
	FetchBlocksMetadataEndpointV2 = FetchBlocksMetadataEndpointDefault
)

func (FetchBlocksMetadataEndpointVersion) String

func (*FetchBlocksMetadataEndpointVersion) UnmarshalYAML

func (v *FetchBlocksMetadataEndpointVersion) UnmarshalYAML(unmarshal func(interface{}) error) error

UnmarshalYAML unmarshals an FetchBlocksMetadataEndpointVersion into a valid type from string.

type HashingConfiguration

type HashingConfiguration struct {
	// Murmur32 seed value
	Seed uint32 `yaml:"seed"`
}

HashingConfiguration is the configuration for hashing

type MockAdminClient

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

MockAdminClient is a mock of AdminClient interface

func NewMockAdminClient

func NewMockAdminClient(ctrl *gomock.Controller) *MockAdminClient

NewMockAdminClient creates a new mock instance

func (*MockAdminClient) DefaultAdminSession

func (m *MockAdminClient) DefaultAdminSession() (AdminSession, error)

DefaultAdminSession mocks base method

func (*MockAdminClient) DefaultSession

func (m *MockAdminClient) DefaultSession() (Session, error)

DefaultSession mocks base method

func (*MockAdminClient) DefaultSessionActive

func (m *MockAdminClient) DefaultSessionActive() bool

DefaultSessionActive mocks base method

func (*MockAdminClient) EXPECT

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

func (*MockAdminClient) NewAdminSession

func (m *MockAdminClient) NewAdminSession() (AdminSession, error)

NewAdminSession mocks base method

func (*MockAdminClient) NewSession

func (m *MockAdminClient) NewSession() (Session, error)

NewSession mocks base method

func (*MockAdminClient) Options

func (m *MockAdminClient) Options() Options

Options mocks base method

type MockAdminClientMockRecorder

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

MockAdminClientMockRecorder is the mock recorder for MockAdminClient

func (*MockAdminClientMockRecorder) DefaultAdminSession

func (mr *MockAdminClientMockRecorder) DefaultAdminSession() *gomock.Call

DefaultAdminSession indicates an expected call of DefaultAdminSession

func (*MockAdminClientMockRecorder) DefaultSession

func (mr *MockAdminClientMockRecorder) DefaultSession() *gomock.Call

DefaultSession indicates an expected call of DefaultSession

func (*MockAdminClientMockRecorder) DefaultSessionActive

func (mr *MockAdminClientMockRecorder) DefaultSessionActive() *gomock.Call

DefaultSessionActive indicates an expected call of DefaultSessionActive

func (*MockAdminClientMockRecorder) NewAdminSession

func (mr *MockAdminClientMockRecorder) NewAdminSession() *gomock.Call

NewAdminSession indicates an expected call of NewAdminSession

func (*MockAdminClientMockRecorder) NewSession

func (mr *MockAdminClientMockRecorder) NewSession() *gomock.Call

NewSession indicates an expected call of NewSession

func (*MockAdminClientMockRecorder) Options

func (mr *MockAdminClientMockRecorder) Options() *gomock.Call

Options indicates an expected call of Options

type MockAdminOptions

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

MockAdminOptions is a mock of AdminOptions interface

func NewMockAdminOptions

func NewMockAdminOptions(ctrl *gomock.Controller) *MockAdminOptions

NewMockAdminOptions creates a new mock instance

func (*MockAdminOptions) BackgroundConnectInterval

func (m *MockAdminOptions) BackgroundConnectInterval() time.Duration

BackgroundConnectInterval mocks base method

func (*MockAdminOptions) BackgroundConnectStutter

func (m *MockAdminOptions) BackgroundConnectStutter() time.Duration

BackgroundConnectStutter mocks base method

func (*MockAdminOptions) BackgroundHealthCheckFailLimit

func (m *MockAdminOptions) BackgroundHealthCheckFailLimit() int

BackgroundHealthCheckFailLimit mocks base method

func (*MockAdminOptions) BackgroundHealthCheckFailThrottleFactor

func (m *MockAdminOptions) BackgroundHealthCheckFailThrottleFactor() float64

BackgroundHealthCheckFailThrottleFactor mocks base method

func (*MockAdminOptions) BackgroundHealthCheckInterval

func (m *MockAdminOptions) BackgroundHealthCheckInterval() time.Duration

BackgroundHealthCheckInterval mocks base method

func (*MockAdminOptions) BackgroundHealthCheckStutter

func (m *MockAdminOptions) BackgroundHealthCheckStutter() time.Duration

BackgroundHealthCheckStutter mocks base method

func (*MockAdminOptions) BootstrapConsistencyLevel

func (m *MockAdminOptions) BootstrapConsistencyLevel() topology.ReadConsistencyLevel

BootstrapConsistencyLevel mocks base method

func (*MockAdminOptions) ChannelOptions

func (m *MockAdminOptions) ChannelOptions() *tchannel_go.ChannelOptions

ChannelOptions mocks base method

func (*MockAdminOptions) CheckedBytesWrapperPoolSize

func (m *MockAdminOptions) CheckedBytesWrapperPoolSize() int

CheckedBytesWrapperPoolSize mocks base method

func (*MockAdminOptions) ClockOptions

func (m *MockAdminOptions) ClockOptions() clock.Options

ClockOptions mocks base method

func (*MockAdminOptions) ClusterConnectConsistencyLevel

func (m *MockAdminOptions) ClusterConnectConsistencyLevel() topology.ConnectConsistencyLevel

ClusterConnectConsistencyLevel mocks base method

func (*MockAdminOptions) ClusterConnectTimeout

func (m *MockAdminOptions) ClusterConnectTimeout() time.Duration

ClusterConnectTimeout mocks base method

func (*MockAdminOptions) ContextPool

func (m *MockAdminOptions) ContextPool() context.Pool

ContextPool mocks base method

func (*MockAdminOptions) EXPECT

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

func (*MockAdminOptions) FetchBatchOpPoolSize

func (m *MockAdminOptions) FetchBatchOpPoolSize() int

FetchBatchOpPoolSize mocks base method

func (*MockAdminOptions) FetchBatchSize

func (m *MockAdminOptions) FetchBatchSize() int

FetchBatchSize mocks base method

func (*MockAdminOptions) FetchRequestTimeout

func (m *MockAdminOptions) FetchRequestTimeout() time.Duration

FetchRequestTimeout mocks base method

func (*MockAdminOptions) FetchRetrier

func (m *MockAdminOptions) FetchRetrier() retry.Retrier

FetchRetrier mocks base method

func (*MockAdminOptions) FetchSeriesBlocksBatchConcurrency

func (m *MockAdminOptions) FetchSeriesBlocksBatchConcurrency() int

FetchSeriesBlocksBatchConcurrency mocks base method

func (*MockAdminOptions) FetchSeriesBlocksBatchSize

func (m *MockAdminOptions) FetchSeriesBlocksBatchSize() int

FetchSeriesBlocksBatchSize mocks base method

func (*MockAdminOptions) FetchSeriesBlocksBatchTimeout

func (m *MockAdminOptions) FetchSeriesBlocksBatchTimeout() time.Duration

FetchSeriesBlocksBatchTimeout mocks base method

func (*MockAdminOptions) FetchSeriesBlocksMaxBlockRetries

func (m *MockAdminOptions) FetchSeriesBlocksMaxBlockRetries() int

FetchSeriesBlocksMaxBlockRetries mocks base method

func (*MockAdminOptions) FetchSeriesBlocksMetadataBatchTimeout

func (m *MockAdminOptions) FetchSeriesBlocksMetadataBatchTimeout() time.Duration

FetchSeriesBlocksMetadataBatchTimeout mocks base method

func (*MockAdminOptions) HostConnectTimeout

func (m *MockAdminOptions) HostConnectTimeout() time.Duration

HostConnectTimeout mocks base method

func (*MockAdminOptions) HostQueueOpsArrayPoolSize

func (m *MockAdminOptions) HostQueueOpsArrayPoolSize() int

HostQueueOpsArrayPoolSize mocks base method

func (*MockAdminOptions) HostQueueOpsFlushInterval

func (m *MockAdminOptions) HostQueueOpsFlushInterval() time.Duration

HostQueueOpsFlushInterval mocks base method

func (*MockAdminOptions) HostQueueOpsFlushSize

func (m *MockAdminOptions) HostQueueOpsFlushSize() int

HostQueueOpsFlushSize mocks base method

func (*MockAdminOptions) IdentifierPool

func (m *MockAdminOptions) IdentifierPool() ident.Pool

IdentifierPool mocks base method

func (*MockAdminOptions) InstrumentOptions

func (m *MockAdminOptions) InstrumentOptions() instrument.Options

InstrumentOptions mocks base method

func (*MockAdminOptions) MaxConnectionCount

func (m *MockAdminOptions) MaxConnectionCount() int

MaxConnectionCount mocks base method

func (*MockAdminOptions) MinConnectionCount

func (m *MockAdminOptions) MinConnectionCount() int

MinConnectionCount mocks base method

func (*MockAdminOptions) Origin

func (m *MockAdminOptions) Origin() topology.Host

Origin mocks base method

func (*MockAdminOptions) ReadConsistencyLevel

func (m *MockAdminOptions) ReadConsistencyLevel() topology.ReadConsistencyLevel

ReadConsistencyLevel mocks base method

func (*MockAdminOptions) ReaderIteratorAllocate

func (m *MockAdminOptions) ReaderIteratorAllocate() encoding.ReaderIteratorAllocate

ReaderIteratorAllocate mocks base method

func (*MockAdminOptions) RuntimeOptionsManager

func (m *MockAdminOptions) RuntimeOptionsManager() runtime.OptionsManager

RuntimeOptionsManager mocks base method

func (*MockAdminOptions) SeriesIteratorArrayPoolBuckets

func (m *MockAdminOptions) SeriesIteratorArrayPoolBuckets() []pool.Bucket

SeriesIteratorArrayPoolBuckets mocks base method

func (*MockAdminOptions) SeriesIteratorPoolSize

func (m *MockAdminOptions) SeriesIteratorPoolSize() int

SeriesIteratorPoolSize mocks base method

func (*MockAdminOptions) SetBackgroundConnectInterval

func (m *MockAdminOptions) SetBackgroundConnectInterval(value time.Duration) Options

SetBackgroundConnectInterval mocks base method

func (*MockAdminOptions) SetBackgroundConnectStutter

func (m *MockAdminOptions) SetBackgroundConnectStutter(value time.Duration) Options

SetBackgroundConnectStutter mocks base method

func (*MockAdminOptions) SetBackgroundHealthCheckFailLimit

func (m *MockAdminOptions) SetBackgroundHealthCheckFailLimit(value int) Options

SetBackgroundHealthCheckFailLimit mocks base method

func (*MockAdminOptions) SetBackgroundHealthCheckFailThrottleFactor

func (m *MockAdminOptions) SetBackgroundHealthCheckFailThrottleFactor(value float64) Options

SetBackgroundHealthCheckFailThrottleFactor mocks base method

func (*MockAdminOptions) SetBackgroundHealthCheckInterval

func (m *MockAdminOptions) SetBackgroundHealthCheckInterval(value time.Duration) Options

SetBackgroundHealthCheckInterval mocks base method

func (*MockAdminOptions) SetBackgroundHealthCheckStutter

func (m *MockAdminOptions) SetBackgroundHealthCheckStutter(value time.Duration) Options

SetBackgroundHealthCheckStutter mocks base method

func (*MockAdminOptions) SetBootstrapConsistencyLevel

func (m *MockAdminOptions) SetBootstrapConsistencyLevel(value topology.ReadConsistencyLevel) AdminOptions

SetBootstrapConsistencyLevel mocks base method

func (*MockAdminOptions) SetChannelOptions

func (m *MockAdminOptions) SetChannelOptions(value *tchannel_go.ChannelOptions) Options

SetChannelOptions mocks base method

func (*MockAdminOptions) SetCheckedBytesWrapperPoolSize

func (m *MockAdminOptions) SetCheckedBytesWrapperPoolSize(value int) Options

SetCheckedBytesWrapperPoolSize mocks base method

func (*MockAdminOptions) SetClockOptions

func (m *MockAdminOptions) SetClockOptions(value clock.Options) Options

SetClockOptions mocks base method

func (*MockAdminOptions) SetClusterConnectConsistencyLevel

func (m *MockAdminOptions) SetClusterConnectConsistencyLevel(value topology.ConnectConsistencyLevel) Options

SetClusterConnectConsistencyLevel mocks base method

func (*MockAdminOptions) SetClusterConnectTimeout

func (m *MockAdminOptions) SetClusterConnectTimeout(value time.Duration) Options

SetClusterConnectTimeout mocks base method

func (*MockAdminOptions) SetContextPool

func (m *MockAdminOptions) SetContextPool(value context.Pool) Options

SetContextPool mocks base method

func (*MockAdminOptions) SetEncodingM3TSZ

func (m *MockAdminOptions) SetEncodingM3TSZ() Options

SetEncodingM3TSZ mocks base method

func (*MockAdminOptions) SetFetchBatchOpPoolSize

func (m *MockAdminOptions) SetFetchBatchOpPoolSize(value int) Options

SetFetchBatchOpPoolSize mocks base method

func (*MockAdminOptions) SetFetchBatchSize

func (m *MockAdminOptions) SetFetchBatchSize(value int) Options

SetFetchBatchSize mocks base method

func (*MockAdminOptions) SetFetchRequestTimeout

func (m *MockAdminOptions) SetFetchRequestTimeout(value time.Duration) Options

SetFetchRequestTimeout mocks base method

func (*MockAdminOptions) SetFetchRetrier

func (m *MockAdminOptions) SetFetchRetrier(value retry.Retrier) Options

SetFetchRetrier mocks base method

func (*MockAdminOptions) SetFetchSeriesBlocksBatchConcurrency

func (m *MockAdminOptions) SetFetchSeriesBlocksBatchConcurrency(value int) AdminOptions

SetFetchSeriesBlocksBatchConcurrency mocks base method

func (*MockAdminOptions) SetFetchSeriesBlocksBatchSize

func (m *MockAdminOptions) SetFetchSeriesBlocksBatchSize(value int) AdminOptions

SetFetchSeriesBlocksBatchSize mocks base method

func (*MockAdminOptions) SetFetchSeriesBlocksBatchTimeout

func (m *MockAdminOptions) SetFetchSeriesBlocksBatchTimeout(value time.Duration) AdminOptions

SetFetchSeriesBlocksBatchTimeout mocks base method

func (*MockAdminOptions) SetFetchSeriesBlocksMaxBlockRetries

func (m *MockAdminOptions) SetFetchSeriesBlocksMaxBlockRetries(value int) AdminOptions

SetFetchSeriesBlocksMaxBlockRetries mocks base method

func (*MockAdminOptions) SetFetchSeriesBlocksMetadataBatchTimeout

func (m *MockAdminOptions) SetFetchSeriesBlocksMetadataBatchTimeout(value time.Duration) AdminOptions

SetFetchSeriesBlocksMetadataBatchTimeout mocks base method

func (*MockAdminOptions) SetHostConnectTimeout

func (m *MockAdminOptions) SetHostConnectTimeout(value time.Duration) Options

SetHostConnectTimeout mocks base method

func (*MockAdminOptions) SetHostQueueOpsArrayPoolSize

func (m *MockAdminOptions) SetHostQueueOpsArrayPoolSize(value int) Options

SetHostQueueOpsArrayPoolSize mocks base method

func (*MockAdminOptions) SetHostQueueOpsFlushInterval

func (m *MockAdminOptions) SetHostQueueOpsFlushInterval(value time.Duration) Options

SetHostQueueOpsFlushInterval mocks base method

func (*MockAdminOptions) SetHostQueueOpsFlushSize

func (m *MockAdminOptions) SetHostQueueOpsFlushSize(value int) Options

SetHostQueueOpsFlushSize mocks base method

func (*MockAdminOptions) SetIdentifierPool

func (m *MockAdminOptions) SetIdentifierPool(value ident.Pool) Options

SetIdentifierPool mocks base method

func (*MockAdminOptions) SetInstrumentOptions

func (m *MockAdminOptions) SetInstrumentOptions(value instrument.Options) Options

SetInstrumentOptions mocks base method

func (*MockAdminOptions) SetMaxConnectionCount

func (m *MockAdminOptions) SetMaxConnectionCount(value int) Options

SetMaxConnectionCount mocks base method

func (*MockAdminOptions) SetMinConnectionCount

func (m *MockAdminOptions) SetMinConnectionCount(value int) Options

SetMinConnectionCount mocks base method

func (*MockAdminOptions) SetOrigin

func (m *MockAdminOptions) SetOrigin(value topology.Host) AdminOptions

SetOrigin mocks base method

func (*MockAdminOptions) SetReadConsistencyLevel

func (m *MockAdminOptions) SetReadConsistencyLevel(value topology.ReadConsistencyLevel) Options

SetReadConsistencyLevel mocks base method

func (*MockAdminOptions) SetReaderIteratorAllocate

func (m *MockAdminOptions) SetReaderIteratorAllocate(value encoding.ReaderIteratorAllocate) Options

SetReaderIteratorAllocate mocks base method

func (*MockAdminOptions) SetRuntimeOptionsManager

func (m *MockAdminOptions) SetRuntimeOptionsManager(value runtime.OptionsManager) Options

SetRuntimeOptionsManager mocks base method

func (*MockAdminOptions) SetSeriesIteratorArrayPoolBuckets

func (m *MockAdminOptions) SetSeriesIteratorArrayPoolBuckets(value []pool.Bucket) Options

SetSeriesIteratorArrayPoolBuckets mocks base method

func (*MockAdminOptions) SetSeriesIteratorPoolSize

func (m *MockAdminOptions) SetSeriesIteratorPoolSize(value int) Options

SetSeriesIteratorPoolSize mocks base method

func (*MockAdminOptions) SetStreamBlocksRetrier

func (m *MockAdminOptions) SetStreamBlocksRetrier(value retry.Retrier) AdminOptions

SetStreamBlocksRetrier mocks base method

func (*MockAdminOptions) SetTagDecoderOptions

func (m *MockAdminOptions) SetTagDecoderOptions(value serialize.TagDecoderOptions) Options

SetTagDecoderOptions mocks base method

func (*MockAdminOptions) SetTagDecoderPoolSize

func (m *MockAdminOptions) SetTagDecoderPoolSize(value int) Options

SetTagDecoderPoolSize mocks base method

func (*MockAdminOptions) SetTagEncoderOptions

func (m *MockAdminOptions) SetTagEncoderOptions(value serialize.TagEncoderOptions) Options

SetTagEncoderOptions mocks base method

func (*MockAdminOptions) SetTagEncoderPoolSize

func (m *MockAdminOptions) SetTagEncoderPoolSize(value int) Options

SetTagEncoderPoolSize mocks base method

func (*MockAdminOptions) SetTopologyInitializer

func (m *MockAdminOptions) SetTopologyInitializer(value topology.Initializer) Options

SetTopologyInitializer mocks base method

func (*MockAdminOptions) SetTruncateRequestTimeout

func (m *MockAdminOptions) SetTruncateRequestTimeout(value time.Duration) Options

SetTruncateRequestTimeout mocks base method

func (*MockAdminOptions) SetWriteBatchSize

func (m *MockAdminOptions) SetWriteBatchSize(value int) Options

SetWriteBatchSize mocks base method

func (*MockAdminOptions) SetWriteConsistencyLevel

func (m *MockAdminOptions) SetWriteConsistencyLevel(value topology.ConsistencyLevel) Options

SetWriteConsistencyLevel mocks base method

func (*MockAdminOptions) SetWriteOpPoolSize

func (m *MockAdminOptions) SetWriteOpPoolSize(value int) Options

SetWriteOpPoolSize mocks base method

func (*MockAdminOptions) SetWriteRequestTimeout

func (m *MockAdminOptions) SetWriteRequestTimeout(value time.Duration) Options

SetWriteRequestTimeout mocks base method

func (*MockAdminOptions) SetWriteRetrier

func (m *MockAdminOptions) SetWriteRetrier(value retry.Retrier) Options

SetWriteRetrier mocks base method

func (*MockAdminOptions) SetWriteTaggedOpPoolSize

func (m *MockAdminOptions) SetWriteTaggedOpPoolSize(value int) Options

SetWriteTaggedOpPoolSize mocks base method

func (*MockAdminOptions) StreamBlocksRetrier

func (m *MockAdminOptions) StreamBlocksRetrier() retry.Retrier

StreamBlocksRetrier mocks base method

func (*MockAdminOptions) TagDecoderOptions

func (m *MockAdminOptions) TagDecoderOptions() serialize.TagDecoderOptions

TagDecoderOptions mocks base method

func (*MockAdminOptions) TagDecoderPoolSize

func (m *MockAdminOptions) TagDecoderPoolSize() int

TagDecoderPoolSize mocks base method

func (*MockAdminOptions) TagEncoderOptions

func (m *MockAdminOptions) TagEncoderOptions() serialize.TagEncoderOptions

TagEncoderOptions mocks base method

func (*MockAdminOptions) TagEncoderPoolSize

func (m *MockAdminOptions) TagEncoderPoolSize() int

TagEncoderPoolSize mocks base method

func (*MockAdminOptions) TopologyInitializer

func (m *MockAdminOptions) TopologyInitializer() topology.Initializer

TopologyInitializer mocks base method

func (*MockAdminOptions) TruncateRequestTimeout

func (m *MockAdminOptions) TruncateRequestTimeout() time.Duration

TruncateRequestTimeout mocks base method

func (*MockAdminOptions) Validate

func (m *MockAdminOptions) Validate() error

Validate mocks base method

func (*MockAdminOptions) WriteBatchSize

func (m *MockAdminOptions) WriteBatchSize() int

WriteBatchSize mocks base method

func (*MockAdminOptions) WriteConsistencyLevel

func (m *MockAdminOptions) WriteConsistencyLevel() topology.ConsistencyLevel

WriteConsistencyLevel mocks base method

func (*MockAdminOptions) WriteOpPoolSize

func (m *MockAdminOptions) WriteOpPoolSize() int

WriteOpPoolSize mocks base method

func (*MockAdminOptions) WriteRequestTimeout

func (m *MockAdminOptions) WriteRequestTimeout() time.Duration

WriteRequestTimeout mocks base method

func (*MockAdminOptions) WriteRetrier

func (m *MockAdminOptions) WriteRetrier() retry.Retrier

WriteRetrier mocks base method

func (*MockAdminOptions) WriteTaggedOpPoolSize

func (m *MockAdminOptions) WriteTaggedOpPoolSize() int

WriteTaggedOpPoolSize mocks base method

type MockAdminOptionsMockRecorder

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

MockAdminOptionsMockRecorder is the mock recorder for MockAdminOptions

func (*MockAdminOptionsMockRecorder) BackgroundConnectInterval

func (mr *MockAdminOptionsMockRecorder) BackgroundConnectInterval() *gomock.Call

BackgroundConnectInterval indicates an expected call of BackgroundConnectInterval

func (*MockAdminOptionsMockRecorder) BackgroundConnectStutter

func (mr *MockAdminOptionsMockRecorder) BackgroundConnectStutter() *gomock.Call

BackgroundConnectStutter indicates an expected call of BackgroundConnectStutter

func (*MockAdminOptionsMockRecorder) BackgroundHealthCheckFailLimit

func (mr *MockAdminOptionsMockRecorder) BackgroundHealthCheckFailLimit() *gomock.Call

BackgroundHealthCheckFailLimit indicates an expected call of BackgroundHealthCheckFailLimit

func (*MockAdminOptionsMockRecorder) BackgroundHealthCheckFailThrottleFactor

func (mr *MockAdminOptionsMockRecorder) BackgroundHealthCheckFailThrottleFactor() *gomock.Call

BackgroundHealthCheckFailThrottleFactor indicates an expected call of BackgroundHealthCheckFailThrottleFactor

func (*MockAdminOptionsMockRecorder) BackgroundHealthCheckInterval

func (mr *MockAdminOptionsMockRecorder) BackgroundHealthCheckInterval() *gomock.Call

BackgroundHealthCheckInterval indicates an expected call of BackgroundHealthCheckInterval

func (*MockAdminOptionsMockRecorder) BackgroundHealthCheckStutter

func (mr *MockAdminOptionsMockRecorder) BackgroundHealthCheckStutter() *gomock.Call

BackgroundHealthCheckStutter indicates an expected call of BackgroundHealthCheckStutter

func (*MockAdminOptionsMockRecorder) BootstrapConsistencyLevel

func (mr *MockAdminOptionsMockRecorder) BootstrapConsistencyLevel() *gomock.Call

BootstrapConsistencyLevel indicates an expected call of BootstrapConsistencyLevel

func (*MockAdminOptionsMockRecorder) ChannelOptions

func (mr *MockAdminOptionsMockRecorder) ChannelOptions() *gomock.Call

ChannelOptions indicates an expected call of ChannelOptions

func (*MockAdminOptionsMockRecorder) CheckedBytesWrapperPoolSize

func (mr *MockAdminOptionsMockRecorder) CheckedBytesWrapperPoolSize() *gomock.Call

CheckedBytesWrapperPoolSize indicates an expected call of CheckedBytesWrapperPoolSize

func (*MockAdminOptionsMockRecorder) ClockOptions

func (mr *MockAdminOptionsMockRecorder) ClockOptions() *gomock.Call

ClockOptions indicates an expected call of ClockOptions

func (*MockAdminOptionsMockRecorder) ClusterConnectConsistencyLevel

func (mr *MockAdminOptionsMockRecorder) ClusterConnectConsistencyLevel() *gomock.Call

ClusterConnectConsistencyLevel indicates an expected call of ClusterConnectConsistencyLevel

func (*MockAdminOptionsMockRecorder) ClusterConnectTimeout

func (mr *MockAdminOptionsMockRecorder) ClusterConnectTimeout() *gomock.Call

ClusterConnectTimeout indicates an expected call of ClusterConnectTimeout

func (*MockAdminOptionsMockRecorder) ContextPool

func (mr *MockAdminOptionsMockRecorder) ContextPool() *gomock.Call

ContextPool indicates an expected call of ContextPool

func (*MockAdminOptionsMockRecorder) FetchBatchOpPoolSize

func (mr *MockAdminOptionsMockRecorder) FetchBatchOpPoolSize() *gomock.Call

FetchBatchOpPoolSize indicates an expected call of FetchBatchOpPoolSize

func (*MockAdminOptionsMockRecorder) FetchBatchSize

func (mr *MockAdminOptionsMockRecorder) FetchBatchSize() *gomock.Call

FetchBatchSize indicates an expected call of FetchBatchSize

func (*MockAdminOptionsMockRecorder) FetchRequestTimeout

func (mr *MockAdminOptionsMockRecorder) FetchRequestTimeout() *gomock.Call

FetchRequestTimeout indicates an expected call of FetchRequestTimeout

func (*MockAdminOptionsMockRecorder) FetchRetrier

func (mr *MockAdminOptionsMockRecorder) FetchRetrier() *gomock.Call

FetchRetrier indicates an expected call of FetchRetrier

func (*MockAdminOptionsMockRecorder) FetchSeriesBlocksBatchConcurrency

func (mr *MockAdminOptionsMockRecorder) FetchSeriesBlocksBatchConcurrency() *gomock.Call

FetchSeriesBlocksBatchConcurrency indicates an expected call of FetchSeriesBlocksBatchConcurrency

func (*MockAdminOptionsMockRecorder) FetchSeriesBlocksBatchSize

func (mr *MockAdminOptionsMockRecorder) FetchSeriesBlocksBatchSize() *gomock.Call

FetchSeriesBlocksBatchSize indicates an expected call of FetchSeriesBlocksBatchSize

func (*MockAdminOptionsMockRecorder) FetchSeriesBlocksBatchTimeout

func (mr *MockAdminOptionsMockRecorder) FetchSeriesBlocksBatchTimeout() *gomock.Call

FetchSeriesBlocksBatchTimeout indicates an expected call of FetchSeriesBlocksBatchTimeout

func (*MockAdminOptionsMockRecorder) FetchSeriesBlocksMaxBlockRetries

func (mr *MockAdminOptionsMockRecorder) FetchSeriesBlocksMaxBlockRetries() *gomock.Call

FetchSeriesBlocksMaxBlockRetries indicates an expected call of FetchSeriesBlocksMaxBlockRetries

func (*MockAdminOptionsMockRecorder) FetchSeriesBlocksMetadataBatchTimeout

func (mr *MockAdminOptionsMockRecorder) FetchSeriesBlocksMetadataBatchTimeout() *gomock.Call

FetchSeriesBlocksMetadataBatchTimeout indicates an expected call of FetchSeriesBlocksMetadataBatchTimeout

func (*MockAdminOptionsMockRecorder) HostConnectTimeout

func (mr *MockAdminOptionsMockRecorder) HostConnectTimeout() *gomock.Call

HostConnectTimeout indicates an expected call of HostConnectTimeout

func (*MockAdminOptionsMockRecorder) HostQueueOpsArrayPoolSize

func (mr *MockAdminOptionsMockRecorder) HostQueueOpsArrayPoolSize() *gomock.Call

HostQueueOpsArrayPoolSize indicates an expected call of HostQueueOpsArrayPoolSize

func (*MockAdminOptionsMockRecorder) HostQueueOpsFlushInterval

func (mr *MockAdminOptionsMockRecorder) HostQueueOpsFlushInterval() *gomock.Call

HostQueueOpsFlushInterval indicates an expected call of HostQueueOpsFlushInterval

func (*MockAdminOptionsMockRecorder) HostQueueOpsFlushSize

func (mr *MockAdminOptionsMockRecorder) HostQueueOpsFlushSize() *gomock.Call

HostQueueOpsFlushSize indicates an expected call of HostQueueOpsFlushSize

func (*MockAdminOptionsMockRecorder) IdentifierPool

func (mr *MockAdminOptionsMockRecorder) IdentifierPool() *gomock.Call

IdentifierPool indicates an expected call of IdentifierPool

func (*MockAdminOptionsMockRecorder) InstrumentOptions

func (mr *MockAdminOptionsMockRecorder) InstrumentOptions() *gomock.Call

InstrumentOptions indicates an expected call of InstrumentOptions

func (*MockAdminOptionsMockRecorder) MaxConnectionCount

func (mr *MockAdminOptionsMockRecorder) MaxConnectionCount() *gomock.Call

MaxConnectionCount indicates an expected call of MaxConnectionCount

func (*MockAdminOptionsMockRecorder) MinConnectionCount

func (mr *MockAdminOptionsMockRecorder) MinConnectionCount() *gomock.Call

MinConnectionCount indicates an expected call of MinConnectionCount

func (*MockAdminOptionsMockRecorder) Origin

Origin indicates an expected call of Origin

func (*MockAdminOptionsMockRecorder) ReadConsistencyLevel

func (mr *MockAdminOptionsMockRecorder) ReadConsistencyLevel() *gomock.Call

ReadConsistencyLevel indicates an expected call of ReadConsistencyLevel

func (*MockAdminOptionsMockRecorder) ReaderIteratorAllocate

func (mr *MockAdminOptionsMockRecorder) ReaderIteratorAllocate() *gomock.Call

ReaderIteratorAllocate indicates an expected call of ReaderIteratorAllocate

func (*MockAdminOptionsMockRecorder) RuntimeOptionsManager

func (mr *MockAdminOptionsMockRecorder) RuntimeOptionsManager() *gomock.Call

RuntimeOptionsManager indicates an expected call of RuntimeOptionsManager

func (*MockAdminOptionsMockRecorder) SeriesIteratorArrayPoolBuckets

func (mr *MockAdminOptionsMockRecorder) SeriesIteratorArrayPoolBuckets() *gomock.Call

SeriesIteratorArrayPoolBuckets indicates an expected call of SeriesIteratorArrayPoolBuckets

func (*MockAdminOptionsMockRecorder) SeriesIteratorPoolSize

func (mr *MockAdminOptionsMockRecorder) SeriesIteratorPoolSize() *gomock.Call

SeriesIteratorPoolSize indicates an expected call of SeriesIteratorPoolSize

func (*MockAdminOptionsMockRecorder) SetBackgroundConnectInterval

func (mr *MockAdminOptionsMockRecorder) SetBackgroundConnectInterval(value interface{}) *gomock.Call

SetBackgroundConnectInterval indicates an expected call of SetBackgroundConnectInterval

func (*MockAdminOptionsMockRecorder) SetBackgroundConnectStutter

func (mr *MockAdminOptionsMockRecorder) SetBackgroundConnectStutter(value interface{}) *gomock.Call

SetBackgroundConnectStutter indicates an expected call of SetBackgroundConnectStutter

func (*MockAdminOptionsMockRecorder) SetBackgroundHealthCheckFailLimit

func (mr *MockAdminOptionsMockRecorder) SetBackgroundHealthCheckFailLimit(value interface{}) *gomock.Call

SetBackgroundHealthCheckFailLimit indicates an expected call of SetBackgroundHealthCheckFailLimit

func (*MockAdminOptionsMockRecorder) SetBackgroundHealthCheckFailThrottleFactor

func (mr *MockAdminOptionsMockRecorder) SetBackgroundHealthCheckFailThrottleFactor(value interface{}) *gomock.Call

SetBackgroundHealthCheckFailThrottleFactor indicates an expected call of SetBackgroundHealthCheckFailThrottleFactor

func (*MockAdminOptionsMockRecorder) SetBackgroundHealthCheckInterval

func (mr *MockAdminOptionsMockRecorder) SetBackgroundHealthCheckInterval(value interface{}) *gomock.Call

SetBackgroundHealthCheckInterval indicates an expected call of SetBackgroundHealthCheckInterval

func (*MockAdminOptionsMockRecorder) SetBackgroundHealthCheckStutter

func (mr *MockAdminOptionsMockRecorder) SetBackgroundHealthCheckStutter(value interface{}) *gomock.Call

SetBackgroundHealthCheckStutter indicates an expected call of SetBackgroundHealthCheckStutter

func (*MockAdminOptionsMockRecorder) SetBootstrapConsistencyLevel

func (mr *MockAdminOptionsMockRecorder) SetBootstrapConsistencyLevel(value interface{}) *gomock.Call

SetBootstrapConsistencyLevel indicates an expected call of SetBootstrapConsistencyLevel

func (*MockAdminOptionsMockRecorder) SetChannelOptions

func (mr *MockAdminOptionsMockRecorder) SetChannelOptions(value interface{}) *gomock.Call

SetChannelOptions indicates an expected call of SetChannelOptions

func (*MockAdminOptionsMockRecorder) SetCheckedBytesWrapperPoolSize

func (mr *MockAdminOptionsMockRecorder) SetCheckedBytesWrapperPoolSize(value interface{}) *gomock.Call

SetCheckedBytesWrapperPoolSize indicates an expected call of SetCheckedBytesWrapperPoolSize

func (*MockAdminOptionsMockRecorder) SetClockOptions

func (mr *MockAdminOptionsMockRecorder) SetClockOptions(value interface{}) *gomock.Call

SetClockOptions indicates an expected call of SetClockOptions

func (*MockAdminOptionsMockRecorder) SetClusterConnectConsistencyLevel

func (mr *MockAdminOptionsMockRecorder) SetClusterConnectConsistencyLevel(value interface{}) *gomock.Call

SetClusterConnectConsistencyLevel indicates an expected call of SetClusterConnectConsistencyLevel

func (*MockAdminOptionsMockRecorder) SetClusterConnectTimeout

func (mr *MockAdminOptionsMockRecorder) SetClusterConnectTimeout(value interface{}) *gomock.Call

SetClusterConnectTimeout indicates an expected call of SetClusterConnectTimeout

func (*MockAdminOptionsMockRecorder) SetContextPool

func (mr *MockAdminOptionsMockRecorder) SetContextPool(value interface{}) *gomock.Call

SetContextPool indicates an expected call of SetContextPool

func (*MockAdminOptionsMockRecorder) SetEncodingM3TSZ

func (mr *MockAdminOptionsMockRecorder) SetEncodingM3TSZ() *gomock.Call

SetEncodingM3TSZ indicates an expected call of SetEncodingM3TSZ

func (*MockAdminOptionsMockRecorder) SetFetchBatchOpPoolSize

func (mr *MockAdminOptionsMockRecorder) SetFetchBatchOpPoolSize(value interface{}) *gomock.Call

SetFetchBatchOpPoolSize indicates an expected call of SetFetchBatchOpPoolSize

func (*MockAdminOptionsMockRecorder) SetFetchBatchSize

func (mr *MockAdminOptionsMockRecorder) SetFetchBatchSize(value interface{}) *gomock.Call

SetFetchBatchSize indicates an expected call of SetFetchBatchSize

func (*MockAdminOptionsMockRecorder) SetFetchRequestTimeout

func (mr *MockAdminOptionsMockRecorder) SetFetchRequestTimeout(value interface{}) *gomock.Call

SetFetchRequestTimeout indicates an expected call of SetFetchRequestTimeout

func (*MockAdminOptionsMockRecorder) SetFetchRetrier

func (mr *MockAdminOptionsMockRecorder) SetFetchRetrier(value interface{}) *gomock.Call

SetFetchRetrier indicates an expected call of SetFetchRetrier

func (*MockAdminOptionsMockRecorder) SetFetchSeriesBlocksBatchConcurrency

func (mr *MockAdminOptionsMockRecorder) SetFetchSeriesBlocksBatchConcurrency(value interface{}) *gomock.Call

SetFetchSeriesBlocksBatchConcurrency indicates an expected call of SetFetchSeriesBlocksBatchConcurrency

func (*MockAdminOptionsMockRecorder) SetFetchSeriesBlocksBatchSize

func (mr *MockAdminOptionsMockRecorder) SetFetchSeriesBlocksBatchSize(value interface{}) *gomock.Call

SetFetchSeriesBlocksBatchSize indicates an expected call of SetFetchSeriesBlocksBatchSize

func (*MockAdminOptionsMockRecorder) SetFetchSeriesBlocksBatchTimeout

func (mr *MockAdminOptionsMockRecorder) SetFetchSeriesBlocksBatchTimeout(value interface{}) *gomock.Call

SetFetchSeriesBlocksBatchTimeout indicates an expected call of SetFetchSeriesBlocksBatchTimeout

func (*MockAdminOptionsMockRecorder) SetFetchSeriesBlocksMaxBlockRetries

func (mr *MockAdminOptionsMockRecorder) SetFetchSeriesBlocksMaxBlockRetries(value interface{}) *gomock.Call

SetFetchSeriesBlocksMaxBlockRetries indicates an expected call of SetFetchSeriesBlocksMaxBlockRetries

func (*MockAdminOptionsMockRecorder) SetFetchSeriesBlocksMetadataBatchTimeout

func (mr *MockAdminOptionsMockRecorder) SetFetchSeriesBlocksMetadataBatchTimeout(value interface{}) *gomock.Call

SetFetchSeriesBlocksMetadataBatchTimeout indicates an expected call of SetFetchSeriesBlocksMetadataBatchTimeout

func (*MockAdminOptionsMockRecorder) SetHostConnectTimeout

func (mr *MockAdminOptionsMockRecorder) SetHostConnectTimeout(value interface{}) *gomock.Call

SetHostConnectTimeout indicates an expected call of SetHostConnectTimeout

func (*MockAdminOptionsMockRecorder) SetHostQueueOpsArrayPoolSize

func (mr *MockAdminOptionsMockRecorder) SetHostQueueOpsArrayPoolSize(value interface{}) *gomock.Call

SetHostQueueOpsArrayPoolSize indicates an expected call of SetHostQueueOpsArrayPoolSize

func (*MockAdminOptionsMockRecorder) SetHostQueueOpsFlushInterval

func (mr *MockAdminOptionsMockRecorder) SetHostQueueOpsFlushInterval(value interface{}) *gomock.Call

SetHostQueueOpsFlushInterval indicates an expected call of SetHostQueueOpsFlushInterval

func (*MockAdminOptionsMockRecorder) SetHostQueueOpsFlushSize

func (mr *MockAdminOptionsMockRecorder) SetHostQueueOpsFlushSize(value interface{}) *gomock.Call

SetHostQueueOpsFlushSize indicates an expected call of SetHostQueueOpsFlushSize

func (*MockAdminOptionsMockRecorder) SetIdentifierPool

func (mr *MockAdminOptionsMockRecorder) SetIdentifierPool(value interface{}) *gomock.Call

SetIdentifierPool indicates an expected call of SetIdentifierPool

func (*MockAdminOptionsMockRecorder) SetInstrumentOptions

func (mr *MockAdminOptionsMockRecorder) SetInstrumentOptions(value interface{}) *gomock.Call

SetInstrumentOptions indicates an expected call of SetInstrumentOptions

func (*MockAdminOptionsMockRecorder) SetMaxConnectionCount

func (mr *MockAdminOptionsMockRecorder) SetMaxConnectionCount(value interface{}) *gomock.Call

SetMaxConnectionCount indicates an expected call of SetMaxConnectionCount

func (*MockAdminOptionsMockRecorder) SetMinConnectionCount

func (mr *MockAdminOptionsMockRecorder) SetMinConnectionCount(value interface{}) *gomock.Call

SetMinConnectionCount indicates an expected call of SetMinConnectionCount

func (*MockAdminOptionsMockRecorder) SetOrigin

func (mr *MockAdminOptionsMockRecorder) SetOrigin(value interface{}) *gomock.Call

SetOrigin indicates an expected call of SetOrigin

func (*MockAdminOptionsMockRecorder) SetReadConsistencyLevel

func (mr *MockAdminOptionsMockRecorder) SetReadConsistencyLevel(value interface{}) *gomock.Call

SetReadConsistencyLevel indicates an expected call of SetReadConsistencyLevel

func (*MockAdminOptionsMockRecorder) SetReaderIteratorAllocate

func (mr *MockAdminOptionsMockRecorder) SetReaderIteratorAllocate(value interface{}) *gomock.Call

SetReaderIteratorAllocate indicates an expected call of SetReaderIteratorAllocate

func (*MockAdminOptionsMockRecorder) SetRuntimeOptionsManager

func (mr *MockAdminOptionsMockRecorder) SetRuntimeOptionsManager(value interface{}) *gomock.Call

SetRuntimeOptionsManager indicates an expected call of SetRuntimeOptionsManager

func (*MockAdminOptionsMockRecorder) SetSeriesIteratorArrayPoolBuckets

func (mr *MockAdminOptionsMockRecorder) SetSeriesIteratorArrayPoolBuckets(value interface{}) *gomock.Call

SetSeriesIteratorArrayPoolBuckets indicates an expected call of SetSeriesIteratorArrayPoolBuckets

func (*MockAdminOptionsMockRecorder) SetSeriesIteratorPoolSize

func (mr *MockAdminOptionsMockRecorder) SetSeriesIteratorPoolSize(value interface{}) *gomock.Call

SetSeriesIteratorPoolSize indicates an expected call of SetSeriesIteratorPoolSize

func (*MockAdminOptionsMockRecorder) SetStreamBlocksRetrier

func (mr *MockAdminOptionsMockRecorder) SetStreamBlocksRetrier(value interface{}) *gomock.Call

SetStreamBlocksRetrier indicates an expected call of SetStreamBlocksRetrier

func (*MockAdminOptionsMockRecorder) SetTagDecoderOptions

func (mr *MockAdminOptionsMockRecorder) SetTagDecoderOptions(value interface{}) *gomock.Call

SetTagDecoderOptions indicates an expected call of SetTagDecoderOptions

func (*MockAdminOptionsMockRecorder) SetTagDecoderPoolSize

func (mr *MockAdminOptionsMockRecorder) SetTagDecoderPoolSize(value interface{}) *gomock.Call

SetTagDecoderPoolSize indicates an expected call of SetTagDecoderPoolSize

func (*MockAdminOptionsMockRecorder) SetTagEncoderOptions

func (mr *MockAdminOptionsMockRecorder) SetTagEncoderOptions(value interface{}) *gomock.Call

SetTagEncoderOptions indicates an expected call of SetTagEncoderOptions

func (*MockAdminOptionsMockRecorder) SetTagEncoderPoolSize

func (mr *MockAdminOptionsMockRecorder) SetTagEncoderPoolSize(value interface{}) *gomock.Call

SetTagEncoderPoolSize indicates an expected call of SetTagEncoderPoolSize

func (*MockAdminOptionsMockRecorder) SetTopologyInitializer

func (mr *MockAdminOptionsMockRecorder) SetTopologyInitializer(value interface{}) *gomock.Call

SetTopologyInitializer indicates an expected call of SetTopologyInitializer

func (*MockAdminOptionsMockRecorder) SetTruncateRequestTimeout

func (mr *MockAdminOptionsMockRecorder) SetTruncateRequestTimeout(value interface{}) *gomock.Call

SetTruncateRequestTimeout indicates an expected call of SetTruncateRequestTimeout

func (*MockAdminOptionsMockRecorder) SetWriteBatchSize

func (mr *MockAdminOptionsMockRecorder) SetWriteBatchSize(value interface{}) *gomock.Call

SetWriteBatchSize indicates an expected call of SetWriteBatchSize

func (*MockAdminOptionsMockRecorder) SetWriteConsistencyLevel

func (mr *MockAdminOptionsMockRecorder) SetWriteConsistencyLevel(value interface{}) *gomock.Call

SetWriteConsistencyLevel indicates an expected call of SetWriteConsistencyLevel

func (*MockAdminOptionsMockRecorder) SetWriteOpPoolSize

func (mr *MockAdminOptionsMockRecorder) SetWriteOpPoolSize(value interface{}) *gomock.Call

SetWriteOpPoolSize indicates an expected call of SetWriteOpPoolSize

func (*MockAdminOptionsMockRecorder) SetWriteRequestTimeout

func (mr *MockAdminOptionsMockRecorder) SetWriteRequestTimeout(value interface{}) *gomock.Call

SetWriteRequestTimeout indicates an expected call of SetWriteRequestTimeout

func (*MockAdminOptionsMockRecorder) SetWriteRetrier

func (mr *MockAdminOptionsMockRecorder) SetWriteRetrier(value interface{}) *gomock.Call

SetWriteRetrier indicates an expected call of SetWriteRetrier

func (*MockAdminOptionsMockRecorder) SetWriteTaggedOpPoolSize

func (mr *MockAdminOptionsMockRecorder) SetWriteTaggedOpPoolSize(value interface{}) *gomock.Call

SetWriteTaggedOpPoolSize indicates an expected call of SetWriteTaggedOpPoolSize

func (*MockAdminOptionsMockRecorder) StreamBlocksRetrier

func (mr *MockAdminOptionsMockRecorder) StreamBlocksRetrier() *gomock.Call

StreamBlocksRetrier indicates an expected call of StreamBlocksRetrier

func (*MockAdminOptionsMockRecorder) TagDecoderOptions

func (mr *MockAdminOptionsMockRecorder) TagDecoderOptions() *gomock.Call

TagDecoderOptions indicates an expected call of TagDecoderOptions

func (*MockAdminOptionsMockRecorder) TagDecoderPoolSize

func (mr *MockAdminOptionsMockRecorder) TagDecoderPoolSize() *gomock.Call

TagDecoderPoolSize indicates an expected call of TagDecoderPoolSize

func (*MockAdminOptionsMockRecorder) TagEncoderOptions

func (mr *MockAdminOptionsMockRecorder) TagEncoderOptions() *gomock.Call

TagEncoderOptions indicates an expected call of TagEncoderOptions

func (*MockAdminOptionsMockRecorder) TagEncoderPoolSize

func (mr *MockAdminOptionsMockRecorder) TagEncoderPoolSize() *gomock.Call

TagEncoderPoolSize indicates an expected call of TagEncoderPoolSize

func (*MockAdminOptionsMockRecorder) TopologyInitializer

func (mr *MockAdminOptionsMockRecorder) TopologyInitializer() *gomock.Call

TopologyInitializer indicates an expected call of TopologyInitializer

func (*MockAdminOptionsMockRecorder) TruncateRequestTimeout

func (mr *MockAdminOptionsMockRecorder) TruncateRequestTimeout() *gomock.Call

TruncateRequestTimeout indicates an expected call of TruncateRequestTimeout

func (*MockAdminOptionsMockRecorder) Validate

func (mr *MockAdminOptionsMockRecorder) Validate() *gomock.Call

Validate indicates an expected call of Validate

func (*MockAdminOptionsMockRecorder) WriteBatchSize

func (mr *MockAdminOptionsMockRecorder) WriteBatchSize() *gomock.Call

WriteBatchSize indicates an expected call of WriteBatchSize

func (*MockAdminOptionsMockRecorder) WriteConsistencyLevel

func (mr *MockAdminOptionsMockRecorder) WriteConsistencyLevel() *gomock.Call

WriteConsistencyLevel indicates an expected call of WriteConsistencyLevel

func (*MockAdminOptionsMockRecorder) WriteOpPoolSize

func (mr *MockAdminOptionsMockRecorder) WriteOpPoolSize() *gomock.Call

WriteOpPoolSize indicates an expected call of WriteOpPoolSize

func (*MockAdminOptionsMockRecorder) WriteRequestTimeout

func (mr *MockAdminOptionsMockRecorder) WriteRequestTimeout() *gomock.Call

WriteRequestTimeout indicates an expected call of WriteRequestTimeout

func (*MockAdminOptionsMockRecorder) WriteRetrier

func (mr *MockAdminOptionsMockRecorder) WriteRetrier() *gomock.Call

WriteRetrier indicates an expected call of WriteRetrier

func (*MockAdminOptionsMockRecorder) WriteTaggedOpPoolSize

func (mr *MockAdminOptionsMockRecorder) WriteTaggedOpPoolSize() *gomock.Call

WriteTaggedOpPoolSize indicates an expected call of WriteTaggedOpPoolSize

type MockAdminSession

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

MockAdminSession is a mock of AdminSession interface

func NewMockAdminSession

func NewMockAdminSession(ctrl *gomock.Controller) *MockAdminSession

NewMockAdminSession creates a new mock instance

func (*MockAdminSession) Close

func (m *MockAdminSession) Close() error

Close mocks base method

func (*MockAdminSession) EXPECT

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

func (*MockAdminSession) Fetch

func (m *MockAdminSession) Fetch(namespace, id ident.ID, startInclusive, endExclusive time.Time) (encoding.SeriesIterator, error)

Fetch mocks base method

func (*MockAdminSession) FetchBlocksFromPeers

func (m *MockAdminSession) FetchBlocksFromPeers(namespace namespace.Metadata, shard uint32, consistencyLevel topology.ReadConsistencyLevel, metadatas []block.ReplicaMetadata, opts result.Options) (PeerBlocksIter, error)

FetchBlocksFromPeers mocks base method

func (*MockAdminSession) FetchBlocksMetadataFromPeers

func (m *MockAdminSession) FetchBlocksMetadataFromPeers(namespace ident.ID, shard uint32, start, end time.Time, consistencyLevel topology.ReadConsistencyLevel, result result.Options, version FetchBlocksMetadataEndpointVersion) (PeerBlockMetadataIter, error)

FetchBlocksMetadataFromPeers mocks base method

func (*MockAdminSession) FetchBootstrapBlocksFromPeers

func (m *MockAdminSession) FetchBootstrapBlocksFromPeers(namespace namespace.Metadata, shard uint32, start, end time.Time, opts result.Options, version FetchBlocksMetadataEndpointVersion) (result.ShardResult, error)

FetchBootstrapBlocksFromPeers mocks base method

func (*MockAdminSession) FetchBootstrapBlocksMetadataFromPeers

func (m *MockAdminSession) FetchBootstrapBlocksMetadataFromPeers(namespace ident.ID, shard uint32, start, end time.Time, result result.Options, version FetchBlocksMetadataEndpointVersion) (PeerBlockMetadataIter, error)

FetchBootstrapBlocksMetadataFromPeers mocks base method

func (*MockAdminSession) FetchIDs

func (m *MockAdminSession) FetchIDs(namespace ident.ID, ids ident.Iterator, startInclusive, endExclusive time.Time) (encoding.SeriesIterators, error)

FetchIDs mocks base method

func (*MockAdminSession) FetchTagged

func (m *MockAdminSession) FetchTagged(namespace ident.ID, q index.Query, opts index.QueryOptions) (encoding.SeriesIterators, bool, error)

FetchTagged mocks base method

func (*MockAdminSession) FetchTaggedIDs

func (m *MockAdminSession) FetchTaggedIDs(namespace ident.ID, q index.Query, opts index.QueryOptions) (TaggedIDsIterator, bool, error)

FetchTaggedIDs mocks base method

func (*MockAdminSession) IteratorPools

func (m *MockAdminSession) IteratorPools() (encoding.IteratorPools, error)

IteratorPools mocks base method

func (*MockAdminSession) Origin

func (m *MockAdminSession) Origin() topology.Host

Origin mocks base method

func (*MockAdminSession) Replicas

func (m *MockAdminSession) Replicas() int

Replicas mocks base method

func (*MockAdminSession) ShardID

func (m *MockAdminSession) ShardID(id ident.ID) (uint32, error)

ShardID mocks base method

func (*MockAdminSession) TopologyMap added in v0.3.0

func (m *MockAdminSession) TopologyMap() (topology.Map, error)

TopologyMap mocks base method

func (*MockAdminSession) Truncate

func (m *MockAdminSession) Truncate(namespace ident.ID) (int64, error)

Truncate mocks base method

func (*MockAdminSession) Write

func (m *MockAdminSession) Write(namespace, id ident.ID, t time.Time, value float64, unit time0.Unit, annotation []byte) error

Write mocks base method

func (*MockAdminSession) WriteTagged

func (m *MockAdminSession) WriteTagged(namespace, id ident.ID, tags ident.TagIterator, t time.Time, value float64, unit time0.Unit, annotation []byte) error

WriteTagged mocks base method

type MockAdminSessionMockRecorder

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

MockAdminSessionMockRecorder is the mock recorder for MockAdminSession

func (*MockAdminSessionMockRecorder) Close

Close indicates an expected call of Close

func (*MockAdminSessionMockRecorder) Fetch

func (mr *MockAdminSessionMockRecorder) Fetch(namespace, id, startInclusive, endExclusive interface{}) *gomock.Call

Fetch indicates an expected call of Fetch

func (*MockAdminSessionMockRecorder) FetchBlocksFromPeers

func (mr *MockAdminSessionMockRecorder) FetchBlocksFromPeers(namespace, shard, consistencyLevel, metadatas, opts interface{}) *gomock.Call

FetchBlocksFromPeers indicates an expected call of FetchBlocksFromPeers

func (*MockAdminSessionMockRecorder) FetchBlocksMetadataFromPeers

func (mr *MockAdminSessionMockRecorder) FetchBlocksMetadataFromPeers(namespace, shard, start, end, consistencyLevel, result, version interface{}) *gomock.Call

FetchBlocksMetadataFromPeers indicates an expected call of FetchBlocksMetadataFromPeers

func (*MockAdminSessionMockRecorder) FetchBootstrapBlocksFromPeers

func (mr *MockAdminSessionMockRecorder) FetchBootstrapBlocksFromPeers(namespace, shard, start, end, opts, version interface{}) *gomock.Call

FetchBootstrapBlocksFromPeers indicates an expected call of FetchBootstrapBlocksFromPeers

func (*MockAdminSessionMockRecorder) FetchBootstrapBlocksMetadataFromPeers

func (mr *MockAdminSessionMockRecorder) FetchBootstrapBlocksMetadataFromPeers(namespace, shard, start, end, result, version interface{}) *gomock.Call

FetchBootstrapBlocksMetadataFromPeers indicates an expected call of FetchBootstrapBlocksMetadataFromPeers

func (*MockAdminSessionMockRecorder) FetchIDs

func (mr *MockAdminSessionMockRecorder) FetchIDs(namespace, ids, startInclusive, endExclusive interface{}) *gomock.Call

FetchIDs indicates an expected call of FetchIDs

func (*MockAdminSessionMockRecorder) FetchTagged

func (mr *MockAdminSessionMockRecorder) FetchTagged(namespace, q, opts interface{}) *gomock.Call

FetchTagged indicates an expected call of FetchTagged

func (*MockAdminSessionMockRecorder) FetchTaggedIDs

func (mr *MockAdminSessionMockRecorder) FetchTaggedIDs(namespace, q, opts interface{}) *gomock.Call

FetchTaggedIDs indicates an expected call of FetchTaggedIDs

func (*MockAdminSessionMockRecorder) IteratorPools

func (mr *MockAdminSessionMockRecorder) IteratorPools() *gomock.Call

IteratorPools indicates an expected call of IteratorPools

func (*MockAdminSessionMockRecorder) Origin

Origin indicates an expected call of Origin

func (*MockAdminSessionMockRecorder) Replicas

func (mr *MockAdminSessionMockRecorder) Replicas() *gomock.Call

Replicas indicates an expected call of Replicas

func (*MockAdminSessionMockRecorder) ShardID

func (mr *MockAdminSessionMockRecorder) ShardID(id interface{}) *gomock.Call

ShardID indicates an expected call of ShardID

func (*MockAdminSessionMockRecorder) TopologyMap added in v0.3.0

func (mr *MockAdminSessionMockRecorder) TopologyMap() *gomock.Call

TopologyMap indicates an expected call of TopologyMap

func (*MockAdminSessionMockRecorder) Truncate

func (mr *MockAdminSessionMockRecorder) Truncate(namespace interface{}) *gomock.Call

Truncate indicates an expected call of Truncate

func (*MockAdminSessionMockRecorder) Write

func (mr *MockAdminSessionMockRecorder) Write(namespace, id, t, value, unit, annotation interface{}) *gomock.Call

Write indicates an expected call of Write

func (*MockAdminSessionMockRecorder) WriteTagged

func (mr *MockAdminSessionMockRecorder) WriteTagged(namespace, id, tags, t, value, unit, annotation interface{}) *gomock.Call

WriteTagged indicates an expected call of WriteTagged

type MockClient

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

MockClient is a mock of Client interface

func NewMockClient

func NewMockClient(ctrl *gomock.Controller) *MockClient

NewMockClient creates a new mock instance

func (*MockClient) DefaultSession

func (m *MockClient) DefaultSession() (Session, error)

DefaultSession mocks base method

func (*MockClient) DefaultSessionActive

func (m *MockClient) DefaultSessionActive() bool

DefaultSessionActive mocks base method

func (*MockClient) EXPECT

func (m *MockClient) EXPECT() *MockClientMockRecorder

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

func (*MockClient) NewSession

func (m *MockClient) NewSession() (Session, error)

NewSession mocks base method

func (*MockClient) Options

func (m *MockClient) Options() Options

Options mocks base method

type MockClientMockRecorder

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

MockClientMockRecorder is the mock recorder for MockClient

func (*MockClientMockRecorder) DefaultSession

func (mr *MockClientMockRecorder) DefaultSession() *gomock.Call

DefaultSession indicates an expected call of DefaultSession

func (*MockClientMockRecorder) DefaultSessionActive

func (mr *MockClientMockRecorder) DefaultSessionActive() *gomock.Call

DefaultSessionActive indicates an expected call of DefaultSessionActive

func (*MockClientMockRecorder) NewSession

func (mr *MockClientMockRecorder) NewSession() *gomock.Call

NewSession indicates an expected call of NewSession

func (*MockClientMockRecorder) Options

func (mr *MockClientMockRecorder) Options() *gomock.Call

Options indicates an expected call of Options

type MockOptions

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

MockOptions is a mock of Options interface

func NewMockOptions

func NewMockOptions(ctrl *gomock.Controller) *MockOptions

NewMockOptions creates a new mock instance

func (*MockOptions) BackgroundConnectInterval

func (m *MockOptions) BackgroundConnectInterval() time.Duration

BackgroundConnectInterval mocks base method

func (*MockOptions) BackgroundConnectStutter

func (m *MockOptions) BackgroundConnectStutter() time.Duration

BackgroundConnectStutter mocks base method

func (*MockOptions) BackgroundHealthCheckFailLimit

func (m *MockOptions) BackgroundHealthCheckFailLimit() int

BackgroundHealthCheckFailLimit mocks base method

func (*MockOptions) BackgroundHealthCheckFailThrottleFactor

func (m *MockOptions) BackgroundHealthCheckFailThrottleFactor() float64

BackgroundHealthCheckFailThrottleFactor mocks base method

func (*MockOptions) BackgroundHealthCheckInterval

func (m *MockOptions) BackgroundHealthCheckInterval() time.Duration

BackgroundHealthCheckInterval mocks base method

func (*MockOptions) BackgroundHealthCheckStutter

func (m *MockOptions) BackgroundHealthCheckStutter() time.Duration

BackgroundHealthCheckStutter mocks base method

func (*MockOptions) ChannelOptions

func (m *MockOptions) ChannelOptions() *tchannel_go.ChannelOptions

ChannelOptions mocks base method

func (*MockOptions) CheckedBytesWrapperPoolSize

func (m *MockOptions) CheckedBytesWrapperPoolSize() int

CheckedBytesWrapperPoolSize mocks base method

func (*MockOptions) ClockOptions

func (m *MockOptions) ClockOptions() clock.Options

ClockOptions mocks base method

func (*MockOptions) ClusterConnectConsistencyLevel

func (m *MockOptions) ClusterConnectConsistencyLevel() topology.ConnectConsistencyLevel

ClusterConnectConsistencyLevel mocks base method

func (*MockOptions) ClusterConnectTimeout

func (m *MockOptions) ClusterConnectTimeout() time.Duration

ClusterConnectTimeout mocks base method

func (*MockOptions) ContextPool

func (m *MockOptions) ContextPool() context.Pool

ContextPool mocks base method

func (*MockOptions) EXPECT

func (m *MockOptions) EXPECT() *MockOptionsMockRecorder

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

func (*MockOptions) FetchBatchOpPoolSize

func (m *MockOptions) FetchBatchOpPoolSize() int

FetchBatchOpPoolSize mocks base method

func (*MockOptions) FetchBatchSize

func (m *MockOptions) FetchBatchSize() int

FetchBatchSize mocks base method

func (*MockOptions) FetchRequestTimeout

func (m *MockOptions) FetchRequestTimeout() time.Duration

FetchRequestTimeout mocks base method

func (*MockOptions) FetchRetrier

func (m *MockOptions) FetchRetrier() retry.Retrier

FetchRetrier mocks base method

func (*MockOptions) HostConnectTimeout

func (m *MockOptions) HostConnectTimeout() time.Duration

HostConnectTimeout mocks base method

func (*MockOptions) HostQueueOpsArrayPoolSize

func (m *MockOptions) HostQueueOpsArrayPoolSize() int

HostQueueOpsArrayPoolSize mocks base method

func (*MockOptions) HostQueueOpsFlushInterval

func (m *MockOptions) HostQueueOpsFlushInterval() time.Duration

HostQueueOpsFlushInterval mocks base method

func (*MockOptions) HostQueueOpsFlushSize

func (m *MockOptions) HostQueueOpsFlushSize() int

HostQueueOpsFlushSize mocks base method

func (*MockOptions) IdentifierPool

func (m *MockOptions) IdentifierPool() ident.Pool

IdentifierPool mocks base method

func (*MockOptions) InstrumentOptions

func (m *MockOptions) InstrumentOptions() instrument.Options

InstrumentOptions mocks base method

func (*MockOptions) MaxConnectionCount

func (m *MockOptions) MaxConnectionCount() int

MaxConnectionCount mocks base method

func (*MockOptions) MinConnectionCount

func (m *MockOptions) MinConnectionCount() int

MinConnectionCount mocks base method

func (*MockOptions) ReadConsistencyLevel

func (m *MockOptions) ReadConsistencyLevel() topology.ReadConsistencyLevel

ReadConsistencyLevel mocks base method

func (*MockOptions) ReaderIteratorAllocate

func (m *MockOptions) ReaderIteratorAllocate() encoding.ReaderIteratorAllocate

ReaderIteratorAllocate mocks base method

func (*MockOptions) RuntimeOptionsManager

func (m *MockOptions) RuntimeOptionsManager() runtime.OptionsManager

RuntimeOptionsManager mocks base method

func (*MockOptions) SeriesIteratorArrayPoolBuckets

func (m *MockOptions) SeriesIteratorArrayPoolBuckets() []pool.Bucket

SeriesIteratorArrayPoolBuckets mocks base method

func (*MockOptions) SeriesIteratorPoolSize

func (m *MockOptions) SeriesIteratorPoolSize() int

SeriesIteratorPoolSize mocks base method

func (*MockOptions) SetBackgroundConnectInterval

func (m *MockOptions) SetBackgroundConnectInterval(value time.Duration) Options

SetBackgroundConnectInterval mocks base method

func (*MockOptions) SetBackgroundConnectStutter

func (m *MockOptions) SetBackgroundConnectStutter(value time.Duration) Options

SetBackgroundConnectStutter mocks base method

func (*MockOptions) SetBackgroundHealthCheckFailLimit

func (m *MockOptions) SetBackgroundHealthCheckFailLimit(value int) Options

SetBackgroundHealthCheckFailLimit mocks base method

func (*MockOptions) SetBackgroundHealthCheckFailThrottleFactor

func (m *MockOptions) SetBackgroundHealthCheckFailThrottleFactor(value float64) Options

SetBackgroundHealthCheckFailThrottleFactor mocks base method

func (*MockOptions) SetBackgroundHealthCheckInterval

func (m *MockOptions) SetBackgroundHealthCheckInterval(value time.Duration) Options

SetBackgroundHealthCheckInterval mocks base method

func (*MockOptions) SetBackgroundHealthCheckStutter

func (m *MockOptions) SetBackgroundHealthCheckStutter(value time.Duration) Options

SetBackgroundHealthCheckStutter mocks base method

func (*MockOptions) SetChannelOptions

func (m *MockOptions) SetChannelOptions(value *tchannel_go.ChannelOptions) Options

SetChannelOptions mocks base method

func (*MockOptions) SetCheckedBytesWrapperPoolSize

func (m *MockOptions) SetCheckedBytesWrapperPoolSize(value int) Options

SetCheckedBytesWrapperPoolSize mocks base method

func (*MockOptions) SetClockOptions

func (m *MockOptions) SetClockOptions(value clock.Options) Options

SetClockOptions mocks base method

func (*MockOptions) SetClusterConnectConsistencyLevel

func (m *MockOptions) SetClusterConnectConsistencyLevel(value topology.ConnectConsistencyLevel) Options

SetClusterConnectConsistencyLevel mocks base method

func (*MockOptions) SetClusterConnectTimeout

func (m *MockOptions) SetClusterConnectTimeout(value time.Duration) Options

SetClusterConnectTimeout mocks base method

func (*MockOptions) SetContextPool

func (m *MockOptions) SetContextPool(value context.Pool) Options

SetContextPool mocks base method

func (*MockOptions) SetEncodingM3TSZ

func (m *MockOptions) SetEncodingM3TSZ() Options

SetEncodingM3TSZ mocks base method

func (*MockOptions) SetFetchBatchOpPoolSize

func (m *MockOptions) SetFetchBatchOpPoolSize(value int) Options

SetFetchBatchOpPoolSize mocks base method

func (*MockOptions) SetFetchBatchSize

func (m *MockOptions) SetFetchBatchSize(value int) Options

SetFetchBatchSize mocks base method

func (*MockOptions) SetFetchRequestTimeout

func (m *MockOptions) SetFetchRequestTimeout(value time.Duration) Options

SetFetchRequestTimeout mocks base method

func (*MockOptions) SetFetchRetrier

func (m *MockOptions) SetFetchRetrier(value retry.Retrier) Options

SetFetchRetrier mocks base method

func (*MockOptions) SetHostConnectTimeout

func (m *MockOptions) SetHostConnectTimeout(value time.Duration) Options

SetHostConnectTimeout mocks base method

func (*MockOptions) SetHostQueueOpsArrayPoolSize

func (m *MockOptions) SetHostQueueOpsArrayPoolSize(value int) Options

SetHostQueueOpsArrayPoolSize mocks base method

func (*MockOptions) SetHostQueueOpsFlushInterval

func (m *MockOptions) SetHostQueueOpsFlushInterval(value time.Duration) Options

SetHostQueueOpsFlushInterval mocks base method

func (*MockOptions) SetHostQueueOpsFlushSize

func (m *MockOptions) SetHostQueueOpsFlushSize(value int) Options

SetHostQueueOpsFlushSize mocks base method

func (*MockOptions) SetIdentifierPool

func (m *MockOptions) SetIdentifierPool(value ident.Pool) Options

SetIdentifierPool mocks base method

func (*MockOptions) SetInstrumentOptions

func (m *MockOptions) SetInstrumentOptions(value instrument.Options) Options

SetInstrumentOptions mocks base method

func (*MockOptions) SetMaxConnectionCount

func (m *MockOptions) SetMaxConnectionCount(value int) Options

SetMaxConnectionCount mocks base method

func (*MockOptions) SetMinConnectionCount

func (m *MockOptions) SetMinConnectionCount(value int) Options

SetMinConnectionCount mocks base method

func (*MockOptions) SetReadConsistencyLevel

func (m *MockOptions) SetReadConsistencyLevel(value topology.ReadConsistencyLevel) Options

SetReadConsistencyLevel mocks base method

func (*MockOptions) SetReaderIteratorAllocate

func (m *MockOptions) SetReaderIteratorAllocate(value encoding.ReaderIteratorAllocate) Options

SetReaderIteratorAllocate mocks base method

func (*MockOptions) SetRuntimeOptionsManager

func (m *MockOptions) SetRuntimeOptionsManager(value runtime.OptionsManager) Options

SetRuntimeOptionsManager mocks base method

func (*MockOptions) SetSeriesIteratorArrayPoolBuckets

func (m *MockOptions) SetSeriesIteratorArrayPoolBuckets(value []pool.Bucket) Options

SetSeriesIteratorArrayPoolBuckets mocks base method

func (*MockOptions) SetSeriesIteratorPoolSize

func (m *MockOptions) SetSeriesIteratorPoolSize(value int) Options

SetSeriesIteratorPoolSize mocks base method

func (*MockOptions) SetTagDecoderOptions

func (m *MockOptions) SetTagDecoderOptions(value serialize.TagDecoderOptions) Options

SetTagDecoderOptions mocks base method

func (*MockOptions) SetTagDecoderPoolSize

func (m *MockOptions) SetTagDecoderPoolSize(value int) Options

SetTagDecoderPoolSize mocks base method

func (*MockOptions) SetTagEncoderOptions

func (m *MockOptions) SetTagEncoderOptions(value serialize.TagEncoderOptions) Options

SetTagEncoderOptions mocks base method

func (*MockOptions) SetTagEncoderPoolSize

func (m *MockOptions) SetTagEncoderPoolSize(value int) Options

SetTagEncoderPoolSize mocks base method

func (*MockOptions) SetTopologyInitializer

func (m *MockOptions) SetTopologyInitializer(value topology.Initializer) Options

SetTopologyInitializer mocks base method

func (*MockOptions) SetTruncateRequestTimeout

func (m *MockOptions) SetTruncateRequestTimeout(value time.Duration) Options

SetTruncateRequestTimeout mocks base method

func (*MockOptions) SetWriteBatchSize

func (m *MockOptions) SetWriteBatchSize(value int) Options

SetWriteBatchSize mocks base method

func (*MockOptions) SetWriteConsistencyLevel

func (m *MockOptions) SetWriteConsistencyLevel(value topology.ConsistencyLevel) Options

SetWriteConsistencyLevel mocks base method

func (*MockOptions) SetWriteOpPoolSize

func (m *MockOptions) SetWriteOpPoolSize(value int) Options

SetWriteOpPoolSize mocks base method

func (*MockOptions) SetWriteRequestTimeout

func (m *MockOptions) SetWriteRequestTimeout(value time.Duration) Options

SetWriteRequestTimeout mocks base method

func (*MockOptions) SetWriteRetrier

func (m *MockOptions) SetWriteRetrier(value retry.Retrier) Options

SetWriteRetrier mocks base method

func (*MockOptions) SetWriteTaggedOpPoolSize

func (m *MockOptions) SetWriteTaggedOpPoolSize(value int) Options

SetWriteTaggedOpPoolSize mocks base method

func (*MockOptions) TagDecoderOptions

func (m *MockOptions) TagDecoderOptions() serialize.TagDecoderOptions

TagDecoderOptions mocks base method

func (*MockOptions) TagDecoderPoolSize

func (m *MockOptions) TagDecoderPoolSize() int

TagDecoderPoolSize mocks base method

func (*MockOptions) TagEncoderOptions

func (m *MockOptions) TagEncoderOptions() serialize.TagEncoderOptions

TagEncoderOptions mocks base method

func (*MockOptions) TagEncoderPoolSize

func (m *MockOptions) TagEncoderPoolSize() int

TagEncoderPoolSize mocks base method

func (*MockOptions) TopologyInitializer

func (m *MockOptions) TopologyInitializer() topology.Initializer

TopologyInitializer mocks base method

func (*MockOptions) TruncateRequestTimeout

func (m *MockOptions) TruncateRequestTimeout() time.Duration

TruncateRequestTimeout mocks base method

func (*MockOptions) Validate

func (m *MockOptions) Validate() error

Validate mocks base method

func (*MockOptions) WriteBatchSize

func (m *MockOptions) WriteBatchSize() int

WriteBatchSize mocks base method

func (*MockOptions) WriteConsistencyLevel

func (m *MockOptions) WriteConsistencyLevel() topology.ConsistencyLevel

WriteConsistencyLevel mocks base method

func (*MockOptions) WriteOpPoolSize

func (m *MockOptions) WriteOpPoolSize() int

WriteOpPoolSize mocks base method

func (*MockOptions) WriteRequestTimeout

func (m *MockOptions) WriteRequestTimeout() time.Duration

WriteRequestTimeout mocks base method

func (*MockOptions) WriteRetrier

func (m *MockOptions) WriteRetrier() retry.Retrier

WriteRetrier mocks base method

func (*MockOptions) WriteTaggedOpPoolSize

func (m *MockOptions) WriteTaggedOpPoolSize() int

WriteTaggedOpPoolSize mocks base method

type MockOptionsMockRecorder

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

MockOptionsMockRecorder is the mock recorder for MockOptions

func (*MockOptionsMockRecorder) BackgroundConnectInterval

func (mr *MockOptionsMockRecorder) BackgroundConnectInterval() *gomock.Call

BackgroundConnectInterval indicates an expected call of BackgroundConnectInterval

func (*MockOptionsMockRecorder) BackgroundConnectStutter

func (mr *MockOptionsMockRecorder) BackgroundConnectStutter() *gomock.Call

BackgroundConnectStutter indicates an expected call of BackgroundConnectStutter

func (*MockOptionsMockRecorder) BackgroundHealthCheckFailLimit

func (mr *MockOptionsMockRecorder) BackgroundHealthCheckFailLimit() *gomock.Call

BackgroundHealthCheckFailLimit indicates an expected call of BackgroundHealthCheckFailLimit

func (*MockOptionsMockRecorder) BackgroundHealthCheckFailThrottleFactor

func (mr *MockOptionsMockRecorder) BackgroundHealthCheckFailThrottleFactor() *gomock.Call

BackgroundHealthCheckFailThrottleFactor indicates an expected call of BackgroundHealthCheckFailThrottleFactor

func (*MockOptionsMockRecorder) BackgroundHealthCheckInterval

func (mr *MockOptionsMockRecorder) BackgroundHealthCheckInterval() *gomock.Call

BackgroundHealthCheckInterval indicates an expected call of BackgroundHealthCheckInterval

func (*MockOptionsMockRecorder) BackgroundHealthCheckStutter

func (mr *MockOptionsMockRecorder) BackgroundHealthCheckStutter() *gomock.Call

BackgroundHealthCheckStutter indicates an expected call of BackgroundHealthCheckStutter

func (*MockOptionsMockRecorder) ChannelOptions

func (mr *MockOptionsMockRecorder) ChannelOptions() *gomock.Call

ChannelOptions indicates an expected call of ChannelOptions

func (*MockOptionsMockRecorder) CheckedBytesWrapperPoolSize

func (mr *MockOptionsMockRecorder) CheckedBytesWrapperPoolSize() *gomock.Call

CheckedBytesWrapperPoolSize indicates an expected call of CheckedBytesWrapperPoolSize

func (*MockOptionsMockRecorder) ClockOptions

func (mr *MockOptionsMockRecorder) ClockOptions() *gomock.Call

ClockOptions indicates an expected call of ClockOptions

func (*MockOptionsMockRecorder) ClusterConnectConsistencyLevel

func (mr *MockOptionsMockRecorder) ClusterConnectConsistencyLevel() *gomock.Call

ClusterConnectConsistencyLevel indicates an expected call of ClusterConnectConsistencyLevel

func (*MockOptionsMockRecorder) ClusterConnectTimeout

func (mr *MockOptionsMockRecorder) ClusterConnectTimeout() *gomock.Call

ClusterConnectTimeout indicates an expected call of ClusterConnectTimeout

func (*MockOptionsMockRecorder) ContextPool

func (mr *MockOptionsMockRecorder) ContextPool() *gomock.Call

ContextPool indicates an expected call of ContextPool

func (*MockOptionsMockRecorder) FetchBatchOpPoolSize

func (mr *MockOptionsMockRecorder) FetchBatchOpPoolSize() *gomock.Call

FetchBatchOpPoolSize indicates an expected call of FetchBatchOpPoolSize

func (*MockOptionsMockRecorder) FetchBatchSize

func (mr *MockOptionsMockRecorder) FetchBatchSize() *gomock.Call

FetchBatchSize indicates an expected call of FetchBatchSize

func (*MockOptionsMockRecorder) FetchRequestTimeout

func (mr *MockOptionsMockRecorder) FetchRequestTimeout() *gomock.Call

FetchRequestTimeout indicates an expected call of FetchRequestTimeout

func (*MockOptionsMockRecorder) FetchRetrier

func (mr *MockOptionsMockRecorder) FetchRetrier() *gomock.Call

FetchRetrier indicates an expected call of FetchRetrier

func (*MockOptionsMockRecorder) HostConnectTimeout

func (mr *MockOptionsMockRecorder) HostConnectTimeout() *gomock.Call

HostConnectTimeout indicates an expected call of HostConnectTimeout

func (*MockOptionsMockRecorder) HostQueueOpsArrayPoolSize

func (mr *MockOptionsMockRecorder) HostQueueOpsArrayPoolSize() *gomock.Call

HostQueueOpsArrayPoolSize indicates an expected call of HostQueueOpsArrayPoolSize

func (*MockOptionsMockRecorder) HostQueueOpsFlushInterval

func (mr *MockOptionsMockRecorder) HostQueueOpsFlushInterval() *gomock.Call

HostQueueOpsFlushInterval indicates an expected call of HostQueueOpsFlushInterval

func (*MockOptionsMockRecorder) HostQueueOpsFlushSize

func (mr *MockOptionsMockRecorder) HostQueueOpsFlushSize() *gomock.Call

HostQueueOpsFlushSize indicates an expected call of HostQueueOpsFlushSize

func (*MockOptionsMockRecorder) IdentifierPool

func (mr *MockOptionsMockRecorder) IdentifierPool() *gomock.Call

IdentifierPool indicates an expected call of IdentifierPool

func (*MockOptionsMockRecorder) InstrumentOptions

func (mr *MockOptionsMockRecorder) InstrumentOptions() *gomock.Call

InstrumentOptions indicates an expected call of InstrumentOptions

func (*MockOptionsMockRecorder) MaxConnectionCount

func (mr *MockOptionsMockRecorder) MaxConnectionCount() *gomock.Call

MaxConnectionCount indicates an expected call of MaxConnectionCount

func (*MockOptionsMockRecorder) MinConnectionCount

func (mr *MockOptionsMockRecorder) MinConnectionCount() *gomock.Call

MinConnectionCount indicates an expected call of MinConnectionCount

func (*MockOptionsMockRecorder) ReadConsistencyLevel

func (mr *MockOptionsMockRecorder) ReadConsistencyLevel() *gomock.Call

ReadConsistencyLevel indicates an expected call of ReadConsistencyLevel

func (*MockOptionsMockRecorder) ReaderIteratorAllocate

func (mr *MockOptionsMockRecorder) ReaderIteratorAllocate() *gomock.Call

ReaderIteratorAllocate indicates an expected call of ReaderIteratorAllocate

func (*MockOptionsMockRecorder) RuntimeOptionsManager

func (mr *MockOptionsMockRecorder) RuntimeOptionsManager() *gomock.Call

RuntimeOptionsManager indicates an expected call of RuntimeOptionsManager

func (*MockOptionsMockRecorder) SeriesIteratorArrayPoolBuckets

func (mr *MockOptionsMockRecorder) SeriesIteratorArrayPoolBuckets() *gomock.Call

SeriesIteratorArrayPoolBuckets indicates an expected call of SeriesIteratorArrayPoolBuckets

func (*MockOptionsMockRecorder) SeriesIteratorPoolSize

func (mr *MockOptionsMockRecorder) SeriesIteratorPoolSize() *gomock.Call

SeriesIteratorPoolSize indicates an expected call of SeriesIteratorPoolSize

func (*MockOptionsMockRecorder) SetBackgroundConnectInterval

func (mr *MockOptionsMockRecorder) SetBackgroundConnectInterval(value interface{}) *gomock.Call

SetBackgroundConnectInterval indicates an expected call of SetBackgroundConnectInterval

func (*MockOptionsMockRecorder) SetBackgroundConnectStutter

func (mr *MockOptionsMockRecorder) SetBackgroundConnectStutter(value interface{}) *gomock.Call

SetBackgroundConnectStutter indicates an expected call of SetBackgroundConnectStutter

func (*MockOptionsMockRecorder) SetBackgroundHealthCheckFailLimit

func (mr *MockOptionsMockRecorder) SetBackgroundHealthCheckFailLimit(value interface{}) *gomock.Call

SetBackgroundHealthCheckFailLimit indicates an expected call of SetBackgroundHealthCheckFailLimit

func (*MockOptionsMockRecorder) SetBackgroundHealthCheckFailThrottleFactor

func (mr *MockOptionsMockRecorder) SetBackgroundHealthCheckFailThrottleFactor(value interface{}) *gomock.Call

SetBackgroundHealthCheckFailThrottleFactor indicates an expected call of SetBackgroundHealthCheckFailThrottleFactor

func (*MockOptionsMockRecorder) SetBackgroundHealthCheckInterval

func (mr *MockOptionsMockRecorder) SetBackgroundHealthCheckInterval(value interface{}) *gomock.Call

SetBackgroundHealthCheckInterval indicates an expected call of SetBackgroundHealthCheckInterval

func (*MockOptionsMockRecorder) SetBackgroundHealthCheckStutter

func (mr *MockOptionsMockRecorder) SetBackgroundHealthCheckStutter(value interface{}) *gomock.Call

SetBackgroundHealthCheckStutter indicates an expected call of SetBackgroundHealthCheckStutter

func (*MockOptionsMockRecorder) SetChannelOptions

func (mr *MockOptionsMockRecorder) SetChannelOptions(value interface{}) *gomock.Call

SetChannelOptions indicates an expected call of SetChannelOptions

func (*MockOptionsMockRecorder) SetCheckedBytesWrapperPoolSize

func (mr *MockOptionsMockRecorder) SetCheckedBytesWrapperPoolSize(value interface{}) *gomock.Call

SetCheckedBytesWrapperPoolSize indicates an expected call of SetCheckedBytesWrapperPoolSize

func (*MockOptionsMockRecorder) SetClockOptions

func (mr *MockOptionsMockRecorder) SetClockOptions(value interface{}) *gomock.Call

SetClockOptions indicates an expected call of SetClockOptions

func (*MockOptionsMockRecorder) SetClusterConnectConsistencyLevel

func (mr *MockOptionsMockRecorder) SetClusterConnectConsistencyLevel(value interface{}) *gomock.Call

SetClusterConnectConsistencyLevel indicates an expected call of SetClusterConnectConsistencyLevel

func (*MockOptionsMockRecorder) SetClusterConnectTimeout

func (mr *MockOptionsMockRecorder) SetClusterConnectTimeout(value interface{}) *gomock.Call

SetClusterConnectTimeout indicates an expected call of SetClusterConnectTimeout

func (*MockOptionsMockRecorder) SetContextPool

func (mr *MockOptionsMockRecorder) SetContextPool(value interface{}) *gomock.Call

SetContextPool indicates an expected call of SetContextPool

func (*MockOptionsMockRecorder) SetEncodingM3TSZ

func (mr *MockOptionsMockRecorder) SetEncodingM3TSZ() *gomock.Call

SetEncodingM3TSZ indicates an expected call of SetEncodingM3TSZ

func (*MockOptionsMockRecorder) SetFetchBatchOpPoolSize

func (mr *MockOptionsMockRecorder) SetFetchBatchOpPoolSize(value interface{}) *gomock.Call

SetFetchBatchOpPoolSize indicates an expected call of SetFetchBatchOpPoolSize

func (*MockOptionsMockRecorder) SetFetchBatchSize

func (mr *MockOptionsMockRecorder) SetFetchBatchSize(value interface{}) *gomock.Call

SetFetchBatchSize indicates an expected call of SetFetchBatchSize

func (*MockOptionsMockRecorder) SetFetchRequestTimeout

func (mr *MockOptionsMockRecorder) SetFetchRequestTimeout(value interface{}) *gomock.Call

SetFetchRequestTimeout indicates an expected call of SetFetchRequestTimeout

func (*MockOptionsMockRecorder) SetFetchRetrier

func (mr *MockOptionsMockRecorder) SetFetchRetrier(value interface{}) *gomock.Call

SetFetchRetrier indicates an expected call of SetFetchRetrier

func (*MockOptionsMockRecorder) SetHostConnectTimeout

func (mr *MockOptionsMockRecorder) SetHostConnectTimeout(value interface{}) *gomock.Call

SetHostConnectTimeout indicates an expected call of SetHostConnectTimeout

func (*MockOptionsMockRecorder) SetHostQueueOpsArrayPoolSize

func (mr *MockOptionsMockRecorder) SetHostQueueOpsArrayPoolSize(value interface{}) *gomock.Call

SetHostQueueOpsArrayPoolSize indicates an expected call of SetHostQueueOpsArrayPoolSize

func (*MockOptionsMockRecorder) SetHostQueueOpsFlushInterval

func (mr *MockOptionsMockRecorder) SetHostQueueOpsFlushInterval(value interface{}) *gomock.Call

SetHostQueueOpsFlushInterval indicates an expected call of SetHostQueueOpsFlushInterval

func (*MockOptionsMockRecorder) SetHostQueueOpsFlushSize

func (mr *MockOptionsMockRecorder) SetHostQueueOpsFlushSize(value interface{}) *gomock.Call

SetHostQueueOpsFlushSize indicates an expected call of SetHostQueueOpsFlushSize

func (*MockOptionsMockRecorder) SetIdentifierPool

func (mr *MockOptionsMockRecorder) SetIdentifierPool(value interface{}) *gomock.Call

SetIdentifierPool indicates an expected call of SetIdentifierPool

func (*MockOptionsMockRecorder) SetInstrumentOptions

func (mr *MockOptionsMockRecorder) SetInstrumentOptions(value interface{}) *gomock.Call

SetInstrumentOptions indicates an expected call of SetInstrumentOptions

func (*MockOptionsMockRecorder) SetMaxConnectionCount

func (mr *MockOptionsMockRecorder) SetMaxConnectionCount(value interface{}) *gomock.Call

SetMaxConnectionCount indicates an expected call of SetMaxConnectionCount

func (*MockOptionsMockRecorder) SetMinConnectionCount

func (mr *MockOptionsMockRecorder) SetMinConnectionCount(value interface{}) *gomock.Call

SetMinConnectionCount indicates an expected call of SetMinConnectionCount

func (*MockOptionsMockRecorder) SetReadConsistencyLevel

func (mr *MockOptionsMockRecorder) SetReadConsistencyLevel(value interface{}) *gomock.Call

SetReadConsistencyLevel indicates an expected call of SetReadConsistencyLevel

func (*MockOptionsMockRecorder) SetReaderIteratorAllocate

func (mr *MockOptionsMockRecorder) SetReaderIteratorAllocate(value interface{}) *gomock.Call

SetReaderIteratorAllocate indicates an expected call of SetReaderIteratorAllocate

func (*MockOptionsMockRecorder) SetRuntimeOptionsManager

func (mr *MockOptionsMockRecorder) SetRuntimeOptionsManager(value interface{}) *gomock.Call

SetRuntimeOptionsManager indicates an expected call of SetRuntimeOptionsManager

func (*MockOptionsMockRecorder) SetSeriesIteratorArrayPoolBuckets

func (mr *MockOptionsMockRecorder) SetSeriesIteratorArrayPoolBuckets(value interface{}) *gomock.Call

SetSeriesIteratorArrayPoolBuckets indicates an expected call of SetSeriesIteratorArrayPoolBuckets

func (*MockOptionsMockRecorder) SetSeriesIteratorPoolSize

func (mr *MockOptionsMockRecorder) SetSeriesIteratorPoolSize(value interface{}) *gomock.Call

SetSeriesIteratorPoolSize indicates an expected call of SetSeriesIteratorPoolSize

func (*MockOptionsMockRecorder) SetTagDecoderOptions

func (mr *MockOptionsMockRecorder) SetTagDecoderOptions(value interface{}) *gomock.Call

SetTagDecoderOptions indicates an expected call of SetTagDecoderOptions

func (*MockOptionsMockRecorder) SetTagDecoderPoolSize

func (mr *MockOptionsMockRecorder) SetTagDecoderPoolSize(value interface{}) *gomock.Call

SetTagDecoderPoolSize indicates an expected call of SetTagDecoderPoolSize

func (*MockOptionsMockRecorder) SetTagEncoderOptions

func (mr *MockOptionsMockRecorder) SetTagEncoderOptions(value interface{}) *gomock.Call

SetTagEncoderOptions indicates an expected call of SetTagEncoderOptions

func (*MockOptionsMockRecorder) SetTagEncoderPoolSize

func (mr *MockOptionsMockRecorder) SetTagEncoderPoolSize(value interface{}) *gomock.Call

SetTagEncoderPoolSize indicates an expected call of SetTagEncoderPoolSize

func (*MockOptionsMockRecorder) SetTopologyInitializer

func (mr *MockOptionsMockRecorder) SetTopologyInitializer(value interface{}) *gomock.Call

SetTopologyInitializer indicates an expected call of SetTopologyInitializer

func (*MockOptionsMockRecorder) SetTruncateRequestTimeout

func (mr *MockOptionsMockRecorder) SetTruncateRequestTimeout(value interface{}) *gomock.Call

SetTruncateRequestTimeout indicates an expected call of SetTruncateRequestTimeout

func (*MockOptionsMockRecorder) SetWriteBatchSize

func (mr *MockOptionsMockRecorder) SetWriteBatchSize(value interface{}) *gomock.Call

SetWriteBatchSize indicates an expected call of SetWriteBatchSize

func (*MockOptionsMockRecorder) SetWriteConsistencyLevel

func (mr *MockOptionsMockRecorder) SetWriteConsistencyLevel(value interface{}) *gomock.Call

SetWriteConsistencyLevel indicates an expected call of SetWriteConsistencyLevel

func (*MockOptionsMockRecorder) SetWriteOpPoolSize

func (mr *MockOptionsMockRecorder) SetWriteOpPoolSize(value interface{}) *gomock.Call

SetWriteOpPoolSize indicates an expected call of SetWriteOpPoolSize

func (*MockOptionsMockRecorder) SetWriteRequestTimeout

func (mr *MockOptionsMockRecorder) SetWriteRequestTimeout(value interface{}) *gomock.Call

SetWriteRequestTimeout indicates an expected call of SetWriteRequestTimeout

func (*MockOptionsMockRecorder) SetWriteRetrier

func (mr *MockOptionsMockRecorder) SetWriteRetrier(value interface{}) *gomock.Call

SetWriteRetrier indicates an expected call of SetWriteRetrier

func (*MockOptionsMockRecorder) SetWriteTaggedOpPoolSize

func (mr *MockOptionsMockRecorder) SetWriteTaggedOpPoolSize(value interface{}) *gomock.Call

SetWriteTaggedOpPoolSize indicates an expected call of SetWriteTaggedOpPoolSize

func (*MockOptionsMockRecorder) TagDecoderOptions

func (mr *MockOptionsMockRecorder) TagDecoderOptions() *gomock.Call

TagDecoderOptions indicates an expected call of TagDecoderOptions

func (*MockOptionsMockRecorder) TagDecoderPoolSize

func (mr *MockOptionsMockRecorder) TagDecoderPoolSize() *gomock.Call

TagDecoderPoolSize indicates an expected call of TagDecoderPoolSize

func (*MockOptionsMockRecorder) TagEncoderOptions

func (mr *MockOptionsMockRecorder) TagEncoderOptions() *gomock.Call

TagEncoderOptions indicates an expected call of TagEncoderOptions

func (*MockOptionsMockRecorder) TagEncoderPoolSize

func (mr *MockOptionsMockRecorder) TagEncoderPoolSize() *gomock.Call

TagEncoderPoolSize indicates an expected call of TagEncoderPoolSize

func (*MockOptionsMockRecorder) TopologyInitializer

func (mr *MockOptionsMockRecorder) TopologyInitializer() *gomock.Call

TopologyInitializer indicates an expected call of TopologyInitializer

func (*MockOptionsMockRecorder) TruncateRequestTimeout

func (mr *MockOptionsMockRecorder) TruncateRequestTimeout() *gomock.Call

TruncateRequestTimeout indicates an expected call of TruncateRequestTimeout

func (*MockOptionsMockRecorder) Validate

func (mr *MockOptionsMockRecorder) Validate() *gomock.Call

Validate indicates an expected call of Validate

func (*MockOptionsMockRecorder) WriteBatchSize

func (mr *MockOptionsMockRecorder) WriteBatchSize() *gomock.Call

WriteBatchSize indicates an expected call of WriteBatchSize

func (*MockOptionsMockRecorder) WriteConsistencyLevel

func (mr *MockOptionsMockRecorder) WriteConsistencyLevel() *gomock.Call

WriteConsistencyLevel indicates an expected call of WriteConsistencyLevel

func (*MockOptionsMockRecorder) WriteOpPoolSize

func (mr *MockOptionsMockRecorder) WriteOpPoolSize() *gomock.Call

WriteOpPoolSize indicates an expected call of WriteOpPoolSize

func (*MockOptionsMockRecorder) WriteRequestTimeout

func (mr *MockOptionsMockRecorder) WriteRequestTimeout() *gomock.Call

WriteRequestTimeout indicates an expected call of WriteRequestTimeout

func (*MockOptionsMockRecorder) WriteRetrier

func (mr *MockOptionsMockRecorder) WriteRetrier() *gomock.Call

WriteRetrier indicates an expected call of WriteRetrier

func (*MockOptionsMockRecorder) WriteTaggedOpPoolSize

func (mr *MockOptionsMockRecorder) WriteTaggedOpPoolSize() *gomock.Call

WriteTaggedOpPoolSize indicates an expected call of WriteTaggedOpPoolSize

type MockPeerBlockMetadataIter

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

MockPeerBlockMetadataIter is a mock of PeerBlockMetadataIter interface

func NewMockPeerBlockMetadataIter

func NewMockPeerBlockMetadataIter(ctrl *gomock.Controller) *MockPeerBlockMetadataIter

NewMockPeerBlockMetadataIter creates a new mock instance

func (*MockPeerBlockMetadataIter) Current

Current mocks base method

func (*MockPeerBlockMetadataIter) EXPECT

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

func (*MockPeerBlockMetadataIter) Err

Err mocks base method

func (*MockPeerBlockMetadataIter) Next

func (m *MockPeerBlockMetadataIter) Next() bool

Next mocks base method

type MockPeerBlockMetadataIterMockRecorder

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

MockPeerBlockMetadataIterMockRecorder is the mock recorder for MockPeerBlockMetadataIter

func (*MockPeerBlockMetadataIterMockRecorder) Current

Current indicates an expected call of Current

func (*MockPeerBlockMetadataIterMockRecorder) Err

Err indicates an expected call of Err

func (*MockPeerBlockMetadataIterMockRecorder) Next

Next indicates an expected call of Next

type MockPeerBlocksIter

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

MockPeerBlocksIter is a mock of PeerBlocksIter interface

func NewMockPeerBlocksIter

func NewMockPeerBlocksIter(ctrl *gomock.Controller) *MockPeerBlocksIter

NewMockPeerBlocksIter creates a new mock instance

func (*MockPeerBlocksIter) Current

Current mocks base method

func (*MockPeerBlocksIter) EXPECT

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

func (*MockPeerBlocksIter) Err

func (m *MockPeerBlocksIter) Err() error

Err mocks base method

func (*MockPeerBlocksIter) Next

func (m *MockPeerBlocksIter) Next() bool

Next mocks base method

type MockPeerBlocksIterMockRecorder

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

MockPeerBlocksIterMockRecorder is the mock recorder for MockPeerBlocksIter

func (*MockPeerBlocksIterMockRecorder) Current

Current indicates an expected call of Current

func (*MockPeerBlocksIterMockRecorder) Err

Err indicates an expected call of Err

func (*MockPeerBlocksIterMockRecorder) Next

Next indicates an expected call of Next

type MockSession

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

MockSession is a mock of Session interface

func NewMockSession

func NewMockSession(ctrl *gomock.Controller) *MockSession

NewMockSession creates a new mock instance

func (*MockSession) Close

func (m *MockSession) Close() error

Close mocks base method

func (*MockSession) EXPECT

func (m *MockSession) EXPECT() *MockSessionMockRecorder

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

func (*MockSession) Fetch

func (m *MockSession) Fetch(namespace, id ident.ID, startInclusive, endExclusive time.Time) (encoding.SeriesIterator, error)

Fetch mocks base method

func (*MockSession) FetchIDs

func (m *MockSession) FetchIDs(namespace ident.ID, ids ident.Iterator, startInclusive, endExclusive time.Time) (encoding.SeriesIterators, error)

FetchIDs mocks base method

func (*MockSession) FetchTagged

func (m *MockSession) FetchTagged(namespace ident.ID, q index.Query, opts index.QueryOptions) (encoding.SeriesIterators, bool, error)

FetchTagged mocks base method

func (*MockSession) FetchTaggedIDs

func (m *MockSession) FetchTaggedIDs(namespace ident.ID, q index.Query, opts index.QueryOptions) (TaggedIDsIterator, bool, error)

FetchTaggedIDs mocks base method

func (*MockSession) IteratorPools

func (m *MockSession) IteratorPools() (encoding.IteratorPools, error)

IteratorPools mocks base method

func (*MockSession) ShardID

func (m *MockSession) ShardID(id ident.ID) (uint32, error)

ShardID mocks base method

func (*MockSession) Write

func (m *MockSession) Write(namespace, id ident.ID, t time.Time, value float64, unit time0.Unit, annotation []byte) error

Write mocks base method

func (*MockSession) WriteTagged

func (m *MockSession) WriteTagged(namespace, id ident.ID, tags ident.TagIterator, t time.Time, value float64, unit time0.Unit, annotation []byte) error

WriteTagged mocks base method

type MockSessionMockRecorder

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

MockSessionMockRecorder is the mock recorder for MockSession

func (*MockSessionMockRecorder) Close

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

Close indicates an expected call of Close

func (*MockSessionMockRecorder) Fetch

func (mr *MockSessionMockRecorder) Fetch(namespace, id, startInclusive, endExclusive interface{}) *gomock.Call

Fetch indicates an expected call of Fetch

func (*MockSessionMockRecorder) FetchIDs

func (mr *MockSessionMockRecorder) FetchIDs(namespace, ids, startInclusive, endExclusive interface{}) *gomock.Call

FetchIDs indicates an expected call of FetchIDs

func (*MockSessionMockRecorder) FetchTagged

func (mr *MockSessionMockRecorder) FetchTagged(namespace, q, opts interface{}) *gomock.Call

FetchTagged indicates an expected call of FetchTagged

func (*MockSessionMockRecorder) FetchTaggedIDs

func (mr *MockSessionMockRecorder) FetchTaggedIDs(namespace, q, opts interface{}) *gomock.Call

FetchTaggedIDs indicates an expected call of FetchTaggedIDs

func (*MockSessionMockRecorder) IteratorPools

func (mr *MockSessionMockRecorder) IteratorPools() *gomock.Call

IteratorPools indicates an expected call of IteratorPools

func (*MockSessionMockRecorder) ShardID

func (mr *MockSessionMockRecorder) ShardID(id interface{}) *gomock.Call

ShardID indicates an expected call of ShardID

func (*MockSessionMockRecorder) Write

func (mr *MockSessionMockRecorder) Write(namespace, id, t, value, unit, annotation interface{}) *gomock.Call

Write indicates an expected call of Write

func (*MockSessionMockRecorder) WriteTagged

func (mr *MockSessionMockRecorder) WriteTagged(namespace, id, tags, t, value, unit, annotation interface{}) *gomock.Call

WriteTagged indicates an expected call of WriteTagged

type MockTaggedIDsIterator

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

MockTaggedIDsIterator is a mock of TaggedIDsIterator interface

func NewMockTaggedIDsIterator

func NewMockTaggedIDsIterator(ctrl *gomock.Controller) *MockTaggedIDsIterator

NewMockTaggedIDsIterator creates a new mock instance

func (*MockTaggedIDsIterator) Current

Current mocks base method

func (*MockTaggedIDsIterator) EXPECT

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

func (*MockTaggedIDsIterator) Err

func (m *MockTaggedIDsIterator) Err() error

Err mocks base method

func (*MockTaggedIDsIterator) Finalize

func (m *MockTaggedIDsIterator) Finalize()

Finalize mocks base method

func (*MockTaggedIDsIterator) Next

func (m *MockTaggedIDsIterator) Next() bool

Next mocks base method

type MockTaggedIDsIteratorMockRecorder

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

MockTaggedIDsIteratorMockRecorder is the mock recorder for MockTaggedIDsIterator

func (*MockTaggedIDsIteratorMockRecorder) Current

Current indicates an expected call of Current

func (*MockTaggedIDsIteratorMockRecorder) Err

Err indicates an expected call of Err

func (*MockTaggedIDsIteratorMockRecorder) Finalize

Finalize indicates an expected call of Finalize

func (*MockTaggedIDsIteratorMockRecorder) Next

Next indicates an expected call of Next

type MockclientSession

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

MockclientSession is a mock of clientSession interface

func NewMockclientSession

func NewMockclientSession(ctrl *gomock.Controller) *MockclientSession

NewMockclientSession creates a new mock instance

func (*MockclientSession) Close

func (m *MockclientSession) Close() error

Close mocks base method

func (*MockclientSession) EXPECT

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

func (*MockclientSession) Fetch

func (m *MockclientSession) Fetch(namespace, id ident.ID, startInclusive, endExclusive time.Time) (encoding.SeriesIterator, error)

Fetch mocks base method

func (*MockclientSession) FetchBlocksFromPeers

func (m *MockclientSession) FetchBlocksFromPeers(namespace namespace.Metadata, shard uint32, consistencyLevel topology.ReadConsistencyLevel, metadatas []block.ReplicaMetadata, opts result.Options) (PeerBlocksIter, error)

FetchBlocksFromPeers mocks base method

func (*MockclientSession) FetchBlocksMetadataFromPeers

func (m *MockclientSession) FetchBlocksMetadataFromPeers(namespace ident.ID, shard uint32, start, end time.Time, consistencyLevel topology.ReadConsistencyLevel, result result.Options, version FetchBlocksMetadataEndpointVersion) (PeerBlockMetadataIter, error)

FetchBlocksMetadataFromPeers mocks base method

func (*MockclientSession) FetchBootstrapBlocksFromPeers

func (m *MockclientSession) FetchBootstrapBlocksFromPeers(namespace namespace.Metadata, shard uint32, start, end time.Time, opts result.Options, version FetchBlocksMetadataEndpointVersion) (result.ShardResult, error)

FetchBootstrapBlocksFromPeers mocks base method

func (*MockclientSession) FetchBootstrapBlocksMetadataFromPeers

func (m *MockclientSession) FetchBootstrapBlocksMetadataFromPeers(namespace ident.ID, shard uint32, start, end time.Time, result result.Options, version FetchBlocksMetadataEndpointVersion) (PeerBlockMetadataIter, error)

FetchBootstrapBlocksMetadataFromPeers mocks base method

func (*MockclientSession) FetchIDs

func (m *MockclientSession) FetchIDs(namespace ident.ID, ids ident.Iterator, startInclusive, endExclusive time.Time) (encoding.SeriesIterators, error)

FetchIDs mocks base method

func (*MockclientSession) FetchTagged

func (m *MockclientSession) FetchTagged(namespace ident.ID, q index.Query, opts index.QueryOptions) (encoding.SeriesIterators, bool, error)

FetchTagged mocks base method

func (*MockclientSession) FetchTaggedIDs

func (m *MockclientSession) FetchTaggedIDs(namespace ident.ID, q index.Query, opts index.QueryOptions) (TaggedIDsIterator, bool, error)

FetchTaggedIDs mocks base method

func (*MockclientSession) IteratorPools

func (m *MockclientSession) IteratorPools() (encoding.IteratorPools, error)

IteratorPools mocks base method

func (*MockclientSession) Open

func (m *MockclientSession) Open() error

Open mocks base method

func (*MockclientSession) Origin

func (m *MockclientSession) Origin() topology.Host

Origin mocks base method

func (*MockclientSession) Replicas

func (m *MockclientSession) Replicas() int

Replicas mocks base method

func (*MockclientSession) ShardID

func (m *MockclientSession) ShardID(id ident.ID) (uint32, error)

ShardID mocks base method

func (*MockclientSession) TopologyMap added in v0.3.0

func (m *MockclientSession) TopologyMap() (topology.Map, error)

TopologyMap mocks base method

func (*MockclientSession) Truncate

func (m *MockclientSession) Truncate(namespace ident.ID) (int64, error)

Truncate mocks base method

func (*MockclientSession) Write

func (m *MockclientSession) Write(namespace, id ident.ID, t time.Time, value float64, unit time0.Unit, annotation []byte) error

Write mocks base method

func (*MockclientSession) WriteTagged

func (m *MockclientSession) WriteTagged(namespace, id ident.ID, tags ident.TagIterator, t time.Time, value float64, unit time0.Unit, annotation []byte) error

WriteTagged mocks base method

type MockclientSessionMockRecorder

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

MockclientSessionMockRecorder is the mock recorder for MockclientSession

func (*MockclientSessionMockRecorder) Close

Close indicates an expected call of Close

func (*MockclientSessionMockRecorder) Fetch

func (mr *MockclientSessionMockRecorder) Fetch(namespace, id, startInclusive, endExclusive interface{}) *gomock.Call

Fetch indicates an expected call of Fetch

func (*MockclientSessionMockRecorder) FetchBlocksFromPeers

func (mr *MockclientSessionMockRecorder) FetchBlocksFromPeers(namespace, shard, consistencyLevel, metadatas, opts interface{}) *gomock.Call

FetchBlocksFromPeers indicates an expected call of FetchBlocksFromPeers

func (*MockclientSessionMockRecorder) FetchBlocksMetadataFromPeers

func (mr *MockclientSessionMockRecorder) FetchBlocksMetadataFromPeers(namespace, shard, start, end, consistencyLevel, result, version interface{}) *gomock.Call

FetchBlocksMetadataFromPeers indicates an expected call of FetchBlocksMetadataFromPeers

func (*MockclientSessionMockRecorder) FetchBootstrapBlocksFromPeers

func (mr *MockclientSessionMockRecorder) FetchBootstrapBlocksFromPeers(namespace, shard, start, end, opts, version interface{}) *gomock.Call

FetchBootstrapBlocksFromPeers indicates an expected call of FetchBootstrapBlocksFromPeers

func (*MockclientSessionMockRecorder) FetchBootstrapBlocksMetadataFromPeers

func (mr *MockclientSessionMockRecorder) FetchBootstrapBlocksMetadataFromPeers(namespace, shard, start, end, result, version interface{}) *gomock.Call

FetchBootstrapBlocksMetadataFromPeers indicates an expected call of FetchBootstrapBlocksMetadataFromPeers

func (*MockclientSessionMockRecorder) FetchIDs

func (mr *MockclientSessionMockRecorder) FetchIDs(namespace, ids, startInclusive, endExclusive interface{}) *gomock.Call

FetchIDs indicates an expected call of FetchIDs

func (*MockclientSessionMockRecorder) FetchTagged

func (mr *MockclientSessionMockRecorder) FetchTagged(namespace, q, opts interface{}) *gomock.Call

FetchTagged indicates an expected call of FetchTagged

func (*MockclientSessionMockRecorder) FetchTaggedIDs

func (mr *MockclientSessionMockRecorder) FetchTaggedIDs(namespace, q, opts interface{}) *gomock.Call

FetchTaggedIDs indicates an expected call of FetchTaggedIDs

func (*MockclientSessionMockRecorder) IteratorPools

func (mr *MockclientSessionMockRecorder) IteratorPools() *gomock.Call

IteratorPools indicates an expected call of IteratorPools

func (*MockclientSessionMockRecorder) Open

Open indicates an expected call of Open

func (*MockclientSessionMockRecorder) Origin

Origin indicates an expected call of Origin

func (*MockclientSessionMockRecorder) Replicas

func (mr *MockclientSessionMockRecorder) Replicas() *gomock.Call

Replicas indicates an expected call of Replicas

func (*MockclientSessionMockRecorder) ShardID

func (mr *MockclientSessionMockRecorder) ShardID(id interface{}) *gomock.Call

ShardID indicates an expected call of ShardID

func (*MockclientSessionMockRecorder) TopologyMap added in v0.3.0

func (mr *MockclientSessionMockRecorder) TopologyMap() *gomock.Call

TopologyMap indicates an expected call of TopologyMap

func (*MockclientSessionMockRecorder) Truncate

func (mr *MockclientSessionMockRecorder) Truncate(namespace interface{}) *gomock.Call

Truncate indicates an expected call of Truncate

func (*MockclientSessionMockRecorder) Write

func (mr *MockclientSessionMockRecorder) Write(namespace, id, t, value, unit, annotation interface{}) *gomock.Call

Write indicates an expected call of Write

func (*MockclientSessionMockRecorder) WriteTagged

func (mr *MockclientSessionMockRecorder) WriteTagged(namespace, id, tags, t, value, unit, annotation interface{}) *gomock.Call

WriteTagged indicates an expected call of WriteTagged

type MockconnectionPool

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

MockconnectionPool is a mock of connectionPool interface

func NewMockconnectionPool

func NewMockconnectionPool(ctrl *gomock.Controller) *MockconnectionPool

NewMockconnectionPool creates a new mock instance

func (*MockconnectionPool) Close

func (m *MockconnectionPool) Close()

Close mocks base method

func (*MockconnectionPool) ConnectionCount

func (m *MockconnectionPool) ConnectionCount() int

ConnectionCount mocks base method

func (*MockconnectionPool) EXPECT

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

func (*MockconnectionPool) NextClient

func (m *MockconnectionPool) NextClient() (rpc.TChanNode, error)

NextClient mocks base method

func (*MockconnectionPool) Open

func (m *MockconnectionPool) Open()

Open mocks base method

type MockconnectionPoolMockRecorder

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

MockconnectionPoolMockRecorder is the mock recorder for MockconnectionPool

func (*MockconnectionPoolMockRecorder) Close

Close indicates an expected call of Close

func (*MockconnectionPoolMockRecorder) ConnectionCount

func (mr *MockconnectionPoolMockRecorder) ConnectionCount() *gomock.Call

ConnectionCount indicates an expected call of ConnectionCount

func (*MockconnectionPoolMockRecorder) NextClient

func (mr *MockconnectionPoolMockRecorder) NextClient() *gomock.Call

NextClient indicates an expected call of NextClient

func (*MockconnectionPoolMockRecorder) Open

Open indicates an expected call of Open

type MockenqueueChannel

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

MockenqueueChannel is a mock of enqueueChannel interface

func NewMockenqueueChannel

func NewMockenqueueChannel(ctrl *gomock.Controller) *MockenqueueChannel

NewMockenqueueChannel creates a new mock instance

func (*MockenqueueChannel) EXPECT

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

type MockenqueueChannelMockRecorder

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

MockenqueueChannelMockRecorder is the mock recorder for MockenqueueChannel

type MockhostQueue

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

MockhostQueue is a mock of hostQueue interface

func NewMockhostQueue

func NewMockhostQueue(ctrl *gomock.Controller) *MockhostQueue

NewMockhostQueue creates a new mock instance

func (*MockhostQueue) BorrowConnection

func (m *MockhostQueue) BorrowConnection(fn withConnectionFn) error

BorrowConnection mocks base method

func (*MockhostQueue) Close

func (m *MockhostQueue) Close()

Close mocks base method

func (*MockhostQueue) ConnectionCount

func (m *MockhostQueue) ConnectionCount() int

ConnectionCount mocks base method

func (*MockhostQueue) ConnectionPool

func (m *MockhostQueue) ConnectionPool() connectionPool

ConnectionPool mocks base method

func (*MockhostQueue) EXPECT

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

func (*MockhostQueue) Enqueue

func (m *MockhostQueue) Enqueue(op op) error

Enqueue mocks base method

func (*MockhostQueue) Host

func (m *MockhostQueue) Host() topology.Host

Host mocks base method

func (*MockhostQueue) Len

func (m *MockhostQueue) Len() int

Len mocks base method

func (*MockhostQueue) Open

func (m *MockhostQueue) Open()

Open mocks base method

type MockhostQueueMockRecorder

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

MockhostQueueMockRecorder is the mock recorder for MockhostQueue

func (*MockhostQueueMockRecorder) BorrowConnection

func (mr *MockhostQueueMockRecorder) BorrowConnection(fn interface{}) *gomock.Call

BorrowConnection indicates an expected call of BorrowConnection

func (*MockhostQueueMockRecorder) Close

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

Close indicates an expected call of Close

func (*MockhostQueueMockRecorder) ConnectionCount

func (mr *MockhostQueueMockRecorder) ConnectionCount() *gomock.Call

ConnectionCount indicates an expected call of ConnectionCount

func (*MockhostQueueMockRecorder) ConnectionPool

func (mr *MockhostQueueMockRecorder) ConnectionPool() *gomock.Call

ConnectionPool indicates an expected call of ConnectionPool

func (*MockhostQueueMockRecorder) Enqueue

func (mr *MockhostQueueMockRecorder) Enqueue(op interface{}) *gomock.Call

Enqueue indicates an expected call of Enqueue

func (*MockhostQueueMockRecorder) Host

Host indicates an expected call of Host

func (*MockhostQueueMockRecorder) Len

Len indicates an expected call of Len

func (*MockhostQueueMockRecorder) Open

Open indicates an expected call of Open

type Mockop

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

Mockop is a mock of op interface

func NewMockop

func NewMockop(ctrl *gomock.Controller) *Mockop

NewMockop creates a new mock instance

func (*Mockop) CompletionFn

func (m *Mockop) CompletionFn() completionFn

CompletionFn mocks base method

func (*Mockop) EXPECT

func (m *Mockop) EXPECT() *MockopMockRecorder

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

func (*Mockop) Size

func (m *Mockop) Size() int

Size mocks base method

type MockopMockRecorder

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

MockopMockRecorder is the mock recorder for Mockop

func (*MockopMockRecorder) CompletionFn

func (mr *MockopMockRecorder) CompletionFn() *gomock.Call

CompletionFn indicates an expected call of CompletionFn

func (*MockopMockRecorder) Size

func (mr *MockopMockRecorder) Size() *gomock.Call

Size indicates an expected call of Size

type Mockpeer

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

Mockpeer is a mock of peer interface

func NewMockpeer

func NewMockpeer(ctrl *gomock.Controller) *Mockpeer

NewMockpeer creates a new mock instance

func (*Mockpeer) BorrowConnection

func (m *Mockpeer) BorrowConnection(fn withConnectionFn) error

BorrowConnection mocks base method

func (*Mockpeer) EXPECT

func (m *Mockpeer) EXPECT() *MockpeerMockRecorder

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

func (*Mockpeer) Host

func (m *Mockpeer) Host() topology.Host

Host mocks base method

type MockpeerMockRecorder

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

MockpeerMockRecorder is the mock recorder for Mockpeer

func (*MockpeerMockRecorder) BorrowConnection

func (mr *MockpeerMockRecorder) BorrowConnection(fn interface{}) *gomock.Call

BorrowConnection indicates an expected call of BorrowConnection

func (*MockpeerMockRecorder) Host

func (mr *MockpeerMockRecorder) Host() *gomock.Call

Host indicates an expected call of Host

type MockpeerSource

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

MockpeerSource is a mock of peerSource interface

func NewMockpeerSource

func NewMockpeerSource(ctrl *gomock.Controller) *MockpeerSource

NewMockpeerSource creates a new mock instance

func (*MockpeerSource) BorrowConnection

func (m *MockpeerSource) BorrowConnection(hostID string, fn withConnectionFn) error

BorrowConnection mocks base method

func (*MockpeerSource) EXPECT

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

type MockpeerSourceMockRecorder

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

MockpeerSourceMockRecorder is the mock recorder for MockpeerSource

func (*MockpeerSourceMockRecorder) BorrowConnection

func (mr *MockpeerSourceMockRecorder) BorrowConnection(hostID, fn interface{}) *gomock.Call

BorrowConnection indicates an expected call of BorrowConnection

type Options

type Options interface {
	// Validate validates the options
	Validate() error

	// SetEncodingM3TSZ sets m3tsz encoding
	SetEncodingM3TSZ() Options

	// SetRuntimeOptionsManager sets the runtime options manager, it is optional
	SetRuntimeOptionsManager(value runtime.OptionsManager) Options

	// RuntimeOptionsManager returns the runtime options manager, it is optional
	RuntimeOptionsManager() runtime.OptionsManager

	// SetClockOptions sets the clock options
	SetClockOptions(value clock.Options) Options

	// ClockOptions returns the clock options
	ClockOptions() clock.Options

	// SetInstrumentOptions sets the instrumentation options
	SetInstrumentOptions(value instrument.Options) Options

	// InstrumentOptions returns the instrumentation options
	InstrumentOptions() instrument.Options

	// SetTopologyInitializer sets the TopologyInitializer
	SetTopologyInitializer(value topology.Initializer) Options

	// TopologyInitializer returns the TopologyInitializer
	TopologyInitializer() topology.Initializer

	// SetReadConsistencyLevel sets the read consistency level
	SetReadConsistencyLevel(value topology.ReadConsistencyLevel) Options

	// topology.ReadConsistencyLevel returns the read consistency level
	ReadConsistencyLevel() topology.ReadConsistencyLevel

	// SetWriteConsistencyLevel sets the write consistency level
	SetWriteConsistencyLevel(value topology.ConsistencyLevel) Options

	// WriteConsistencyLevel returns the write consistency level
	WriteConsistencyLevel() topology.ConsistencyLevel

	// SetChannelOptions sets the channelOptions
	SetChannelOptions(value *tchannel.ChannelOptions) Options

	// ChannelOptions returns the channelOptions
	ChannelOptions() *tchannel.ChannelOptions

	// SetMaxConnectionCount sets the maxConnectionCount
	SetMaxConnectionCount(value int) Options

	// MaxConnectionCount returns the maxConnectionCount
	MaxConnectionCount() int

	// SetMinConnectionCount sets the minConnectionCount
	SetMinConnectionCount(value int) Options

	// MinConnectionCount returns the minConnectionCount
	MinConnectionCount() int

	// SetHostConnectTimeout sets the hostConnectTimeout
	SetHostConnectTimeout(value time.Duration) Options

	// HostConnectTimeout returns the hostConnectTimeout
	HostConnectTimeout() time.Duration

	// SetClusterConnectTimeout sets the clusterConnectTimeout
	SetClusterConnectTimeout(value time.Duration) Options

	// ClusterConnectTimeout returns the clusterConnectTimeout
	ClusterConnectTimeout() time.Duration

	// SetClusterConnectConsistencyLevel sets the clusterConnectConsistencyLevel
	SetClusterConnectConsistencyLevel(value topology.ConnectConsistencyLevel) Options

	// ClusterConnectConsistencyLevel returns the clusterConnectConsistencyLevel
	ClusterConnectConsistencyLevel() topology.ConnectConsistencyLevel

	// SetWriteRequestTimeout sets the writeRequestTimeout
	SetWriteRequestTimeout(value time.Duration) Options

	// WriteRequestTimeout returns the writeRequestTimeout
	WriteRequestTimeout() time.Duration

	// SetFetchRequestTimeout sets the fetchRequestTimeout
	SetFetchRequestTimeout(value time.Duration) Options

	// FetchRequestTimeout returns the fetchRequestTimeout
	FetchRequestTimeout() time.Duration

	// SetTruncateRequestTimeout sets the truncateRequestTimeout
	SetTruncateRequestTimeout(value time.Duration) Options

	// TruncateRequestTimeout returns the truncateRequestTimeout
	TruncateRequestTimeout() time.Duration

	// SetBackgroundConnectInterval sets the backgroundConnectInterval
	SetBackgroundConnectInterval(value time.Duration) Options

	// BackgroundConnectInterval returns the backgroundConnectInterval
	BackgroundConnectInterval() time.Duration

	// SetBackgroundConnectStutter sets the backgroundConnectStutter
	SetBackgroundConnectStutter(value time.Duration) Options

	// BackgroundConnectStutter returns the backgroundConnectStutter
	BackgroundConnectStutter() time.Duration

	// SetBackgroundHealthCheckInterval sets the background health check interval
	SetBackgroundHealthCheckInterval(value time.Duration) Options

	// BackgroundHealthCheckInterval returns the background health check interval
	BackgroundHealthCheckInterval() time.Duration

	// SetBackgroundHealthCheckStutter sets the background health check stutter
	SetBackgroundHealthCheckStutter(value time.Duration) Options

	// BackgroundHealthCheckStutter returns the background health check stutter
	BackgroundHealthCheckStutter() time.Duration

	// SetBackgroundHealthCheckFailLimit sets the background health failure
	// limit before connection is deemed unhealth
	SetBackgroundHealthCheckFailLimit(value int) Options

	// BackgroundHealthCheckFailLimit returns the background health failure
	// limit before connection is deemed unhealth
	BackgroundHealthCheckFailLimit() int

	// SetBackgroundHealthCheckFailThrottleFactor sets the throttle factor to
	// apply when calculating how long to wait between a failed health check and
	// a retry attempt. It is applied by multiplying against the host connect
	// timeout to produce a throttle sleep value.
	SetBackgroundHealthCheckFailThrottleFactor(value float64) Options

	// BackgroundHealthCheckFailThrottleFactor returns the throttle factor to
	// apply when calculating how long to wait between a failed health check and
	// a retry attempt. It is applied by multiplying against the host connect
	// timeout to produce a throttle sleep value.
	BackgroundHealthCheckFailThrottleFactor() float64

	// SetWriteRetrier sets the write retrier when performing a write for
	// a write operation. Only retryable errors are retried.
	SetWriteRetrier(value xretry.Retrier) Options

	// WriteRetrier returns the write retrier when perform a write for
	// a write operation. Only retryable errors are retried.
	WriteRetrier() xretry.Retrier

	// SetFetchRetrier sets the fetch retrier when performing a write for
	// a fetch operation. Only retryable errors are retried.
	SetFetchRetrier(value xretry.Retrier) Options

	// FetchRetrier returns the fetch retrier when performing a fetch for
	// a fetch operation. Only retryable errors are retried.
	FetchRetrier() xretry.Retrier

	// SetTagEncoderOptions sets the TagEncoderOptions.
	SetTagEncoderOptions(value serialize.TagEncoderOptions) Options

	// TagEncoderOptions returns the TagEncoderOptions.
	TagEncoderOptions() serialize.TagEncoderOptions

	// SetTagEncoderPoolSize sets the TagEncoderPoolSize.
	SetTagEncoderPoolSize(value int) Options

	// TagEncoderPoolSize returns the TagEncoderPoolSize.
	TagEncoderPoolSize() int

	// SetTagDecoderOptions sets the TagDecoderOptions.
	SetTagDecoderOptions(value serialize.TagDecoderOptions) Options

	// TagDecoderOptions returns the TagDecoderOptions.
	TagDecoderOptions() serialize.TagDecoderOptions

	// SetTagDecoderPoolSize sets the TagDecoderPoolSize.
	SetTagDecoderPoolSize(value int) Options

	// TagDecoderPoolSize returns the TagDecoderPoolSize.
	TagDecoderPoolSize() int

	// SetWriteBatchSize sets the writeBatchSize
	// NB(r): for a write only application load this should match the host
	// queue ops flush size so that each time a host queue is flushed it can
	// fit the entire flushed write ops into a single batch.
	SetWriteBatchSize(value int) Options

	// WriteBatchSize returns the writeBatchSize
	WriteBatchSize() int

	// SetFetchBatchSize sets the fetchBatchSize
	// NB(r): for a fetch only application load this should match the host
	// queue ops flush size so that each time a host queue is flushed it can
	// fit the entire flushed fetch ops into a single batch.
	SetFetchBatchSize(value int) Options

	// FetchBatchSize returns the fetchBatchSize
	FetchBatchSize() int

	// SetWriteOpPoolSize sets the writeOperationPoolSize
	SetWriteOpPoolSize(value int) Options

	// WriteOpPoolSize returns the writeOperationPoolSize
	WriteOpPoolSize() int

	// SetWriteTaggedOpPoolSize sets the writeTaggedOperationPoolSize
	SetWriteTaggedOpPoolSize(value int) Options

	// WriteTaggedOpPoolSize returns the writeTaggedOperationPoolSize
	WriteTaggedOpPoolSize() int

	// SetFetchBatchOpPoolSize sets the fetchBatchOpPoolSize
	SetFetchBatchOpPoolSize(value int) Options

	// FetchBatchOpPoolSize returns the fetchBatchOpPoolSize
	FetchBatchOpPoolSize() int

	// SetCheckedBytesWrapperPoolSize sets the checkedBytesWrapperPoolSize
	SetCheckedBytesWrapperPoolSize(value int) Options

	// CheckedBytesWrapperPoolSize returns the checkedBytesWrapperPoolSize
	CheckedBytesWrapperPoolSize() int

	// SetHostQueueOpsFlushSize sets the hostQueueOpsFlushSize
	SetHostQueueOpsFlushSize(value int) Options

	// HostQueueOpsFlushSize returns the hostQueueOpsFlushSize
	HostQueueOpsFlushSize() int

	// SetHostQueueOpsFlushInterval sets the hostQueueOpsFlushInterval
	SetHostQueueOpsFlushInterval(value time.Duration) Options

	// HostQueueOpsFlushInterval returns the hostQueueOpsFlushInterval
	HostQueueOpsFlushInterval() time.Duration

	// SetContextPool sets the contextPool
	SetContextPool(value context.Pool) Options

	// ContextPool returns the contextPool
	ContextPool() context.Pool

	// SetIdentifierPool sets the identifier pool
	SetIdentifierPool(value ident.Pool) Options

	// IdentifierPool returns the identifier pool
	IdentifierPool() ident.Pool

	// HostQueueOpsArrayPoolSize sets the hostQueueOpsArrayPoolSize
	SetHostQueueOpsArrayPoolSize(value int) Options

	// HostQueueOpsArrayPoolSize returns the hostQueueOpsArrayPoolSize
	HostQueueOpsArrayPoolSize() int

	// SetSeriesIteratorPoolSize sets the seriesIteratorPoolSize
	SetSeriesIteratorPoolSize(value int) Options

	// SeriesIteratorPoolSize returns the seriesIteratorPoolSize
	SeriesIteratorPoolSize() int

	// SetSeriesIteratorArrayPoolBuckets sets the seriesIteratorArrayPoolBuckets
	SetSeriesIteratorArrayPoolBuckets(value []pool.Bucket) Options

	// SeriesIteratorArrayPoolBuckets returns the seriesIteratorArrayPoolBuckets
	SeriesIteratorArrayPoolBuckets() []pool.Bucket

	// SetReaderIteratorAllocate sets the readerIteratorAllocate
	SetReaderIteratorAllocate(value encoding.ReaderIteratorAllocate) Options

	// ReaderIteratorAllocate returns the readerIteratorAllocate
	ReaderIteratorAllocate() encoding.ReaderIteratorAllocate
}

Options is a set of client options

func NewOptions

func NewOptions() Options

NewOptions creates a new set of client options with defaults

type PeerBlockMetadataIter

type PeerBlockMetadataIter interface {
	// Next returns whether there are more items in the collection
	Next() bool

	// Current returns the host and block metadata, which remain
	// valid until Next() is called again
	Current() (topology.Host, block.Metadata)

	// Err returns any error encountered
	Err() error
}

PeerBlockMetadataIter iterates over a collection of blocks metadata from peers

type PeerBlocksIter

type PeerBlocksIter interface {
	// Next returns whether there are more items in the collection
	Next() bool

	// Current returns the metadata, and block data for a single block replica.
	// These remain valid until Next() is called again
	Current() (topology.Host, ident.ID, block.DatabaseBlock)

	// Err returns any error encountered
	Err() error
}

PeerBlocksIter iterates over a collection of blocks from peers

type Session

type Session interface {
	// Write value to the database for an ID
	Write(namespace, id ident.ID, t time.Time, value float64, unit xtime.Unit, annotation []byte) error

	// WriteTagged value to the database for an ID and given tags.
	WriteTagged(namespace, id ident.ID, tags ident.TagIterator, t time.Time, value float64, unit xtime.Unit, annotation []byte) error

	// Fetch values from the database for an ID
	Fetch(namespace, id ident.ID, startInclusive, endExclusive time.Time) (encoding.SeriesIterator, error)

	// FetchIDs values from the database for a set of IDs
	FetchIDs(namespace ident.ID, ids ident.Iterator, startInclusive, endExclusive time.Time) (encoding.SeriesIterators, error)

	// FetchTagged resolves the provided query to known IDs, and fetches the data for them.
	FetchTagged(namespace ident.ID, q index.Query, opts index.QueryOptions) (results encoding.SeriesIterators, exhaustive bool, err error)

	// FetchTaggedIDs resolves the provided query to known IDs.
	FetchTaggedIDs(namespace ident.ID, q index.Query, opts index.QueryOptions) (iter TaggedIDsIterator, exhaustive bool, err error)

	// ShardID returns the given shard for an ID for callers
	// to easily discern what shard is failing when operations
	// for given IDs begin failing
	ShardID(id ident.ID) (uint32, error)

	// IteratorPools exposes the internal iterator pools used by the session to clients
	IteratorPools() (encoding.IteratorPools, error)

	// Close the session
	Close() error
}

Session can write and read to a cluster

type TaggedIDsIterator

type TaggedIDsIterator interface {
	// Next returns whether there are more items in the collection.
	Next() bool

	// Current returns the ID, Tags and Namespace for a single timeseries.
	// These remain valid until Next() is called again.
	Current() (namespaceID ident.ID, seriesID ident.ID, tags ident.TagIterator)

	// Err returns any error encountered.
	Err() error

	// Finalize releases any held resources.
	Finalize()
}

TaggedIDsIterator iterates over a collection of IDs with associated tags and namespace.

type TaggedIDsIteratorMatcher

type TaggedIDsIteratorMatcher interface {
	gomock.Matcher
}

TaggedIDsIteratorMatcher is a gomock.Matcher that matches TaggedIDsIterator.

func MustNewTaggedIDsIteratorMatcher

func MustNewTaggedIDsIteratorMatcher(opts ...TaggedIDsIteratorMatcherOption) TaggedIDsIteratorMatcher

MustNewTaggedIDsIteratorMatcher returns a new TaggedIDsIteratorMatcher.

func NewTaggedIDsIteratorMatcher

func NewTaggedIDsIteratorMatcher(opts ...TaggedIDsIteratorMatcherOption) (TaggedIDsIteratorMatcher, error)

NewTaggedIDsIteratorMatcher returns a new TaggedIDsIteratorMatcher.

type TaggedIDsIteratorMatcherOption

type TaggedIDsIteratorMatcherOption struct {
	Namespace string
	ID        string
	Tags      []string
}

TaggedIDsIteratorMatcherOption is an option for the TaggedIDsIteratorMatcher ctor.

Jump to

Keyboard shortcuts

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