Documentation ¶
Index ¶
- type Client
- type Client_Close_Call
- type Client_Expecter
- type Client_Init_Call
- type Client_StreamExists_Call
- type Controller
- func (_m *Controller) EXPECT() *Controller_Expecter
- func (_m *Controller) GetLogger() logr.Logger
- func (_m *Controller) Reconcile(_a0 context.Context, _a1 reconcile.Request) (reconcile.Result, error)
- func (_m *Controller) Start(ctx context.Context) error
- func (_m *Controller) Watch(src source.Source, eventhandler handler.EventHandler, ...) error
- type Controller_Expecter
- func (_e *Controller_Expecter) GetLogger() *Controller_GetLogger_Call
- func (_e *Controller_Expecter) Reconcile(_a0 interface{}, _a1 interface{}) *Controller_Reconcile_Call
- func (_e *Controller_Expecter) Start(ctx interface{}) *Controller_Start_Call
- func (_e *Controller_Expecter) Watch(src interface{}, eventhandler interface{}, predicates ...interface{}) *Controller_Watch_Call
- type Controller_GetLogger_Call
- type Controller_Reconcile_Call
- func (_c *Controller_Reconcile_Call) Return(_a0 reconcile.Result, _a1 error) *Controller_Reconcile_Call
- func (_c *Controller_Reconcile_Call) Run(run func(_a0 context.Context, _a1 reconcile.Request)) *Controller_Reconcile_Call
- func (_c *Controller_Reconcile_Call) RunAndReturn(run func(context.Context, reconcile.Request) (reconcile.Result, error)) *Controller_Reconcile_Call
- type Controller_Start_Call
- type Controller_Watch_Call
- func (_c *Controller_Watch_Call) Return(_a0 error) *Controller_Watch_Call
- func (_c *Controller_Watch_Call) Run(run func(src source.Source, eventhandler handler.EventHandler, ...)) *Controller_Watch_Call
- func (_c *Controller_Watch_Call) RunAndReturn(run func(source.Source, handler.EventHandler, ...predicate.Predicate) error) *Controller_Watch_Call
- type JetStreamContext
- func (_m *JetStreamContext) AccountInfo(opts ...nats.JSOpt) (*nats.AccountInfo, error)
- func (_m *JetStreamContext) AddConsumer(stream string, cfg *nats.ConsumerConfig, opts ...nats.JSOpt) (*nats.ConsumerInfo, error)
- func (_m *JetStreamContext) AddStream(cfg *nats.StreamConfig, opts ...nats.JSOpt) (*nats.StreamInfo, error)
- func (_m *JetStreamContext) ChanQueueSubscribe(subj string, queue string, ch chan *nats.Msg, opts ...nats.SubOpt) (*nats.Subscription, error)
- func (_m *JetStreamContext) ChanSubscribe(subj string, ch chan *nats.Msg, opts ...nats.SubOpt) (*nats.Subscription, error)
- func (_m *JetStreamContext) ConsumerInfo(stream string, name string, opts ...nats.JSOpt) (*nats.ConsumerInfo, error)
- func (_m *JetStreamContext) ConsumerNames(stream string, opts ...nats.JSOpt) <-chan string
- func (_m *JetStreamContext) Consumers(stream string, opts ...nats.JSOpt) <-chan *nats.ConsumerInfo
- func (_m *JetStreamContext) ConsumersInfo(stream string, opts ...nats.JSOpt) <-chan *nats.ConsumerInfo
- func (_m *JetStreamContext) CreateKeyValue(cfg *nats.KeyValueConfig) (nats.KeyValue, error)
- func (_m *JetStreamContext) CreateObjectStore(cfg *nats.ObjectStoreConfig) (nats.ObjectStore, error)
- func (_m *JetStreamContext) DeleteConsumer(stream string, consumer string, opts ...nats.JSOpt) error
- func (_m *JetStreamContext) DeleteKeyValue(bucket string) error
- func (_m *JetStreamContext) DeleteMsg(name string, seq uint64, opts ...nats.JSOpt) error
- func (_m *JetStreamContext) DeleteObjectStore(bucket string) error
- func (_m *JetStreamContext) DeleteStream(name string, opts ...nats.JSOpt) error
- func (_m *JetStreamContext) EXPECT() *JetStreamContext_Expecter
- func (_m *JetStreamContext) GetLastMsg(name string, subject string, opts ...nats.JSOpt) (*nats.RawStreamMsg, error)
- func (_m *JetStreamContext) GetMsg(name string, seq uint64, opts ...nats.JSOpt) (*nats.RawStreamMsg, error)
- func (_m *JetStreamContext) KeyValue(bucket string) (nats.KeyValue, error)
- func (_m *JetStreamContext) KeyValueStoreNames() <-chan string
- func (_m *JetStreamContext) KeyValueStores() <-chan nats.KeyValueStatus
- func (_m *JetStreamContext) ObjectStore(bucket string) (nats.ObjectStore, error)
- func (_m *JetStreamContext) ObjectStoreNames(opts ...nats.ObjectOpt) <-chan string
- func (_m *JetStreamContext) ObjectStores(opts ...nats.ObjectOpt) <-chan nats.ObjectStoreStatus
- func (_m *JetStreamContext) Publish(subj string, data []byte, opts ...nats.PubOpt) (*nats.PubAck, error)
- func (_m *JetStreamContext) PublishAsync(subj string, data []byte, opts ...nats.PubOpt) (nats.PubAckFuture, error)
- func (_m *JetStreamContext) PublishAsyncComplete() <-chan struct{}
- func (_m *JetStreamContext) PublishAsyncPending() int
- func (_m *JetStreamContext) PublishMsg(m *nats.Msg, opts ...nats.PubOpt) (*nats.PubAck, error)
- func (_m *JetStreamContext) PublishMsgAsync(m *nats.Msg, opts ...nats.PubOpt) (nats.PubAckFuture, error)
- func (_m *JetStreamContext) PullSubscribe(subj string, durable string, opts ...nats.SubOpt) (*nats.Subscription, error)
- func (_m *JetStreamContext) PurgeStream(name string, opts ...nats.JSOpt) error
- func (_m *JetStreamContext) QueueSubscribe(subj string, queue string, cb nats.MsgHandler, opts ...nats.SubOpt) (*nats.Subscription, error)
- func (_m *JetStreamContext) QueueSubscribeSync(subj string, queue string, opts ...nats.SubOpt) (*nats.Subscription, error)
- func (_m *JetStreamContext) SecureDeleteMsg(name string, seq uint64, opts ...nats.JSOpt) error
- func (_m *JetStreamContext) StreamInfo(stream string, opts ...nats.JSOpt) (*nats.StreamInfo, error)
- func (_m *JetStreamContext) StreamNameBySubject(_a0 string, _a1 ...nats.JSOpt) (string, error)
- func (_m *JetStreamContext) StreamNames(opts ...nats.JSOpt) <-chan string
- func (_m *JetStreamContext) Streams(opts ...nats.JSOpt) <-chan *nats.StreamInfo
- func (_m *JetStreamContext) StreamsInfo(opts ...nats.JSOpt) <-chan *nats.StreamInfo
- func (_m *JetStreamContext) Subscribe(subj string, cb nats.MsgHandler, opts ...nats.SubOpt) (*nats.Subscription, error)
- func (_m *JetStreamContext) SubscribeSync(subj string, opts ...nats.SubOpt) (*nats.Subscription, error)
- func (_m *JetStreamContext) UpdateConsumer(stream string, cfg *nats.ConsumerConfig, opts ...nats.JSOpt) (*nats.ConsumerInfo, error)
- func (_m *JetStreamContext) UpdateStream(cfg *nats.StreamConfig, opts ...nats.JSOpt) (*nats.StreamInfo, error)
- type JetStreamContext_AccountInfo_Call
- func (_c *JetStreamContext_AccountInfo_Call) Return(_a0 *nats.AccountInfo, _a1 error) *JetStreamContext_AccountInfo_Call
- func (_c *JetStreamContext_AccountInfo_Call) Run(run func(opts ...nats.JSOpt)) *JetStreamContext_AccountInfo_Call
- func (_c *JetStreamContext_AccountInfo_Call) RunAndReturn(run func(...nats.JSOpt) (*nats.AccountInfo, error)) *JetStreamContext_AccountInfo_Call
- type JetStreamContext_AddConsumer_Call
- func (_c *JetStreamContext_AddConsumer_Call) Return(_a0 *nats.ConsumerInfo, _a1 error) *JetStreamContext_AddConsumer_Call
- func (_c *JetStreamContext_AddConsumer_Call) Run(run func(stream string, cfg *nats.ConsumerConfig, opts ...nats.JSOpt)) *JetStreamContext_AddConsumer_Call
- func (_c *JetStreamContext_AddConsumer_Call) RunAndReturn(...) *JetStreamContext_AddConsumer_Call
- type JetStreamContext_AddStream_Call
- func (_c *JetStreamContext_AddStream_Call) Return(_a0 *nats.StreamInfo, _a1 error) *JetStreamContext_AddStream_Call
- func (_c *JetStreamContext_AddStream_Call) Run(run func(cfg *nats.StreamConfig, opts ...nats.JSOpt)) *JetStreamContext_AddStream_Call
- func (_c *JetStreamContext_AddStream_Call) RunAndReturn(run func(*nats.StreamConfig, ...nats.JSOpt) (*nats.StreamInfo, error)) *JetStreamContext_AddStream_Call
- type JetStreamContext_ChanQueueSubscribe_Call
- func (_c *JetStreamContext_ChanQueueSubscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_ChanQueueSubscribe_Call
- func (_c *JetStreamContext_ChanQueueSubscribe_Call) Run(run func(subj string, queue string, ch chan *nats.Msg, opts ...nats.SubOpt)) *JetStreamContext_ChanQueueSubscribe_Call
- func (_c *JetStreamContext_ChanQueueSubscribe_Call) RunAndReturn(...) *JetStreamContext_ChanQueueSubscribe_Call
- type JetStreamContext_ChanSubscribe_Call
- func (_c *JetStreamContext_ChanSubscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_ChanSubscribe_Call
- func (_c *JetStreamContext_ChanSubscribe_Call) Run(run func(subj string, ch chan *nats.Msg, opts ...nats.SubOpt)) *JetStreamContext_ChanSubscribe_Call
- func (_c *JetStreamContext_ChanSubscribe_Call) RunAndReturn(run func(string, chan *nats.Msg, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_ChanSubscribe_Call
- type JetStreamContext_ConsumerInfo_Call
- func (_c *JetStreamContext_ConsumerInfo_Call) Return(_a0 *nats.ConsumerInfo, _a1 error) *JetStreamContext_ConsumerInfo_Call
- func (_c *JetStreamContext_ConsumerInfo_Call) Run(run func(stream string, name string, opts ...nats.JSOpt)) *JetStreamContext_ConsumerInfo_Call
- func (_c *JetStreamContext_ConsumerInfo_Call) RunAndReturn(run func(string, string, ...nats.JSOpt) (*nats.ConsumerInfo, error)) *JetStreamContext_ConsumerInfo_Call
- type JetStreamContext_ConsumerNames_Call
- func (_c *JetStreamContext_ConsumerNames_Call) Return(_a0 <-chan string) *JetStreamContext_ConsumerNames_Call
- func (_c *JetStreamContext_ConsumerNames_Call) Run(run func(stream string, opts ...nats.JSOpt)) *JetStreamContext_ConsumerNames_Call
- func (_c *JetStreamContext_ConsumerNames_Call) RunAndReturn(run func(string, ...nats.JSOpt) <-chan string) *JetStreamContext_ConsumerNames_Call
- type JetStreamContext_ConsumersInfo_Call
- func (_c *JetStreamContext_ConsumersInfo_Call) Return(_a0 <-chan *nats.ConsumerInfo) *JetStreamContext_ConsumersInfo_Call
- func (_c *JetStreamContext_ConsumersInfo_Call) Run(run func(stream string, opts ...nats.JSOpt)) *JetStreamContext_ConsumersInfo_Call
- func (_c *JetStreamContext_ConsumersInfo_Call) RunAndReturn(run func(string, ...nats.JSOpt) <-chan *nats.ConsumerInfo) *JetStreamContext_ConsumersInfo_Call
- type JetStreamContext_Consumers_Call
- func (_c *JetStreamContext_Consumers_Call) Return(_a0 <-chan *nats.ConsumerInfo) *JetStreamContext_Consumers_Call
- func (_c *JetStreamContext_Consumers_Call) Run(run func(stream string, opts ...nats.JSOpt)) *JetStreamContext_Consumers_Call
- func (_c *JetStreamContext_Consumers_Call) RunAndReturn(run func(string, ...nats.JSOpt) <-chan *nats.ConsumerInfo) *JetStreamContext_Consumers_Call
- type JetStreamContext_CreateKeyValue_Call
- func (_c *JetStreamContext_CreateKeyValue_Call) Return(_a0 nats.KeyValue, _a1 error) *JetStreamContext_CreateKeyValue_Call
- func (_c *JetStreamContext_CreateKeyValue_Call) Run(run func(cfg *nats.KeyValueConfig)) *JetStreamContext_CreateKeyValue_Call
- func (_c *JetStreamContext_CreateKeyValue_Call) RunAndReturn(run func(*nats.KeyValueConfig) (nats.KeyValue, error)) *JetStreamContext_CreateKeyValue_Call
- type JetStreamContext_CreateObjectStore_Call
- func (_c *JetStreamContext_CreateObjectStore_Call) Return(_a0 nats.ObjectStore, _a1 error) *JetStreamContext_CreateObjectStore_Call
- func (_c *JetStreamContext_CreateObjectStore_Call) Run(run func(cfg *nats.ObjectStoreConfig)) *JetStreamContext_CreateObjectStore_Call
- func (_c *JetStreamContext_CreateObjectStore_Call) RunAndReturn(run func(*nats.ObjectStoreConfig) (nats.ObjectStore, error)) *JetStreamContext_CreateObjectStore_Call
- type JetStreamContext_DeleteConsumer_Call
- func (_c *JetStreamContext_DeleteConsumer_Call) Return(_a0 error) *JetStreamContext_DeleteConsumer_Call
- func (_c *JetStreamContext_DeleteConsumer_Call) Run(run func(stream string, consumer string, opts ...nats.JSOpt)) *JetStreamContext_DeleteConsumer_Call
- func (_c *JetStreamContext_DeleteConsumer_Call) RunAndReturn(run func(string, string, ...nats.JSOpt) error) *JetStreamContext_DeleteConsumer_Call
- type JetStreamContext_DeleteKeyValue_Call
- func (_c *JetStreamContext_DeleteKeyValue_Call) Return(_a0 error) *JetStreamContext_DeleteKeyValue_Call
- func (_c *JetStreamContext_DeleteKeyValue_Call) Run(run func(bucket string)) *JetStreamContext_DeleteKeyValue_Call
- func (_c *JetStreamContext_DeleteKeyValue_Call) RunAndReturn(run func(string) error) *JetStreamContext_DeleteKeyValue_Call
- type JetStreamContext_DeleteMsg_Call
- func (_c *JetStreamContext_DeleteMsg_Call) Return(_a0 error) *JetStreamContext_DeleteMsg_Call
- func (_c *JetStreamContext_DeleteMsg_Call) Run(run func(name string, seq uint64, opts ...nats.JSOpt)) *JetStreamContext_DeleteMsg_Call
- func (_c *JetStreamContext_DeleteMsg_Call) RunAndReturn(run func(string, uint64, ...nats.JSOpt) error) *JetStreamContext_DeleteMsg_Call
- type JetStreamContext_DeleteObjectStore_Call
- func (_c *JetStreamContext_DeleteObjectStore_Call) Return(_a0 error) *JetStreamContext_DeleteObjectStore_Call
- func (_c *JetStreamContext_DeleteObjectStore_Call) Run(run func(bucket string)) *JetStreamContext_DeleteObjectStore_Call
- func (_c *JetStreamContext_DeleteObjectStore_Call) RunAndReturn(run func(string) error) *JetStreamContext_DeleteObjectStore_Call
- type JetStreamContext_DeleteStream_Call
- func (_c *JetStreamContext_DeleteStream_Call) Return(_a0 error) *JetStreamContext_DeleteStream_Call
- func (_c *JetStreamContext_DeleteStream_Call) Run(run func(name string, opts ...nats.JSOpt)) *JetStreamContext_DeleteStream_Call
- func (_c *JetStreamContext_DeleteStream_Call) RunAndReturn(run func(string, ...nats.JSOpt) error) *JetStreamContext_DeleteStream_Call
- type JetStreamContext_Expecter
- func (_e *JetStreamContext_Expecter) AccountInfo(opts ...interface{}) *JetStreamContext_AccountInfo_Call
- func (_e *JetStreamContext_Expecter) AddConsumer(stream interface{}, cfg interface{}, opts ...interface{}) *JetStreamContext_AddConsumer_Call
- func (_e *JetStreamContext_Expecter) AddStream(cfg interface{}, opts ...interface{}) *JetStreamContext_AddStream_Call
- func (_e *JetStreamContext_Expecter) ChanQueueSubscribe(subj interface{}, queue interface{}, ch interface{}, opts ...interface{}) *JetStreamContext_ChanQueueSubscribe_Call
- func (_e *JetStreamContext_Expecter) ChanSubscribe(subj interface{}, ch interface{}, opts ...interface{}) *JetStreamContext_ChanSubscribe_Call
- func (_e *JetStreamContext_Expecter) ConsumerInfo(stream interface{}, name interface{}, opts ...interface{}) *JetStreamContext_ConsumerInfo_Call
- func (_e *JetStreamContext_Expecter) ConsumerNames(stream interface{}, opts ...interface{}) *JetStreamContext_ConsumerNames_Call
- func (_e *JetStreamContext_Expecter) Consumers(stream interface{}, opts ...interface{}) *JetStreamContext_Consumers_Call
- func (_e *JetStreamContext_Expecter) ConsumersInfo(stream interface{}, opts ...interface{}) *JetStreamContext_ConsumersInfo_Call
- func (_e *JetStreamContext_Expecter) CreateKeyValue(cfg interface{}) *JetStreamContext_CreateKeyValue_Call
- func (_e *JetStreamContext_Expecter) CreateObjectStore(cfg interface{}) *JetStreamContext_CreateObjectStore_Call
- func (_e *JetStreamContext_Expecter) DeleteConsumer(stream interface{}, consumer interface{}, opts ...interface{}) *JetStreamContext_DeleteConsumer_Call
- func (_e *JetStreamContext_Expecter) DeleteKeyValue(bucket interface{}) *JetStreamContext_DeleteKeyValue_Call
- func (_e *JetStreamContext_Expecter) DeleteMsg(name interface{}, seq interface{}, opts ...interface{}) *JetStreamContext_DeleteMsg_Call
- func (_e *JetStreamContext_Expecter) DeleteObjectStore(bucket interface{}) *JetStreamContext_DeleteObjectStore_Call
- func (_e *JetStreamContext_Expecter) DeleteStream(name interface{}, opts ...interface{}) *JetStreamContext_DeleteStream_Call
- func (_e *JetStreamContext_Expecter) GetLastMsg(name interface{}, subject interface{}, opts ...interface{}) *JetStreamContext_GetLastMsg_Call
- func (_e *JetStreamContext_Expecter) GetMsg(name interface{}, seq interface{}, opts ...interface{}) *JetStreamContext_GetMsg_Call
- func (_e *JetStreamContext_Expecter) KeyValue(bucket interface{}) *JetStreamContext_KeyValue_Call
- func (_e *JetStreamContext_Expecter) KeyValueStoreNames() *JetStreamContext_KeyValueStoreNames_Call
- func (_e *JetStreamContext_Expecter) KeyValueStores() *JetStreamContext_KeyValueStores_Call
- func (_e *JetStreamContext_Expecter) ObjectStore(bucket interface{}) *JetStreamContext_ObjectStore_Call
- func (_e *JetStreamContext_Expecter) ObjectStoreNames(opts ...interface{}) *JetStreamContext_ObjectStoreNames_Call
- func (_e *JetStreamContext_Expecter) ObjectStores(opts ...interface{}) *JetStreamContext_ObjectStores_Call
- func (_e *JetStreamContext_Expecter) Publish(subj interface{}, data interface{}, opts ...interface{}) *JetStreamContext_Publish_Call
- func (_e *JetStreamContext_Expecter) PublishAsync(subj interface{}, data interface{}, opts ...interface{}) *JetStreamContext_PublishAsync_Call
- func (_e *JetStreamContext_Expecter) PublishAsyncComplete() *JetStreamContext_PublishAsyncComplete_Call
- func (_e *JetStreamContext_Expecter) PublishAsyncPending() *JetStreamContext_PublishAsyncPending_Call
- func (_e *JetStreamContext_Expecter) PublishMsg(m interface{}, opts ...interface{}) *JetStreamContext_PublishMsg_Call
- func (_e *JetStreamContext_Expecter) PublishMsgAsync(m interface{}, opts ...interface{}) *JetStreamContext_PublishMsgAsync_Call
- func (_e *JetStreamContext_Expecter) PullSubscribe(subj interface{}, durable interface{}, opts ...interface{}) *JetStreamContext_PullSubscribe_Call
- func (_e *JetStreamContext_Expecter) PurgeStream(name interface{}, opts ...interface{}) *JetStreamContext_PurgeStream_Call
- func (_e *JetStreamContext_Expecter) QueueSubscribe(subj interface{}, queue interface{}, cb interface{}, opts ...interface{}) *JetStreamContext_QueueSubscribe_Call
- func (_e *JetStreamContext_Expecter) QueueSubscribeSync(subj interface{}, queue interface{}, opts ...interface{}) *JetStreamContext_QueueSubscribeSync_Call
- func (_e *JetStreamContext_Expecter) SecureDeleteMsg(name interface{}, seq interface{}, opts ...interface{}) *JetStreamContext_SecureDeleteMsg_Call
- func (_e *JetStreamContext_Expecter) StreamInfo(stream interface{}, opts ...interface{}) *JetStreamContext_StreamInfo_Call
- func (_e *JetStreamContext_Expecter) StreamNameBySubject(_a0 interface{}, _a1 ...interface{}) *JetStreamContext_StreamNameBySubject_Call
- func (_e *JetStreamContext_Expecter) StreamNames(opts ...interface{}) *JetStreamContext_StreamNames_Call
- func (_e *JetStreamContext_Expecter) Streams(opts ...interface{}) *JetStreamContext_Streams_Call
- func (_e *JetStreamContext_Expecter) StreamsInfo(opts ...interface{}) *JetStreamContext_StreamsInfo_Call
- func (_e *JetStreamContext_Expecter) Subscribe(subj interface{}, cb interface{}, opts ...interface{}) *JetStreamContext_Subscribe_Call
- func (_e *JetStreamContext_Expecter) SubscribeSync(subj interface{}, opts ...interface{}) *JetStreamContext_SubscribeSync_Call
- func (_e *JetStreamContext_Expecter) UpdateConsumer(stream interface{}, cfg interface{}, opts ...interface{}) *JetStreamContext_UpdateConsumer_Call
- func (_e *JetStreamContext_Expecter) UpdateStream(cfg interface{}, opts ...interface{}) *JetStreamContext_UpdateStream_Call
- type JetStreamContext_GetLastMsg_Call
- func (_c *JetStreamContext_GetLastMsg_Call) Return(_a0 *nats.RawStreamMsg, _a1 error) *JetStreamContext_GetLastMsg_Call
- func (_c *JetStreamContext_GetLastMsg_Call) Run(run func(name string, subject string, opts ...nats.JSOpt)) *JetStreamContext_GetLastMsg_Call
- func (_c *JetStreamContext_GetLastMsg_Call) RunAndReturn(run func(string, string, ...nats.JSOpt) (*nats.RawStreamMsg, error)) *JetStreamContext_GetLastMsg_Call
- type JetStreamContext_GetMsg_Call
- func (_c *JetStreamContext_GetMsg_Call) Return(_a0 *nats.RawStreamMsg, _a1 error) *JetStreamContext_GetMsg_Call
- func (_c *JetStreamContext_GetMsg_Call) Run(run func(name string, seq uint64, opts ...nats.JSOpt)) *JetStreamContext_GetMsg_Call
- func (_c *JetStreamContext_GetMsg_Call) RunAndReturn(run func(string, uint64, ...nats.JSOpt) (*nats.RawStreamMsg, error)) *JetStreamContext_GetMsg_Call
- type JetStreamContext_KeyValueStoreNames_Call
- func (_c *JetStreamContext_KeyValueStoreNames_Call) Return(_a0 <-chan string) *JetStreamContext_KeyValueStoreNames_Call
- func (_c *JetStreamContext_KeyValueStoreNames_Call) Run(run func()) *JetStreamContext_KeyValueStoreNames_Call
- func (_c *JetStreamContext_KeyValueStoreNames_Call) RunAndReturn(run func() <-chan string) *JetStreamContext_KeyValueStoreNames_Call
- type JetStreamContext_KeyValueStores_Call
- func (_c *JetStreamContext_KeyValueStores_Call) Return(_a0 <-chan nats.KeyValueStatus) *JetStreamContext_KeyValueStores_Call
- func (_c *JetStreamContext_KeyValueStores_Call) Run(run func()) *JetStreamContext_KeyValueStores_Call
- func (_c *JetStreamContext_KeyValueStores_Call) RunAndReturn(run func() <-chan nats.KeyValueStatus) *JetStreamContext_KeyValueStores_Call
- type JetStreamContext_KeyValue_Call
- func (_c *JetStreamContext_KeyValue_Call) Return(_a0 nats.KeyValue, _a1 error) *JetStreamContext_KeyValue_Call
- func (_c *JetStreamContext_KeyValue_Call) Run(run func(bucket string)) *JetStreamContext_KeyValue_Call
- func (_c *JetStreamContext_KeyValue_Call) RunAndReturn(run func(string) (nats.KeyValue, error)) *JetStreamContext_KeyValue_Call
- type JetStreamContext_ObjectStoreNames_Call
- func (_c *JetStreamContext_ObjectStoreNames_Call) Return(_a0 <-chan string) *JetStreamContext_ObjectStoreNames_Call
- func (_c *JetStreamContext_ObjectStoreNames_Call) Run(run func(opts ...nats.ObjectOpt)) *JetStreamContext_ObjectStoreNames_Call
- func (_c *JetStreamContext_ObjectStoreNames_Call) RunAndReturn(run func(...nats.ObjectOpt) <-chan string) *JetStreamContext_ObjectStoreNames_Call
- type JetStreamContext_ObjectStore_Call
- func (_c *JetStreamContext_ObjectStore_Call) Return(_a0 nats.ObjectStore, _a1 error) *JetStreamContext_ObjectStore_Call
- func (_c *JetStreamContext_ObjectStore_Call) Run(run func(bucket string)) *JetStreamContext_ObjectStore_Call
- func (_c *JetStreamContext_ObjectStore_Call) RunAndReturn(run func(string) (nats.ObjectStore, error)) *JetStreamContext_ObjectStore_Call
- type JetStreamContext_ObjectStores_Call
- func (_c *JetStreamContext_ObjectStores_Call) Return(_a0 <-chan nats.ObjectStoreStatus) *JetStreamContext_ObjectStores_Call
- func (_c *JetStreamContext_ObjectStores_Call) Run(run func(opts ...nats.ObjectOpt)) *JetStreamContext_ObjectStores_Call
- func (_c *JetStreamContext_ObjectStores_Call) RunAndReturn(run func(...nats.ObjectOpt) <-chan nats.ObjectStoreStatus) *JetStreamContext_ObjectStores_Call
- type JetStreamContext_PublishAsyncComplete_Call
- func (_c *JetStreamContext_PublishAsyncComplete_Call) Return(_a0 <-chan struct{}) *JetStreamContext_PublishAsyncComplete_Call
- func (_c *JetStreamContext_PublishAsyncComplete_Call) Run(run func()) *JetStreamContext_PublishAsyncComplete_Call
- func (_c *JetStreamContext_PublishAsyncComplete_Call) RunAndReturn(run func() <-chan struct{}) *JetStreamContext_PublishAsyncComplete_Call
- type JetStreamContext_PublishAsyncPending_Call
- func (_c *JetStreamContext_PublishAsyncPending_Call) Return(_a0 int) *JetStreamContext_PublishAsyncPending_Call
- func (_c *JetStreamContext_PublishAsyncPending_Call) Run(run func()) *JetStreamContext_PublishAsyncPending_Call
- func (_c *JetStreamContext_PublishAsyncPending_Call) RunAndReturn(run func() int) *JetStreamContext_PublishAsyncPending_Call
- type JetStreamContext_PublishAsync_Call
- func (_c *JetStreamContext_PublishAsync_Call) Return(_a0 nats.PubAckFuture, _a1 error) *JetStreamContext_PublishAsync_Call
- func (_c *JetStreamContext_PublishAsync_Call) Run(run func(subj string, data []byte, opts ...nats.PubOpt)) *JetStreamContext_PublishAsync_Call
- func (_c *JetStreamContext_PublishAsync_Call) RunAndReturn(run func(string, []byte, ...nats.PubOpt) (nats.PubAckFuture, error)) *JetStreamContext_PublishAsync_Call
- type JetStreamContext_PublishMsgAsync_Call
- func (_c *JetStreamContext_PublishMsgAsync_Call) Return(_a0 nats.PubAckFuture, _a1 error) *JetStreamContext_PublishMsgAsync_Call
- func (_c *JetStreamContext_PublishMsgAsync_Call) Run(run func(m *nats.Msg, opts ...nats.PubOpt)) *JetStreamContext_PublishMsgAsync_Call
- func (_c *JetStreamContext_PublishMsgAsync_Call) RunAndReturn(run func(*nats.Msg, ...nats.PubOpt) (nats.PubAckFuture, error)) *JetStreamContext_PublishMsgAsync_Call
- type JetStreamContext_PublishMsg_Call
- func (_c *JetStreamContext_PublishMsg_Call) Return(_a0 *nats.PubAck, _a1 error) *JetStreamContext_PublishMsg_Call
- func (_c *JetStreamContext_PublishMsg_Call) Run(run func(m *nats.Msg, opts ...nats.PubOpt)) *JetStreamContext_PublishMsg_Call
- func (_c *JetStreamContext_PublishMsg_Call) RunAndReturn(run func(*nats.Msg, ...nats.PubOpt) (*nats.PubAck, error)) *JetStreamContext_PublishMsg_Call
- type JetStreamContext_Publish_Call
- func (_c *JetStreamContext_Publish_Call) Return(_a0 *nats.PubAck, _a1 error) *JetStreamContext_Publish_Call
- func (_c *JetStreamContext_Publish_Call) Run(run func(subj string, data []byte, opts ...nats.PubOpt)) *JetStreamContext_Publish_Call
- func (_c *JetStreamContext_Publish_Call) RunAndReturn(run func(string, []byte, ...nats.PubOpt) (*nats.PubAck, error)) *JetStreamContext_Publish_Call
- type JetStreamContext_PullSubscribe_Call
- func (_c *JetStreamContext_PullSubscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_PullSubscribe_Call
- func (_c *JetStreamContext_PullSubscribe_Call) Run(run func(subj string, durable string, opts ...nats.SubOpt)) *JetStreamContext_PullSubscribe_Call
- func (_c *JetStreamContext_PullSubscribe_Call) RunAndReturn(run func(string, string, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_PullSubscribe_Call
- type JetStreamContext_PurgeStream_Call
- func (_c *JetStreamContext_PurgeStream_Call) Return(_a0 error) *JetStreamContext_PurgeStream_Call
- func (_c *JetStreamContext_PurgeStream_Call) Run(run func(name string, opts ...nats.JSOpt)) *JetStreamContext_PurgeStream_Call
- func (_c *JetStreamContext_PurgeStream_Call) RunAndReturn(run func(string, ...nats.JSOpt) error) *JetStreamContext_PurgeStream_Call
- type JetStreamContext_QueueSubscribeSync_Call
- func (_c *JetStreamContext_QueueSubscribeSync_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_QueueSubscribeSync_Call
- func (_c *JetStreamContext_QueueSubscribeSync_Call) Run(run func(subj string, queue string, opts ...nats.SubOpt)) *JetStreamContext_QueueSubscribeSync_Call
- func (_c *JetStreamContext_QueueSubscribeSync_Call) RunAndReturn(run func(string, string, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_QueueSubscribeSync_Call
- type JetStreamContext_QueueSubscribe_Call
- func (_c *JetStreamContext_QueueSubscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_QueueSubscribe_Call
- func (_c *JetStreamContext_QueueSubscribe_Call) Run(run func(subj string, queue string, cb nats.MsgHandler, opts ...nats.SubOpt)) *JetStreamContext_QueueSubscribe_Call
- func (_c *JetStreamContext_QueueSubscribe_Call) RunAndReturn(...) *JetStreamContext_QueueSubscribe_Call
- type JetStreamContext_SecureDeleteMsg_Call
- func (_c *JetStreamContext_SecureDeleteMsg_Call) Return(_a0 error) *JetStreamContext_SecureDeleteMsg_Call
- func (_c *JetStreamContext_SecureDeleteMsg_Call) Run(run func(name string, seq uint64, opts ...nats.JSOpt)) *JetStreamContext_SecureDeleteMsg_Call
- func (_c *JetStreamContext_SecureDeleteMsg_Call) RunAndReturn(run func(string, uint64, ...nats.JSOpt) error) *JetStreamContext_SecureDeleteMsg_Call
- type JetStreamContext_StreamInfo_Call
- func (_c *JetStreamContext_StreamInfo_Call) Return(_a0 *nats.StreamInfo, _a1 error) *JetStreamContext_StreamInfo_Call
- func (_c *JetStreamContext_StreamInfo_Call) Run(run func(stream string, opts ...nats.JSOpt)) *JetStreamContext_StreamInfo_Call
- func (_c *JetStreamContext_StreamInfo_Call) RunAndReturn(run func(string, ...nats.JSOpt) (*nats.StreamInfo, error)) *JetStreamContext_StreamInfo_Call
- type JetStreamContext_StreamNameBySubject_Call
- func (_c *JetStreamContext_StreamNameBySubject_Call) Return(_a0 string, _a1 error) *JetStreamContext_StreamNameBySubject_Call
- func (_c *JetStreamContext_StreamNameBySubject_Call) Run(run func(_a0 string, _a1 ...nats.JSOpt)) *JetStreamContext_StreamNameBySubject_Call
- func (_c *JetStreamContext_StreamNameBySubject_Call) RunAndReturn(run func(string, ...nats.JSOpt) (string, error)) *JetStreamContext_StreamNameBySubject_Call
- type JetStreamContext_StreamNames_Call
- func (_c *JetStreamContext_StreamNames_Call) Return(_a0 <-chan string) *JetStreamContext_StreamNames_Call
- func (_c *JetStreamContext_StreamNames_Call) Run(run func(opts ...nats.JSOpt)) *JetStreamContext_StreamNames_Call
- func (_c *JetStreamContext_StreamNames_Call) RunAndReturn(run func(...nats.JSOpt) <-chan string) *JetStreamContext_StreamNames_Call
- type JetStreamContext_StreamsInfo_Call
- func (_c *JetStreamContext_StreamsInfo_Call) Return(_a0 <-chan *nats.StreamInfo) *JetStreamContext_StreamsInfo_Call
- func (_c *JetStreamContext_StreamsInfo_Call) Run(run func(opts ...nats.JSOpt)) *JetStreamContext_StreamsInfo_Call
- func (_c *JetStreamContext_StreamsInfo_Call) RunAndReturn(run func(...nats.JSOpt) <-chan *nats.StreamInfo) *JetStreamContext_StreamsInfo_Call
- type JetStreamContext_Streams_Call
- func (_c *JetStreamContext_Streams_Call) Return(_a0 <-chan *nats.StreamInfo) *JetStreamContext_Streams_Call
- func (_c *JetStreamContext_Streams_Call) Run(run func(opts ...nats.JSOpt)) *JetStreamContext_Streams_Call
- func (_c *JetStreamContext_Streams_Call) RunAndReturn(run func(...nats.JSOpt) <-chan *nats.StreamInfo) *JetStreamContext_Streams_Call
- type JetStreamContext_SubscribeSync_Call
- func (_c *JetStreamContext_SubscribeSync_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_SubscribeSync_Call
- func (_c *JetStreamContext_SubscribeSync_Call) Run(run func(subj string, opts ...nats.SubOpt)) *JetStreamContext_SubscribeSync_Call
- func (_c *JetStreamContext_SubscribeSync_Call) RunAndReturn(run func(string, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_SubscribeSync_Call
- type JetStreamContext_Subscribe_Call
- func (_c *JetStreamContext_Subscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_Subscribe_Call
- func (_c *JetStreamContext_Subscribe_Call) Run(run func(subj string, cb nats.MsgHandler, opts ...nats.SubOpt)) *JetStreamContext_Subscribe_Call
- func (_c *JetStreamContext_Subscribe_Call) RunAndReturn(run func(string, nats.MsgHandler, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_Subscribe_Call
- type JetStreamContext_UpdateConsumer_Call
- func (_c *JetStreamContext_UpdateConsumer_Call) Return(_a0 *nats.ConsumerInfo, _a1 error) *JetStreamContext_UpdateConsumer_Call
- func (_c *JetStreamContext_UpdateConsumer_Call) Run(run func(stream string, cfg *nats.ConsumerConfig, opts ...nats.JSOpt)) *JetStreamContext_UpdateConsumer_Call
- func (_c *JetStreamContext_UpdateConsumer_Call) RunAndReturn(...) *JetStreamContext_UpdateConsumer_Call
- type JetStreamContext_UpdateStream_Call
- func (_c *JetStreamContext_UpdateStream_Call) Return(_a0 *nats.StreamInfo, _a1 error) *JetStreamContext_UpdateStream_Call
- func (_c *JetStreamContext_UpdateStream_Call) Run(run func(cfg *nats.StreamConfig, opts ...nats.JSOpt)) *JetStreamContext_UpdateStream_Call
- func (_c *JetStreamContext_UpdateStream_Call) RunAndReturn(run func(*nats.StreamConfig, ...nats.JSOpt) (*nats.StreamInfo, error)) *JetStreamContext_UpdateStream_Call
- type Manager
- func (_m *Manager) Add(_a0 manager.Runnable) error
- func (_m *Manager) AddHealthzCheck(name string, check healthz.Checker) error
- func (_m *Manager) AddMetricsExtraHandler(path string, handler http.Handler) error
- func (_m *Manager) AddReadyzCheck(name string, check healthz.Checker) error
- func (_m *Manager) EXPECT() *Manager_Expecter
- func (_m *Manager) Elected() <-chan struct{}
- func (_m *Manager) GetAPIReader() client.Reader
- func (_m *Manager) GetCache() cache.Cache
- func (_m *Manager) GetClient() client.Client
- func (_m *Manager) GetConfig() *rest.Config
- func (_m *Manager) GetControllerOptions() config.Controller
- func (_m *Manager) GetEventRecorderFor(name string) record.EventRecorder
- func (_m *Manager) GetFieldIndexer() client.FieldIndexer
- func (_m *Manager) GetHTTPClient() *http.Client
- func (_m *Manager) GetLogger() logr.Logger
- func (_m *Manager) GetRESTMapper() meta.RESTMapper
- func (_m *Manager) GetScheme() *runtime.Scheme
- func (_m *Manager) GetWebhookServer() webhook.Server
- func (_m *Manager) Start(ctx context.Context) error
- type Manager_AddHealthzCheck_Call
- func (_c *Manager_AddHealthzCheck_Call) Return(_a0 error) *Manager_AddHealthzCheck_Call
- func (_c *Manager_AddHealthzCheck_Call) Run(run func(name string, check healthz.Checker)) *Manager_AddHealthzCheck_Call
- func (_c *Manager_AddHealthzCheck_Call) RunAndReturn(run func(string, healthz.Checker) error) *Manager_AddHealthzCheck_Call
- type Manager_AddMetricsExtraHandler_Call
- func (_c *Manager_AddMetricsExtraHandler_Call) Return(_a0 error) *Manager_AddMetricsExtraHandler_Call
- func (_c *Manager_AddMetricsExtraHandler_Call) Run(run func(path string, handler http.Handler)) *Manager_AddMetricsExtraHandler_Call
- func (_c *Manager_AddMetricsExtraHandler_Call) RunAndReturn(run func(string, http.Handler) error) *Manager_AddMetricsExtraHandler_Call
- type Manager_AddReadyzCheck_Call
- func (_c *Manager_AddReadyzCheck_Call) Return(_a0 error) *Manager_AddReadyzCheck_Call
- func (_c *Manager_AddReadyzCheck_Call) Run(run func(name string, check healthz.Checker)) *Manager_AddReadyzCheck_Call
- func (_c *Manager_AddReadyzCheck_Call) RunAndReturn(run func(string, healthz.Checker) error) *Manager_AddReadyzCheck_Call
- type Manager_Add_Call
- type Manager_Elected_Call
- type Manager_Expecter
- func (_e *Manager_Expecter) Add(_a0 interface{}) *Manager_Add_Call
- func (_e *Manager_Expecter) AddHealthzCheck(name interface{}, check interface{}) *Manager_AddHealthzCheck_Call
- func (_e *Manager_Expecter) AddMetricsExtraHandler(path interface{}, handler interface{}) *Manager_AddMetricsExtraHandler_Call
- func (_e *Manager_Expecter) AddReadyzCheck(name interface{}, check interface{}) *Manager_AddReadyzCheck_Call
- func (_e *Manager_Expecter) Elected() *Manager_Elected_Call
- func (_e *Manager_Expecter) GetAPIReader() *Manager_GetAPIReader_Call
- func (_e *Manager_Expecter) GetCache() *Manager_GetCache_Call
- func (_e *Manager_Expecter) GetClient() *Manager_GetClient_Call
- func (_e *Manager_Expecter) GetConfig() *Manager_GetConfig_Call
- func (_e *Manager_Expecter) GetControllerOptions() *Manager_GetControllerOptions_Call
- func (_e *Manager_Expecter) GetEventRecorderFor(name interface{}) *Manager_GetEventRecorderFor_Call
- func (_e *Manager_Expecter) GetFieldIndexer() *Manager_GetFieldIndexer_Call
- func (_e *Manager_Expecter) GetHTTPClient() *Manager_GetHTTPClient_Call
- func (_e *Manager_Expecter) GetLogger() *Manager_GetLogger_Call
- func (_e *Manager_Expecter) GetRESTMapper() *Manager_GetRESTMapper_Call
- func (_e *Manager_Expecter) GetScheme() *Manager_GetScheme_Call
- func (_e *Manager_Expecter) GetWebhookServer() *Manager_GetWebhookServer_Call
- func (_e *Manager_Expecter) Start(ctx interface{}) *Manager_Start_Call
- type Manager_GetAPIReader_Call
- type Manager_GetCache_Call
- type Manager_GetClient_Call
- type Manager_GetConfig_Call
- type Manager_GetControllerOptions_Call
- func (_c *Manager_GetControllerOptions_Call) Return(_a0 config.Controller) *Manager_GetControllerOptions_Call
- func (_c *Manager_GetControllerOptions_Call) Run(run func()) *Manager_GetControllerOptions_Call
- func (_c *Manager_GetControllerOptions_Call) RunAndReturn(run func() config.Controller) *Manager_GetControllerOptions_Call
- type Manager_GetEventRecorderFor_Call
- func (_c *Manager_GetEventRecorderFor_Call) Return(_a0 record.EventRecorder) *Manager_GetEventRecorderFor_Call
- func (_c *Manager_GetEventRecorderFor_Call) Run(run func(name string)) *Manager_GetEventRecorderFor_Call
- func (_c *Manager_GetEventRecorderFor_Call) RunAndReturn(run func(string) record.EventRecorder) *Manager_GetEventRecorderFor_Call
- type Manager_GetFieldIndexer_Call
- func (_c *Manager_GetFieldIndexer_Call) Return(_a0 client.FieldIndexer) *Manager_GetFieldIndexer_Call
- func (_c *Manager_GetFieldIndexer_Call) Run(run func()) *Manager_GetFieldIndexer_Call
- func (_c *Manager_GetFieldIndexer_Call) RunAndReturn(run func() client.FieldIndexer) *Manager_GetFieldIndexer_Call
- type Manager_GetHTTPClient_Call
- type Manager_GetLogger_Call
- type Manager_GetRESTMapper_Call
- type Manager_GetScheme_Call
- type Manager_GetWebhookServer_Call
- type Manager_Start_Call
- type NatsConn
- type NatsConn_Close_Call
- type NatsConn_Expecter
- type NatsConn_IsConnected_Call
- type NatsConn_JetStream_Call
- func (_c *NatsConn_JetStream_Call) Return(_a0 nats_go.JetStreamContext, _a1 error) *NatsConn_JetStream_Call
- func (_c *NatsConn_JetStream_Call) Run(run func()) *NatsConn_JetStream_Call
- func (_c *NatsConn_JetStream_Call) RunAndReturn(run func() (nats_go.JetStreamContext, error)) *NatsConn_JetStream_Call
- type NatsConn_Status_Call
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type Client ¶
Client is an autogenerated mock type for the Client type
func NewClient ¶
NewClient creates a new instance of Client. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Client) EXPECT ¶
func (_m *Client) EXPECT() *Client_Expecter
func (*Client) StreamExists ¶
StreamExists provides a mock function with given fields:
type Client_Close_Call ¶
Client_Close_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Close'
func (*Client_Close_Call) Return ¶
func (_c *Client_Close_Call) Return() *Client_Close_Call
func (*Client_Close_Call) Run ¶
func (_c *Client_Close_Call) Run(run func()) *Client_Close_Call
func (*Client_Close_Call) RunAndReturn ¶
func (_c *Client_Close_Call) RunAndReturn(run func()) *Client_Close_Call
type Client_Expecter ¶
type Client_Expecter struct {
// contains filtered or unexported fields
}
func (*Client_Expecter) Close ¶
func (_e *Client_Expecter) Close() *Client_Close_Call
Close is a helper method to define mock.On call
func (*Client_Expecter) Init ¶
func (_e *Client_Expecter) Init() *Client_Init_Call
Init is a helper method to define mock.On call
func (*Client_Expecter) StreamExists ¶
func (_e *Client_Expecter) StreamExists() *Client_StreamExists_Call
StreamExists is a helper method to define mock.On call
type Client_Init_Call ¶
Client_Init_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Init'
func (*Client_Init_Call) Return ¶
func (_c *Client_Init_Call) Return(_a0 error) *Client_Init_Call
func (*Client_Init_Call) Run ¶
func (_c *Client_Init_Call) Run(run func()) *Client_Init_Call
func (*Client_Init_Call) RunAndReturn ¶
func (_c *Client_Init_Call) RunAndReturn(run func() error) *Client_Init_Call
type Client_StreamExists_Call ¶
Client_StreamExists_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'StreamExists'
func (*Client_StreamExists_Call) Return ¶
func (_c *Client_StreamExists_Call) Return(_a0 bool, _a1 error) *Client_StreamExists_Call
func (*Client_StreamExists_Call) Run ¶
func (_c *Client_StreamExists_Call) Run(run func()) *Client_StreamExists_Call
func (*Client_StreamExists_Call) RunAndReturn ¶
func (_c *Client_StreamExists_Call) RunAndReturn(run func() (bool, error)) *Client_StreamExists_Call
type Controller ¶
Controller is an autogenerated mock type for the Controller type
func NewController ¶
func NewController(t interface { mock.TestingT Cleanup(func()) }) *Controller
NewController creates a new instance of Controller. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Controller) EXPECT ¶
func (_m *Controller) EXPECT() *Controller_Expecter
func (*Controller) GetLogger ¶
func (_m *Controller) GetLogger() logr.Logger
GetLogger provides a mock function with given fields:
func (*Controller) Reconcile ¶
func (_m *Controller) Reconcile(_a0 context.Context, _a1 reconcile.Request) (reconcile.Result, error)
Reconcile provides a mock function with given fields: _a0, _a1
func (*Controller) Start ¶
func (_m *Controller) Start(ctx context.Context) error
Start provides a mock function with given fields: ctx
func (*Controller) Watch ¶
func (_m *Controller) Watch(src source.Source, eventhandler handler.EventHandler, predicates ...predicate.Predicate) error
Watch provides a mock function with given fields: src, eventhandler, predicates
type Controller_Expecter ¶
type Controller_Expecter struct {
// contains filtered or unexported fields
}
func (*Controller_Expecter) GetLogger ¶
func (_e *Controller_Expecter) GetLogger() *Controller_GetLogger_Call
GetLogger is a helper method to define mock.On call
func (*Controller_Expecter) Reconcile ¶
func (_e *Controller_Expecter) Reconcile(_a0 interface{}, _a1 interface{}) *Controller_Reconcile_Call
Reconcile is a helper method to define mock.On call
- _a0 context.Context
- _a1 reconcile.Request
func (*Controller_Expecter) Start ¶
func (_e *Controller_Expecter) Start(ctx interface{}) *Controller_Start_Call
Start is a helper method to define mock.On call
- ctx context.Context
func (*Controller_Expecter) Watch ¶
func (_e *Controller_Expecter) Watch(src interface{}, eventhandler interface{}, predicates ...interface{}) *Controller_Watch_Call
Watch is a helper method to define mock.On call
- src source.Source
- eventhandler handler.EventHandler
- predicates ...predicate.Predicate
type Controller_GetLogger_Call ¶
Controller_GetLogger_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetLogger'
func (*Controller_GetLogger_Call) Return ¶
func (_c *Controller_GetLogger_Call) Return(_a0 logr.Logger) *Controller_GetLogger_Call
func (*Controller_GetLogger_Call) Run ¶
func (_c *Controller_GetLogger_Call) Run(run func()) *Controller_GetLogger_Call
func (*Controller_GetLogger_Call) RunAndReturn ¶
func (_c *Controller_GetLogger_Call) RunAndReturn(run func() logr.Logger) *Controller_GetLogger_Call
type Controller_Reconcile_Call ¶
Controller_Reconcile_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Reconcile'
func (*Controller_Reconcile_Call) Return ¶
func (_c *Controller_Reconcile_Call) Return(_a0 reconcile.Result, _a1 error) *Controller_Reconcile_Call
func (*Controller_Reconcile_Call) Run ¶
func (_c *Controller_Reconcile_Call) Run(run func(_a0 context.Context, _a1 reconcile.Request)) *Controller_Reconcile_Call
func (*Controller_Reconcile_Call) RunAndReturn ¶
func (_c *Controller_Reconcile_Call) RunAndReturn(run func(context.Context, reconcile.Request) (reconcile.Result, error)) *Controller_Reconcile_Call
type Controller_Start_Call ¶
Controller_Start_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Start'
func (*Controller_Start_Call) Return ¶
func (_c *Controller_Start_Call) Return(_a0 error) *Controller_Start_Call
func (*Controller_Start_Call) Run ¶
func (_c *Controller_Start_Call) Run(run func(ctx context.Context)) *Controller_Start_Call
func (*Controller_Start_Call) RunAndReturn ¶
func (_c *Controller_Start_Call) RunAndReturn(run func(context.Context) error) *Controller_Start_Call
type Controller_Watch_Call ¶
Controller_Watch_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Watch'
func (*Controller_Watch_Call) Return ¶
func (_c *Controller_Watch_Call) Return(_a0 error) *Controller_Watch_Call
func (*Controller_Watch_Call) Run ¶
func (_c *Controller_Watch_Call) Run(run func(src source.Source, eventhandler handler.EventHandler, predicates ...predicate.Predicate)) *Controller_Watch_Call
func (*Controller_Watch_Call) RunAndReturn ¶
func (_c *Controller_Watch_Call) RunAndReturn(run func(source.Source, handler.EventHandler, ...predicate.Predicate) error) *Controller_Watch_Call
type JetStreamContext ¶
JetStreamContext is an autogenerated mock type for the JetStreamContext type
func NewJetStreamContext ¶
func NewJetStreamContext(t interface { mock.TestingT Cleanup(func()) }) *JetStreamContext
NewJetStreamContext creates a new instance of JetStreamContext. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*JetStreamContext) AccountInfo ¶
func (_m *JetStreamContext) AccountInfo(opts ...nats.JSOpt) (*nats.AccountInfo, error)
AccountInfo provides a mock function with given fields: opts
func (*JetStreamContext) AddConsumer ¶
func (_m *JetStreamContext) AddConsumer(stream string, cfg *nats.ConsumerConfig, opts ...nats.JSOpt) (*nats.ConsumerInfo, error)
AddConsumer provides a mock function with given fields: stream, cfg, opts
func (*JetStreamContext) AddStream ¶
func (_m *JetStreamContext) AddStream(cfg *nats.StreamConfig, opts ...nats.JSOpt) (*nats.StreamInfo, error)
AddStream provides a mock function with given fields: cfg, opts
func (*JetStreamContext) ChanQueueSubscribe ¶
func (_m *JetStreamContext) ChanQueueSubscribe(subj string, queue string, ch chan *nats.Msg, opts ...nats.SubOpt) (*nats.Subscription, error)
ChanQueueSubscribe provides a mock function with given fields: subj, queue, ch, opts
func (*JetStreamContext) ChanSubscribe ¶
func (_m *JetStreamContext) ChanSubscribe(subj string, ch chan *nats.Msg, opts ...nats.SubOpt) (*nats.Subscription, error)
ChanSubscribe provides a mock function with given fields: subj, ch, opts
func (*JetStreamContext) ConsumerInfo ¶
func (_m *JetStreamContext) ConsumerInfo(stream string, name string, opts ...nats.JSOpt) (*nats.ConsumerInfo, error)
ConsumerInfo provides a mock function with given fields: stream, name, opts
func (*JetStreamContext) ConsumerNames ¶
func (_m *JetStreamContext) ConsumerNames(stream string, opts ...nats.JSOpt) <-chan string
ConsumerNames provides a mock function with given fields: stream, opts
func (*JetStreamContext) Consumers ¶
func (_m *JetStreamContext) Consumers(stream string, opts ...nats.JSOpt) <-chan *nats.ConsumerInfo
Consumers provides a mock function with given fields: stream, opts
func (*JetStreamContext) ConsumersInfo ¶
func (_m *JetStreamContext) ConsumersInfo(stream string, opts ...nats.JSOpt) <-chan *nats.ConsumerInfo
ConsumersInfo provides a mock function with given fields: stream, opts
func (*JetStreamContext) CreateKeyValue ¶
func (_m *JetStreamContext) CreateKeyValue(cfg *nats.KeyValueConfig) (nats.KeyValue, error)
CreateKeyValue provides a mock function with given fields: cfg
func (*JetStreamContext) CreateObjectStore ¶
func (_m *JetStreamContext) CreateObjectStore(cfg *nats.ObjectStoreConfig) (nats.ObjectStore, error)
CreateObjectStore provides a mock function with given fields: cfg
func (*JetStreamContext) DeleteConsumer ¶
func (_m *JetStreamContext) DeleteConsumer(stream string, consumer string, opts ...nats.JSOpt) error
DeleteConsumer provides a mock function with given fields: stream, consumer, opts
func (*JetStreamContext) DeleteKeyValue ¶
func (_m *JetStreamContext) DeleteKeyValue(bucket string) error
DeleteKeyValue provides a mock function with given fields: bucket
func (*JetStreamContext) DeleteMsg ¶
DeleteMsg provides a mock function with given fields: name, seq, opts
func (*JetStreamContext) DeleteObjectStore ¶
func (_m *JetStreamContext) DeleteObjectStore(bucket string) error
DeleteObjectStore provides a mock function with given fields: bucket
func (*JetStreamContext) DeleteStream ¶
func (_m *JetStreamContext) DeleteStream(name string, opts ...nats.JSOpt) error
DeleteStream provides a mock function with given fields: name, opts
func (*JetStreamContext) EXPECT ¶
func (_m *JetStreamContext) EXPECT() *JetStreamContext_Expecter
func (*JetStreamContext) GetLastMsg ¶
func (_m *JetStreamContext) GetLastMsg(name string, subject string, opts ...nats.JSOpt) (*nats.RawStreamMsg, error)
GetLastMsg provides a mock function with given fields: name, subject, opts
func (*JetStreamContext) GetMsg ¶
func (_m *JetStreamContext) GetMsg(name string, seq uint64, opts ...nats.JSOpt) (*nats.RawStreamMsg, error)
GetMsg provides a mock function with given fields: name, seq, opts
func (*JetStreamContext) KeyValue ¶
func (_m *JetStreamContext) KeyValue(bucket string) (nats.KeyValue, error)
KeyValue provides a mock function with given fields: bucket
func (*JetStreamContext) KeyValueStoreNames ¶
func (_m *JetStreamContext) KeyValueStoreNames() <-chan string
KeyValueStoreNames provides a mock function with given fields:
func (*JetStreamContext) KeyValueStores ¶
func (_m *JetStreamContext) KeyValueStores() <-chan nats.KeyValueStatus
KeyValueStores provides a mock function with given fields:
func (*JetStreamContext) ObjectStore ¶
func (_m *JetStreamContext) ObjectStore(bucket string) (nats.ObjectStore, error)
ObjectStore provides a mock function with given fields: bucket
func (*JetStreamContext) ObjectStoreNames ¶
func (_m *JetStreamContext) ObjectStoreNames(opts ...nats.ObjectOpt) <-chan string
ObjectStoreNames provides a mock function with given fields: opts
func (*JetStreamContext) ObjectStores ¶
func (_m *JetStreamContext) ObjectStores(opts ...nats.ObjectOpt) <-chan nats.ObjectStoreStatus
ObjectStores provides a mock function with given fields: opts
func (*JetStreamContext) Publish ¶
func (_m *JetStreamContext) Publish(subj string, data []byte, opts ...nats.PubOpt) (*nats.PubAck, error)
Publish provides a mock function with given fields: subj, data, opts
func (*JetStreamContext) PublishAsync ¶
func (_m *JetStreamContext) PublishAsync(subj string, data []byte, opts ...nats.PubOpt) (nats.PubAckFuture, error)
PublishAsync provides a mock function with given fields: subj, data, opts
func (*JetStreamContext) PublishAsyncComplete ¶
func (_m *JetStreamContext) PublishAsyncComplete() <-chan struct{}
PublishAsyncComplete provides a mock function with given fields:
func (*JetStreamContext) PublishAsyncPending ¶
func (_m *JetStreamContext) PublishAsyncPending() int
PublishAsyncPending provides a mock function with given fields:
func (*JetStreamContext) PublishMsg ¶
PublishMsg provides a mock function with given fields: m, opts
func (*JetStreamContext) PublishMsgAsync ¶
func (_m *JetStreamContext) PublishMsgAsync(m *nats.Msg, opts ...nats.PubOpt) (nats.PubAckFuture, error)
PublishMsgAsync provides a mock function with given fields: m, opts
func (*JetStreamContext) PullSubscribe ¶
func (_m *JetStreamContext) PullSubscribe(subj string, durable string, opts ...nats.SubOpt) (*nats.Subscription, error)
PullSubscribe provides a mock function with given fields: subj, durable, opts
func (*JetStreamContext) PurgeStream ¶
func (_m *JetStreamContext) PurgeStream(name string, opts ...nats.JSOpt) error
PurgeStream provides a mock function with given fields: name, opts
func (*JetStreamContext) QueueSubscribe ¶
func (_m *JetStreamContext) QueueSubscribe(subj string, queue string, cb nats.MsgHandler, opts ...nats.SubOpt) (*nats.Subscription, error)
QueueSubscribe provides a mock function with given fields: subj, queue, cb, opts
func (*JetStreamContext) QueueSubscribeSync ¶
func (_m *JetStreamContext) QueueSubscribeSync(subj string, queue string, opts ...nats.SubOpt) (*nats.Subscription, error)
QueueSubscribeSync provides a mock function with given fields: subj, queue, opts
func (*JetStreamContext) SecureDeleteMsg ¶
SecureDeleteMsg provides a mock function with given fields: name, seq, opts
func (*JetStreamContext) StreamInfo ¶
func (_m *JetStreamContext) StreamInfo(stream string, opts ...nats.JSOpt) (*nats.StreamInfo, error)
StreamInfo provides a mock function with given fields: stream, opts
func (*JetStreamContext) StreamNameBySubject ¶
StreamNameBySubject provides a mock function with given fields: _a0, _a1
func (*JetStreamContext) StreamNames ¶
func (_m *JetStreamContext) StreamNames(opts ...nats.JSOpt) <-chan string
StreamNames provides a mock function with given fields: opts
func (*JetStreamContext) Streams ¶
func (_m *JetStreamContext) Streams(opts ...nats.JSOpt) <-chan *nats.StreamInfo
Streams provides a mock function with given fields: opts
func (*JetStreamContext) StreamsInfo ¶
func (_m *JetStreamContext) StreamsInfo(opts ...nats.JSOpt) <-chan *nats.StreamInfo
StreamsInfo provides a mock function with given fields: opts
func (*JetStreamContext) Subscribe ¶
func (_m *JetStreamContext) Subscribe(subj string, cb nats.MsgHandler, opts ...nats.SubOpt) (*nats.Subscription, error)
Subscribe provides a mock function with given fields: subj, cb, opts
func (*JetStreamContext) SubscribeSync ¶
func (_m *JetStreamContext) SubscribeSync(subj string, opts ...nats.SubOpt) (*nats.Subscription, error)
SubscribeSync provides a mock function with given fields: subj, opts
func (*JetStreamContext) UpdateConsumer ¶
func (_m *JetStreamContext) UpdateConsumer(stream string, cfg *nats.ConsumerConfig, opts ...nats.JSOpt) (*nats.ConsumerInfo, error)
UpdateConsumer provides a mock function with given fields: stream, cfg, opts
func (*JetStreamContext) UpdateStream ¶
func (_m *JetStreamContext) UpdateStream(cfg *nats.StreamConfig, opts ...nats.JSOpt) (*nats.StreamInfo, error)
UpdateStream provides a mock function with given fields: cfg, opts
type JetStreamContext_AccountInfo_Call ¶
JetStreamContext_AccountInfo_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'AccountInfo'
func (*JetStreamContext_AccountInfo_Call) Return ¶
func (_c *JetStreamContext_AccountInfo_Call) Return(_a0 *nats.AccountInfo, _a1 error) *JetStreamContext_AccountInfo_Call
func (*JetStreamContext_AccountInfo_Call) Run ¶
func (_c *JetStreamContext_AccountInfo_Call) Run(run func(opts ...nats.JSOpt)) *JetStreamContext_AccountInfo_Call
func (*JetStreamContext_AccountInfo_Call) RunAndReturn ¶
func (_c *JetStreamContext_AccountInfo_Call) RunAndReturn(run func(...nats.JSOpt) (*nats.AccountInfo, error)) *JetStreamContext_AccountInfo_Call
type JetStreamContext_AddConsumer_Call ¶
JetStreamContext_AddConsumer_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'AddConsumer'
func (*JetStreamContext_AddConsumer_Call) Return ¶
func (_c *JetStreamContext_AddConsumer_Call) Return(_a0 *nats.ConsumerInfo, _a1 error) *JetStreamContext_AddConsumer_Call
func (*JetStreamContext_AddConsumer_Call) Run ¶
func (_c *JetStreamContext_AddConsumer_Call) Run(run func(stream string, cfg *nats.ConsumerConfig, opts ...nats.JSOpt)) *JetStreamContext_AddConsumer_Call
func (*JetStreamContext_AddConsumer_Call) RunAndReturn ¶
func (_c *JetStreamContext_AddConsumer_Call) RunAndReturn(run func(string, *nats.ConsumerConfig, ...nats.JSOpt) (*nats.ConsumerInfo, error)) *JetStreamContext_AddConsumer_Call
type JetStreamContext_AddStream_Call ¶
JetStreamContext_AddStream_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'AddStream'
func (*JetStreamContext_AddStream_Call) Return ¶
func (_c *JetStreamContext_AddStream_Call) Return(_a0 *nats.StreamInfo, _a1 error) *JetStreamContext_AddStream_Call
func (*JetStreamContext_AddStream_Call) Run ¶
func (_c *JetStreamContext_AddStream_Call) Run(run func(cfg *nats.StreamConfig, opts ...nats.JSOpt)) *JetStreamContext_AddStream_Call
func (*JetStreamContext_AddStream_Call) RunAndReturn ¶
func (_c *JetStreamContext_AddStream_Call) RunAndReturn(run func(*nats.StreamConfig, ...nats.JSOpt) (*nats.StreamInfo, error)) *JetStreamContext_AddStream_Call
type JetStreamContext_ChanQueueSubscribe_Call ¶
JetStreamContext_ChanQueueSubscribe_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'ChanQueueSubscribe'
func (*JetStreamContext_ChanQueueSubscribe_Call) Return ¶
func (_c *JetStreamContext_ChanQueueSubscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_ChanQueueSubscribe_Call
func (*JetStreamContext_ChanQueueSubscribe_Call) Run ¶
func (_c *JetStreamContext_ChanQueueSubscribe_Call) Run(run func(subj string, queue string, ch chan *nats.Msg, opts ...nats.SubOpt)) *JetStreamContext_ChanQueueSubscribe_Call
func (*JetStreamContext_ChanQueueSubscribe_Call) RunAndReturn ¶
func (_c *JetStreamContext_ChanQueueSubscribe_Call) RunAndReturn(run func(string, string, chan *nats.Msg, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_ChanQueueSubscribe_Call
type JetStreamContext_ChanSubscribe_Call ¶
JetStreamContext_ChanSubscribe_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'ChanSubscribe'
func (*JetStreamContext_ChanSubscribe_Call) Return ¶
func (_c *JetStreamContext_ChanSubscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_ChanSubscribe_Call
func (*JetStreamContext_ChanSubscribe_Call) Run ¶
func (_c *JetStreamContext_ChanSubscribe_Call) Run(run func(subj string, ch chan *nats.Msg, opts ...nats.SubOpt)) *JetStreamContext_ChanSubscribe_Call
func (*JetStreamContext_ChanSubscribe_Call) RunAndReturn ¶
func (_c *JetStreamContext_ChanSubscribe_Call) RunAndReturn(run func(string, chan *nats.Msg, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_ChanSubscribe_Call
type JetStreamContext_ConsumerInfo_Call ¶
JetStreamContext_ConsumerInfo_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'ConsumerInfo'
func (*JetStreamContext_ConsumerInfo_Call) Return ¶
func (_c *JetStreamContext_ConsumerInfo_Call) Return(_a0 *nats.ConsumerInfo, _a1 error) *JetStreamContext_ConsumerInfo_Call
func (*JetStreamContext_ConsumerInfo_Call) Run ¶
func (_c *JetStreamContext_ConsumerInfo_Call) Run(run func(stream string, name string, opts ...nats.JSOpt)) *JetStreamContext_ConsumerInfo_Call
func (*JetStreamContext_ConsumerInfo_Call) RunAndReturn ¶
func (_c *JetStreamContext_ConsumerInfo_Call) RunAndReturn(run func(string, string, ...nats.JSOpt) (*nats.ConsumerInfo, error)) *JetStreamContext_ConsumerInfo_Call
type JetStreamContext_ConsumerNames_Call ¶
JetStreamContext_ConsumerNames_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'ConsumerNames'
func (*JetStreamContext_ConsumerNames_Call) Return ¶
func (_c *JetStreamContext_ConsumerNames_Call) Return(_a0 <-chan string) *JetStreamContext_ConsumerNames_Call
func (*JetStreamContext_ConsumerNames_Call) Run ¶
func (_c *JetStreamContext_ConsumerNames_Call) Run(run func(stream string, opts ...nats.JSOpt)) *JetStreamContext_ConsumerNames_Call
func (*JetStreamContext_ConsumerNames_Call) RunAndReturn ¶
func (_c *JetStreamContext_ConsumerNames_Call) RunAndReturn(run func(string, ...nats.JSOpt) <-chan string) *JetStreamContext_ConsumerNames_Call
type JetStreamContext_ConsumersInfo_Call ¶
JetStreamContext_ConsumersInfo_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'ConsumersInfo'
func (*JetStreamContext_ConsumersInfo_Call) Return ¶
func (_c *JetStreamContext_ConsumersInfo_Call) Return(_a0 <-chan *nats.ConsumerInfo) *JetStreamContext_ConsumersInfo_Call
func (*JetStreamContext_ConsumersInfo_Call) Run ¶
func (_c *JetStreamContext_ConsumersInfo_Call) Run(run func(stream string, opts ...nats.JSOpt)) *JetStreamContext_ConsumersInfo_Call
func (*JetStreamContext_ConsumersInfo_Call) RunAndReturn ¶
func (_c *JetStreamContext_ConsumersInfo_Call) RunAndReturn(run func(string, ...nats.JSOpt) <-chan *nats.ConsumerInfo) *JetStreamContext_ConsumersInfo_Call
type JetStreamContext_Consumers_Call ¶
JetStreamContext_Consumers_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Consumers'
func (*JetStreamContext_Consumers_Call) Return ¶
func (_c *JetStreamContext_Consumers_Call) Return(_a0 <-chan *nats.ConsumerInfo) *JetStreamContext_Consumers_Call
func (*JetStreamContext_Consumers_Call) Run ¶
func (_c *JetStreamContext_Consumers_Call) Run(run func(stream string, opts ...nats.JSOpt)) *JetStreamContext_Consumers_Call
func (*JetStreamContext_Consumers_Call) RunAndReturn ¶
func (_c *JetStreamContext_Consumers_Call) RunAndReturn(run func(string, ...nats.JSOpt) <-chan *nats.ConsumerInfo) *JetStreamContext_Consumers_Call
type JetStreamContext_CreateKeyValue_Call ¶
JetStreamContext_CreateKeyValue_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'CreateKeyValue'
func (*JetStreamContext_CreateKeyValue_Call) Return ¶
func (_c *JetStreamContext_CreateKeyValue_Call) Return(_a0 nats.KeyValue, _a1 error) *JetStreamContext_CreateKeyValue_Call
func (*JetStreamContext_CreateKeyValue_Call) Run ¶
func (_c *JetStreamContext_CreateKeyValue_Call) Run(run func(cfg *nats.KeyValueConfig)) *JetStreamContext_CreateKeyValue_Call
func (*JetStreamContext_CreateKeyValue_Call) RunAndReturn ¶
func (_c *JetStreamContext_CreateKeyValue_Call) RunAndReturn(run func(*nats.KeyValueConfig) (nats.KeyValue, error)) *JetStreamContext_CreateKeyValue_Call
type JetStreamContext_CreateObjectStore_Call ¶
JetStreamContext_CreateObjectStore_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'CreateObjectStore'
func (*JetStreamContext_CreateObjectStore_Call) Return ¶
func (_c *JetStreamContext_CreateObjectStore_Call) Return(_a0 nats.ObjectStore, _a1 error) *JetStreamContext_CreateObjectStore_Call
func (*JetStreamContext_CreateObjectStore_Call) Run ¶
func (_c *JetStreamContext_CreateObjectStore_Call) Run(run func(cfg *nats.ObjectStoreConfig)) *JetStreamContext_CreateObjectStore_Call
func (*JetStreamContext_CreateObjectStore_Call) RunAndReturn ¶
func (_c *JetStreamContext_CreateObjectStore_Call) RunAndReturn(run func(*nats.ObjectStoreConfig) (nats.ObjectStore, error)) *JetStreamContext_CreateObjectStore_Call
type JetStreamContext_DeleteConsumer_Call ¶
JetStreamContext_DeleteConsumer_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'DeleteConsumer'
func (*JetStreamContext_DeleteConsumer_Call) Return ¶
func (_c *JetStreamContext_DeleteConsumer_Call) Return(_a0 error) *JetStreamContext_DeleteConsumer_Call
func (*JetStreamContext_DeleteConsumer_Call) Run ¶
func (_c *JetStreamContext_DeleteConsumer_Call) Run(run func(stream string, consumer string, opts ...nats.JSOpt)) *JetStreamContext_DeleteConsumer_Call
func (*JetStreamContext_DeleteConsumer_Call) RunAndReturn ¶
func (_c *JetStreamContext_DeleteConsumer_Call) RunAndReturn(run func(string, string, ...nats.JSOpt) error) *JetStreamContext_DeleteConsumer_Call
type JetStreamContext_DeleteKeyValue_Call ¶
JetStreamContext_DeleteKeyValue_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'DeleteKeyValue'
func (*JetStreamContext_DeleteKeyValue_Call) Return ¶
func (_c *JetStreamContext_DeleteKeyValue_Call) Return(_a0 error) *JetStreamContext_DeleteKeyValue_Call
func (*JetStreamContext_DeleteKeyValue_Call) Run ¶
func (_c *JetStreamContext_DeleteKeyValue_Call) Run(run func(bucket string)) *JetStreamContext_DeleteKeyValue_Call
func (*JetStreamContext_DeleteKeyValue_Call) RunAndReturn ¶
func (_c *JetStreamContext_DeleteKeyValue_Call) RunAndReturn(run func(string) error) *JetStreamContext_DeleteKeyValue_Call
type JetStreamContext_DeleteMsg_Call ¶
JetStreamContext_DeleteMsg_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'DeleteMsg'
func (*JetStreamContext_DeleteMsg_Call) Return ¶
func (_c *JetStreamContext_DeleteMsg_Call) Return(_a0 error) *JetStreamContext_DeleteMsg_Call
func (*JetStreamContext_DeleteMsg_Call) Run ¶
func (_c *JetStreamContext_DeleteMsg_Call) Run(run func(name string, seq uint64, opts ...nats.JSOpt)) *JetStreamContext_DeleteMsg_Call
func (*JetStreamContext_DeleteMsg_Call) RunAndReturn ¶
func (_c *JetStreamContext_DeleteMsg_Call) RunAndReturn(run func(string, uint64, ...nats.JSOpt) error) *JetStreamContext_DeleteMsg_Call
type JetStreamContext_DeleteObjectStore_Call ¶
JetStreamContext_DeleteObjectStore_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'DeleteObjectStore'
func (*JetStreamContext_DeleteObjectStore_Call) Return ¶
func (_c *JetStreamContext_DeleteObjectStore_Call) Return(_a0 error) *JetStreamContext_DeleteObjectStore_Call
func (*JetStreamContext_DeleteObjectStore_Call) Run ¶
func (_c *JetStreamContext_DeleteObjectStore_Call) Run(run func(bucket string)) *JetStreamContext_DeleteObjectStore_Call
func (*JetStreamContext_DeleteObjectStore_Call) RunAndReturn ¶
func (_c *JetStreamContext_DeleteObjectStore_Call) RunAndReturn(run func(string) error) *JetStreamContext_DeleteObjectStore_Call
type JetStreamContext_DeleteStream_Call ¶
JetStreamContext_DeleteStream_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'DeleteStream'
func (*JetStreamContext_DeleteStream_Call) Return ¶
func (_c *JetStreamContext_DeleteStream_Call) Return(_a0 error) *JetStreamContext_DeleteStream_Call
func (*JetStreamContext_DeleteStream_Call) Run ¶
func (_c *JetStreamContext_DeleteStream_Call) Run(run func(name string, opts ...nats.JSOpt)) *JetStreamContext_DeleteStream_Call
func (*JetStreamContext_DeleteStream_Call) RunAndReturn ¶
func (_c *JetStreamContext_DeleteStream_Call) RunAndReturn(run func(string, ...nats.JSOpt) error) *JetStreamContext_DeleteStream_Call
type JetStreamContext_Expecter ¶
type JetStreamContext_Expecter struct {
// contains filtered or unexported fields
}
func (*JetStreamContext_Expecter) AccountInfo ¶
func (_e *JetStreamContext_Expecter) AccountInfo(opts ...interface{}) *JetStreamContext_AccountInfo_Call
AccountInfo is a helper method to define mock.On call
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) AddConsumer ¶
func (_e *JetStreamContext_Expecter) AddConsumer(stream interface{}, cfg interface{}, opts ...interface{}) *JetStreamContext_AddConsumer_Call
AddConsumer is a helper method to define mock.On call
- stream string
- cfg *nats.ConsumerConfig
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) AddStream ¶
func (_e *JetStreamContext_Expecter) AddStream(cfg interface{}, opts ...interface{}) *JetStreamContext_AddStream_Call
AddStream is a helper method to define mock.On call
- cfg *nats.StreamConfig
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) ChanQueueSubscribe ¶
func (_e *JetStreamContext_Expecter) ChanQueueSubscribe(subj interface{}, queue interface{}, ch interface{}, opts ...interface{}) *JetStreamContext_ChanQueueSubscribe_Call
ChanQueueSubscribe is a helper method to define mock.On call
- subj string
- queue string
- ch chan *nats.Msg
- opts ...nats.SubOpt
func (*JetStreamContext_Expecter) ChanSubscribe ¶
func (_e *JetStreamContext_Expecter) ChanSubscribe(subj interface{}, ch interface{}, opts ...interface{}) *JetStreamContext_ChanSubscribe_Call
ChanSubscribe is a helper method to define mock.On call
- subj string
- ch chan *nats.Msg
- opts ...nats.SubOpt
func (*JetStreamContext_Expecter) ConsumerInfo ¶
func (_e *JetStreamContext_Expecter) ConsumerInfo(stream interface{}, name interface{}, opts ...interface{}) *JetStreamContext_ConsumerInfo_Call
ConsumerInfo is a helper method to define mock.On call
- stream string
- name string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) ConsumerNames ¶
func (_e *JetStreamContext_Expecter) ConsumerNames(stream interface{}, opts ...interface{}) *JetStreamContext_ConsumerNames_Call
ConsumerNames is a helper method to define mock.On call
- stream string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) Consumers ¶
func (_e *JetStreamContext_Expecter) Consumers(stream interface{}, opts ...interface{}) *JetStreamContext_Consumers_Call
Consumers is a helper method to define mock.On call
- stream string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) ConsumersInfo ¶
func (_e *JetStreamContext_Expecter) ConsumersInfo(stream interface{}, opts ...interface{}) *JetStreamContext_ConsumersInfo_Call
ConsumersInfo is a helper method to define mock.On call
- stream string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) CreateKeyValue ¶
func (_e *JetStreamContext_Expecter) CreateKeyValue(cfg interface{}) *JetStreamContext_CreateKeyValue_Call
CreateKeyValue is a helper method to define mock.On call
- cfg *nats.KeyValueConfig
func (*JetStreamContext_Expecter) CreateObjectStore ¶
func (_e *JetStreamContext_Expecter) CreateObjectStore(cfg interface{}) *JetStreamContext_CreateObjectStore_Call
CreateObjectStore is a helper method to define mock.On call
- cfg *nats.ObjectStoreConfig
func (*JetStreamContext_Expecter) DeleteConsumer ¶
func (_e *JetStreamContext_Expecter) DeleteConsumer(stream interface{}, consumer interface{}, opts ...interface{}) *JetStreamContext_DeleteConsumer_Call
DeleteConsumer is a helper method to define mock.On call
- stream string
- consumer string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) DeleteKeyValue ¶
func (_e *JetStreamContext_Expecter) DeleteKeyValue(bucket interface{}) *JetStreamContext_DeleteKeyValue_Call
DeleteKeyValue is a helper method to define mock.On call
- bucket string
func (*JetStreamContext_Expecter) DeleteMsg ¶
func (_e *JetStreamContext_Expecter) DeleteMsg(name interface{}, seq interface{}, opts ...interface{}) *JetStreamContext_DeleteMsg_Call
DeleteMsg is a helper method to define mock.On call
- name string
- seq uint64
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) DeleteObjectStore ¶
func (_e *JetStreamContext_Expecter) DeleteObjectStore(bucket interface{}) *JetStreamContext_DeleteObjectStore_Call
DeleteObjectStore is a helper method to define mock.On call
- bucket string
func (*JetStreamContext_Expecter) DeleteStream ¶
func (_e *JetStreamContext_Expecter) DeleteStream(name interface{}, opts ...interface{}) *JetStreamContext_DeleteStream_Call
DeleteStream is a helper method to define mock.On call
- name string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) GetLastMsg ¶
func (_e *JetStreamContext_Expecter) GetLastMsg(name interface{}, subject interface{}, opts ...interface{}) *JetStreamContext_GetLastMsg_Call
GetLastMsg is a helper method to define mock.On call
- name string
- subject string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) GetMsg ¶
func (_e *JetStreamContext_Expecter) GetMsg(name interface{}, seq interface{}, opts ...interface{}) *JetStreamContext_GetMsg_Call
GetMsg is a helper method to define mock.On call
- name string
- seq uint64
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) KeyValue ¶
func (_e *JetStreamContext_Expecter) KeyValue(bucket interface{}) *JetStreamContext_KeyValue_Call
KeyValue is a helper method to define mock.On call
- bucket string
func (*JetStreamContext_Expecter) KeyValueStoreNames ¶
func (_e *JetStreamContext_Expecter) KeyValueStoreNames() *JetStreamContext_KeyValueStoreNames_Call
KeyValueStoreNames is a helper method to define mock.On call
func (*JetStreamContext_Expecter) KeyValueStores ¶
func (_e *JetStreamContext_Expecter) KeyValueStores() *JetStreamContext_KeyValueStores_Call
KeyValueStores is a helper method to define mock.On call
func (*JetStreamContext_Expecter) ObjectStore ¶
func (_e *JetStreamContext_Expecter) ObjectStore(bucket interface{}) *JetStreamContext_ObjectStore_Call
ObjectStore is a helper method to define mock.On call
- bucket string
func (*JetStreamContext_Expecter) ObjectStoreNames ¶
func (_e *JetStreamContext_Expecter) ObjectStoreNames(opts ...interface{}) *JetStreamContext_ObjectStoreNames_Call
ObjectStoreNames is a helper method to define mock.On call
- opts ...nats.ObjectOpt
func (*JetStreamContext_Expecter) ObjectStores ¶
func (_e *JetStreamContext_Expecter) ObjectStores(opts ...interface{}) *JetStreamContext_ObjectStores_Call
ObjectStores is a helper method to define mock.On call
- opts ...nats.ObjectOpt
func (*JetStreamContext_Expecter) Publish ¶
func (_e *JetStreamContext_Expecter) Publish(subj interface{}, data interface{}, opts ...interface{}) *JetStreamContext_Publish_Call
Publish is a helper method to define mock.On call
- subj string
- data []byte
- opts ...nats.PubOpt
func (*JetStreamContext_Expecter) PublishAsync ¶
func (_e *JetStreamContext_Expecter) PublishAsync(subj interface{}, data interface{}, opts ...interface{}) *JetStreamContext_PublishAsync_Call
PublishAsync is a helper method to define mock.On call
- subj string
- data []byte
- opts ...nats.PubOpt
func (*JetStreamContext_Expecter) PublishAsyncComplete ¶
func (_e *JetStreamContext_Expecter) PublishAsyncComplete() *JetStreamContext_PublishAsyncComplete_Call
PublishAsyncComplete is a helper method to define mock.On call
func (*JetStreamContext_Expecter) PublishAsyncPending ¶
func (_e *JetStreamContext_Expecter) PublishAsyncPending() *JetStreamContext_PublishAsyncPending_Call
PublishAsyncPending is a helper method to define mock.On call
func (*JetStreamContext_Expecter) PublishMsg ¶
func (_e *JetStreamContext_Expecter) PublishMsg(m interface{}, opts ...interface{}) *JetStreamContext_PublishMsg_Call
PublishMsg is a helper method to define mock.On call
- m *nats.Msg
- opts ...nats.PubOpt
func (*JetStreamContext_Expecter) PublishMsgAsync ¶
func (_e *JetStreamContext_Expecter) PublishMsgAsync(m interface{}, opts ...interface{}) *JetStreamContext_PublishMsgAsync_Call
PublishMsgAsync is a helper method to define mock.On call
- m *nats.Msg
- opts ...nats.PubOpt
func (*JetStreamContext_Expecter) PullSubscribe ¶
func (_e *JetStreamContext_Expecter) PullSubscribe(subj interface{}, durable interface{}, opts ...interface{}) *JetStreamContext_PullSubscribe_Call
PullSubscribe is a helper method to define mock.On call
- subj string
- durable string
- opts ...nats.SubOpt
func (*JetStreamContext_Expecter) PurgeStream ¶
func (_e *JetStreamContext_Expecter) PurgeStream(name interface{}, opts ...interface{}) *JetStreamContext_PurgeStream_Call
PurgeStream is a helper method to define mock.On call
- name string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) QueueSubscribe ¶
func (_e *JetStreamContext_Expecter) QueueSubscribe(subj interface{}, queue interface{}, cb interface{}, opts ...interface{}) *JetStreamContext_QueueSubscribe_Call
QueueSubscribe is a helper method to define mock.On call
- subj string
- queue string
- cb nats.MsgHandler
- opts ...nats.SubOpt
func (*JetStreamContext_Expecter) QueueSubscribeSync ¶
func (_e *JetStreamContext_Expecter) QueueSubscribeSync(subj interface{}, queue interface{}, opts ...interface{}) *JetStreamContext_QueueSubscribeSync_Call
QueueSubscribeSync is a helper method to define mock.On call
- subj string
- queue string
- opts ...nats.SubOpt
func (*JetStreamContext_Expecter) SecureDeleteMsg ¶
func (_e *JetStreamContext_Expecter) SecureDeleteMsg(name interface{}, seq interface{}, opts ...interface{}) *JetStreamContext_SecureDeleteMsg_Call
SecureDeleteMsg is a helper method to define mock.On call
- name string
- seq uint64
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) StreamInfo ¶
func (_e *JetStreamContext_Expecter) StreamInfo(stream interface{}, opts ...interface{}) *JetStreamContext_StreamInfo_Call
StreamInfo is a helper method to define mock.On call
- stream string
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) StreamNameBySubject ¶
func (_e *JetStreamContext_Expecter) StreamNameBySubject(_a0 interface{}, _a1 ...interface{}) *JetStreamContext_StreamNameBySubject_Call
StreamNameBySubject is a helper method to define mock.On call
- _a0 string
- _a1 ...nats.JSOpt
func (*JetStreamContext_Expecter) StreamNames ¶
func (_e *JetStreamContext_Expecter) StreamNames(opts ...interface{}) *JetStreamContext_StreamNames_Call
StreamNames is a helper method to define mock.On call
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) Streams ¶
func (_e *JetStreamContext_Expecter) Streams(opts ...interface{}) *JetStreamContext_Streams_Call
Streams is a helper method to define mock.On call
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) StreamsInfo ¶
func (_e *JetStreamContext_Expecter) StreamsInfo(opts ...interface{}) *JetStreamContext_StreamsInfo_Call
StreamsInfo is a helper method to define mock.On call
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) Subscribe ¶
func (_e *JetStreamContext_Expecter) Subscribe(subj interface{}, cb interface{}, opts ...interface{}) *JetStreamContext_Subscribe_Call
Subscribe is a helper method to define mock.On call
- subj string
- cb nats.MsgHandler
- opts ...nats.SubOpt
func (*JetStreamContext_Expecter) SubscribeSync ¶
func (_e *JetStreamContext_Expecter) SubscribeSync(subj interface{}, opts ...interface{}) *JetStreamContext_SubscribeSync_Call
SubscribeSync is a helper method to define mock.On call
- subj string
- opts ...nats.SubOpt
func (*JetStreamContext_Expecter) UpdateConsumer ¶
func (_e *JetStreamContext_Expecter) UpdateConsumer(stream interface{}, cfg interface{}, opts ...interface{}) *JetStreamContext_UpdateConsumer_Call
UpdateConsumer is a helper method to define mock.On call
- stream string
- cfg *nats.ConsumerConfig
- opts ...nats.JSOpt
func (*JetStreamContext_Expecter) UpdateStream ¶
func (_e *JetStreamContext_Expecter) UpdateStream(cfg interface{}, opts ...interface{}) *JetStreamContext_UpdateStream_Call
UpdateStream is a helper method to define mock.On call
- cfg *nats.StreamConfig
- opts ...nats.JSOpt
type JetStreamContext_GetLastMsg_Call ¶
JetStreamContext_GetLastMsg_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetLastMsg'
func (*JetStreamContext_GetLastMsg_Call) Return ¶
func (_c *JetStreamContext_GetLastMsg_Call) Return(_a0 *nats.RawStreamMsg, _a1 error) *JetStreamContext_GetLastMsg_Call
func (*JetStreamContext_GetLastMsg_Call) Run ¶
func (_c *JetStreamContext_GetLastMsg_Call) Run(run func(name string, subject string, opts ...nats.JSOpt)) *JetStreamContext_GetLastMsg_Call
func (*JetStreamContext_GetLastMsg_Call) RunAndReturn ¶
func (_c *JetStreamContext_GetLastMsg_Call) RunAndReturn(run func(string, string, ...nats.JSOpt) (*nats.RawStreamMsg, error)) *JetStreamContext_GetLastMsg_Call
type JetStreamContext_GetMsg_Call ¶
JetStreamContext_GetMsg_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetMsg'
func (*JetStreamContext_GetMsg_Call) Return ¶
func (_c *JetStreamContext_GetMsg_Call) Return(_a0 *nats.RawStreamMsg, _a1 error) *JetStreamContext_GetMsg_Call
func (*JetStreamContext_GetMsg_Call) Run ¶
func (_c *JetStreamContext_GetMsg_Call) Run(run func(name string, seq uint64, opts ...nats.JSOpt)) *JetStreamContext_GetMsg_Call
func (*JetStreamContext_GetMsg_Call) RunAndReturn ¶
func (_c *JetStreamContext_GetMsg_Call) RunAndReturn(run func(string, uint64, ...nats.JSOpt) (*nats.RawStreamMsg, error)) *JetStreamContext_GetMsg_Call
type JetStreamContext_KeyValueStoreNames_Call ¶
JetStreamContext_KeyValueStoreNames_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'KeyValueStoreNames'
func (*JetStreamContext_KeyValueStoreNames_Call) Return ¶
func (_c *JetStreamContext_KeyValueStoreNames_Call) Return(_a0 <-chan string) *JetStreamContext_KeyValueStoreNames_Call
func (*JetStreamContext_KeyValueStoreNames_Call) Run ¶
func (_c *JetStreamContext_KeyValueStoreNames_Call) Run(run func()) *JetStreamContext_KeyValueStoreNames_Call
func (*JetStreamContext_KeyValueStoreNames_Call) RunAndReturn ¶
func (_c *JetStreamContext_KeyValueStoreNames_Call) RunAndReturn(run func() <-chan string) *JetStreamContext_KeyValueStoreNames_Call
type JetStreamContext_KeyValueStores_Call ¶
JetStreamContext_KeyValueStores_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'KeyValueStores'
func (*JetStreamContext_KeyValueStores_Call) Return ¶
func (_c *JetStreamContext_KeyValueStores_Call) Return(_a0 <-chan nats.KeyValueStatus) *JetStreamContext_KeyValueStores_Call
func (*JetStreamContext_KeyValueStores_Call) Run ¶
func (_c *JetStreamContext_KeyValueStores_Call) Run(run func()) *JetStreamContext_KeyValueStores_Call
func (*JetStreamContext_KeyValueStores_Call) RunAndReturn ¶
func (_c *JetStreamContext_KeyValueStores_Call) RunAndReturn(run func() <-chan nats.KeyValueStatus) *JetStreamContext_KeyValueStores_Call
type JetStreamContext_KeyValue_Call ¶
JetStreamContext_KeyValue_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'KeyValue'
func (*JetStreamContext_KeyValue_Call) Return ¶
func (_c *JetStreamContext_KeyValue_Call) Return(_a0 nats.KeyValue, _a1 error) *JetStreamContext_KeyValue_Call
func (*JetStreamContext_KeyValue_Call) Run ¶
func (_c *JetStreamContext_KeyValue_Call) Run(run func(bucket string)) *JetStreamContext_KeyValue_Call
func (*JetStreamContext_KeyValue_Call) RunAndReturn ¶
func (_c *JetStreamContext_KeyValue_Call) RunAndReturn(run func(string) (nats.KeyValue, error)) *JetStreamContext_KeyValue_Call
type JetStreamContext_ObjectStoreNames_Call ¶
JetStreamContext_ObjectStoreNames_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'ObjectStoreNames'
func (*JetStreamContext_ObjectStoreNames_Call) Return ¶
func (_c *JetStreamContext_ObjectStoreNames_Call) Return(_a0 <-chan string) *JetStreamContext_ObjectStoreNames_Call
func (*JetStreamContext_ObjectStoreNames_Call) Run ¶
func (_c *JetStreamContext_ObjectStoreNames_Call) Run(run func(opts ...nats.ObjectOpt)) *JetStreamContext_ObjectStoreNames_Call
func (*JetStreamContext_ObjectStoreNames_Call) RunAndReturn ¶
func (_c *JetStreamContext_ObjectStoreNames_Call) RunAndReturn(run func(...nats.ObjectOpt) <-chan string) *JetStreamContext_ObjectStoreNames_Call
type JetStreamContext_ObjectStore_Call ¶
JetStreamContext_ObjectStore_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'ObjectStore'
func (*JetStreamContext_ObjectStore_Call) Return ¶
func (_c *JetStreamContext_ObjectStore_Call) Return(_a0 nats.ObjectStore, _a1 error) *JetStreamContext_ObjectStore_Call
func (*JetStreamContext_ObjectStore_Call) Run ¶
func (_c *JetStreamContext_ObjectStore_Call) Run(run func(bucket string)) *JetStreamContext_ObjectStore_Call
func (*JetStreamContext_ObjectStore_Call) RunAndReturn ¶
func (_c *JetStreamContext_ObjectStore_Call) RunAndReturn(run func(string) (nats.ObjectStore, error)) *JetStreamContext_ObjectStore_Call
type JetStreamContext_ObjectStores_Call ¶
JetStreamContext_ObjectStores_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'ObjectStores'
func (*JetStreamContext_ObjectStores_Call) Return ¶
func (_c *JetStreamContext_ObjectStores_Call) Return(_a0 <-chan nats.ObjectStoreStatus) *JetStreamContext_ObjectStores_Call
func (*JetStreamContext_ObjectStores_Call) Run ¶
func (_c *JetStreamContext_ObjectStores_Call) Run(run func(opts ...nats.ObjectOpt)) *JetStreamContext_ObjectStores_Call
func (*JetStreamContext_ObjectStores_Call) RunAndReturn ¶
func (_c *JetStreamContext_ObjectStores_Call) RunAndReturn(run func(...nats.ObjectOpt) <-chan nats.ObjectStoreStatus) *JetStreamContext_ObjectStores_Call
type JetStreamContext_PublishAsyncComplete_Call ¶
JetStreamContext_PublishAsyncComplete_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'PublishAsyncComplete'
func (*JetStreamContext_PublishAsyncComplete_Call) Return ¶
func (_c *JetStreamContext_PublishAsyncComplete_Call) Return(_a0 <-chan struct{}) *JetStreamContext_PublishAsyncComplete_Call
func (*JetStreamContext_PublishAsyncComplete_Call) Run ¶
func (_c *JetStreamContext_PublishAsyncComplete_Call) Run(run func()) *JetStreamContext_PublishAsyncComplete_Call
func (*JetStreamContext_PublishAsyncComplete_Call) RunAndReturn ¶
func (_c *JetStreamContext_PublishAsyncComplete_Call) RunAndReturn(run func() <-chan struct{}) *JetStreamContext_PublishAsyncComplete_Call
type JetStreamContext_PublishAsyncPending_Call ¶
JetStreamContext_PublishAsyncPending_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'PublishAsyncPending'
func (*JetStreamContext_PublishAsyncPending_Call) Return ¶
func (_c *JetStreamContext_PublishAsyncPending_Call) Return(_a0 int) *JetStreamContext_PublishAsyncPending_Call
func (*JetStreamContext_PublishAsyncPending_Call) Run ¶
func (_c *JetStreamContext_PublishAsyncPending_Call) Run(run func()) *JetStreamContext_PublishAsyncPending_Call
func (*JetStreamContext_PublishAsyncPending_Call) RunAndReturn ¶
func (_c *JetStreamContext_PublishAsyncPending_Call) RunAndReturn(run func() int) *JetStreamContext_PublishAsyncPending_Call
type JetStreamContext_PublishAsync_Call ¶
JetStreamContext_PublishAsync_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'PublishAsync'
func (*JetStreamContext_PublishAsync_Call) Return ¶
func (_c *JetStreamContext_PublishAsync_Call) Return(_a0 nats.PubAckFuture, _a1 error) *JetStreamContext_PublishAsync_Call
func (*JetStreamContext_PublishAsync_Call) Run ¶
func (_c *JetStreamContext_PublishAsync_Call) Run(run func(subj string, data []byte, opts ...nats.PubOpt)) *JetStreamContext_PublishAsync_Call
func (*JetStreamContext_PublishAsync_Call) RunAndReturn ¶
func (_c *JetStreamContext_PublishAsync_Call) RunAndReturn(run func(string, []byte, ...nats.PubOpt) (nats.PubAckFuture, error)) *JetStreamContext_PublishAsync_Call
type JetStreamContext_PublishMsgAsync_Call ¶
JetStreamContext_PublishMsgAsync_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'PublishMsgAsync'
func (*JetStreamContext_PublishMsgAsync_Call) Return ¶
func (_c *JetStreamContext_PublishMsgAsync_Call) Return(_a0 nats.PubAckFuture, _a1 error) *JetStreamContext_PublishMsgAsync_Call
func (*JetStreamContext_PublishMsgAsync_Call) Run ¶
func (_c *JetStreamContext_PublishMsgAsync_Call) Run(run func(m *nats.Msg, opts ...nats.PubOpt)) *JetStreamContext_PublishMsgAsync_Call
func (*JetStreamContext_PublishMsgAsync_Call) RunAndReturn ¶
func (_c *JetStreamContext_PublishMsgAsync_Call) RunAndReturn(run func(*nats.Msg, ...nats.PubOpt) (nats.PubAckFuture, error)) *JetStreamContext_PublishMsgAsync_Call
type JetStreamContext_PublishMsg_Call ¶
JetStreamContext_PublishMsg_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'PublishMsg'
func (*JetStreamContext_PublishMsg_Call) Return ¶
func (_c *JetStreamContext_PublishMsg_Call) Return(_a0 *nats.PubAck, _a1 error) *JetStreamContext_PublishMsg_Call
func (*JetStreamContext_PublishMsg_Call) Run ¶
func (_c *JetStreamContext_PublishMsg_Call) Run(run func(m *nats.Msg, opts ...nats.PubOpt)) *JetStreamContext_PublishMsg_Call
func (*JetStreamContext_PublishMsg_Call) RunAndReturn ¶
func (_c *JetStreamContext_PublishMsg_Call) RunAndReturn(run func(*nats.Msg, ...nats.PubOpt) (*nats.PubAck, error)) *JetStreamContext_PublishMsg_Call
type JetStreamContext_Publish_Call ¶
JetStreamContext_Publish_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Publish'
func (*JetStreamContext_Publish_Call) Return ¶
func (_c *JetStreamContext_Publish_Call) Return(_a0 *nats.PubAck, _a1 error) *JetStreamContext_Publish_Call
func (*JetStreamContext_Publish_Call) Run ¶
func (_c *JetStreamContext_Publish_Call) Run(run func(subj string, data []byte, opts ...nats.PubOpt)) *JetStreamContext_Publish_Call
func (*JetStreamContext_Publish_Call) RunAndReturn ¶
func (_c *JetStreamContext_Publish_Call) RunAndReturn(run func(string, []byte, ...nats.PubOpt) (*nats.PubAck, error)) *JetStreamContext_Publish_Call
type JetStreamContext_PullSubscribe_Call ¶
JetStreamContext_PullSubscribe_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'PullSubscribe'
func (*JetStreamContext_PullSubscribe_Call) Return ¶
func (_c *JetStreamContext_PullSubscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_PullSubscribe_Call
func (*JetStreamContext_PullSubscribe_Call) Run ¶
func (_c *JetStreamContext_PullSubscribe_Call) Run(run func(subj string, durable string, opts ...nats.SubOpt)) *JetStreamContext_PullSubscribe_Call
func (*JetStreamContext_PullSubscribe_Call) RunAndReturn ¶
func (_c *JetStreamContext_PullSubscribe_Call) RunAndReturn(run func(string, string, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_PullSubscribe_Call
type JetStreamContext_PurgeStream_Call ¶
JetStreamContext_PurgeStream_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'PurgeStream'
func (*JetStreamContext_PurgeStream_Call) Return ¶
func (_c *JetStreamContext_PurgeStream_Call) Return(_a0 error) *JetStreamContext_PurgeStream_Call
func (*JetStreamContext_PurgeStream_Call) Run ¶
func (_c *JetStreamContext_PurgeStream_Call) Run(run func(name string, opts ...nats.JSOpt)) *JetStreamContext_PurgeStream_Call
func (*JetStreamContext_PurgeStream_Call) RunAndReturn ¶
func (_c *JetStreamContext_PurgeStream_Call) RunAndReturn(run func(string, ...nats.JSOpt) error) *JetStreamContext_PurgeStream_Call
type JetStreamContext_QueueSubscribeSync_Call ¶
JetStreamContext_QueueSubscribeSync_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'QueueSubscribeSync'
func (*JetStreamContext_QueueSubscribeSync_Call) Return ¶
func (_c *JetStreamContext_QueueSubscribeSync_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_QueueSubscribeSync_Call
func (*JetStreamContext_QueueSubscribeSync_Call) Run ¶
func (_c *JetStreamContext_QueueSubscribeSync_Call) Run(run func(subj string, queue string, opts ...nats.SubOpt)) *JetStreamContext_QueueSubscribeSync_Call
func (*JetStreamContext_QueueSubscribeSync_Call) RunAndReturn ¶
func (_c *JetStreamContext_QueueSubscribeSync_Call) RunAndReturn(run func(string, string, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_QueueSubscribeSync_Call
type JetStreamContext_QueueSubscribe_Call ¶
JetStreamContext_QueueSubscribe_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'QueueSubscribe'
func (*JetStreamContext_QueueSubscribe_Call) Return ¶
func (_c *JetStreamContext_QueueSubscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_QueueSubscribe_Call
func (*JetStreamContext_QueueSubscribe_Call) Run ¶
func (_c *JetStreamContext_QueueSubscribe_Call) Run(run func(subj string, queue string, cb nats.MsgHandler, opts ...nats.SubOpt)) *JetStreamContext_QueueSubscribe_Call
func (*JetStreamContext_QueueSubscribe_Call) RunAndReturn ¶
func (_c *JetStreamContext_QueueSubscribe_Call) RunAndReturn(run func(string, string, nats.MsgHandler, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_QueueSubscribe_Call
type JetStreamContext_SecureDeleteMsg_Call ¶
JetStreamContext_SecureDeleteMsg_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'SecureDeleteMsg'
func (*JetStreamContext_SecureDeleteMsg_Call) Return ¶
func (_c *JetStreamContext_SecureDeleteMsg_Call) Return(_a0 error) *JetStreamContext_SecureDeleteMsg_Call
func (*JetStreamContext_SecureDeleteMsg_Call) Run ¶
func (_c *JetStreamContext_SecureDeleteMsg_Call) Run(run func(name string, seq uint64, opts ...nats.JSOpt)) *JetStreamContext_SecureDeleteMsg_Call
func (*JetStreamContext_SecureDeleteMsg_Call) RunAndReturn ¶
func (_c *JetStreamContext_SecureDeleteMsg_Call) RunAndReturn(run func(string, uint64, ...nats.JSOpt) error) *JetStreamContext_SecureDeleteMsg_Call
type JetStreamContext_StreamInfo_Call ¶
JetStreamContext_StreamInfo_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'StreamInfo'
func (*JetStreamContext_StreamInfo_Call) Return ¶
func (_c *JetStreamContext_StreamInfo_Call) Return(_a0 *nats.StreamInfo, _a1 error) *JetStreamContext_StreamInfo_Call
func (*JetStreamContext_StreamInfo_Call) Run ¶
func (_c *JetStreamContext_StreamInfo_Call) Run(run func(stream string, opts ...nats.JSOpt)) *JetStreamContext_StreamInfo_Call
func (*JetStreamContext_StreamInfo_Call) RunAndReturn ¶
func (_c *JetStreamContext_StreamInfo_Call) RunAndReturn(run func(string, ...nats.JSOpt) (*nats.StreamInfo, error)) *JetStreamContext_StreamInfo_Call
type JetStreamContext_StreamNameBySubject_Call ¶
JetStreamContext_StreamNameBySubject_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'StreamNameBySubject'
func (*JetStreamContext_StreamNameBySubject_Call) Return ¶
func (_c *JetStreamContext_StreamNameBySubject_Call) Return(_a0 string, _a1 error) *JetStreamContext_StreamNameBySubject_Call
func (*JetStreamContext_StreamNameBySubject_Call) Run ¶
func (_c *JetStreamContext_StreamNameBySubject_Call) Run(run func(_a0 string, _a1 ...nats.JSOpt)) *JetStreamContext_StreamNameBySubject_Call
func (*JetStreamContext_StreamNameBySubject_Call) RunAndReturn ¶
func (_c *JetStreamContext_StreamNameBySubject_Call) RunAndReturn(run func(string, ...nats.JSOpt) (string, error)) *JetStreamContext_StreamNameBySubject_Call
type JetStreamContext_StreamNames_Call ¶
JetStreamContext_StreamNames_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'StreamNames'
func (*JetStreamContext_StreamNames_Call) Return ¶
func (_c *JetStreamContext_StreamNames_Call) Return(_a0 <-chan string) *JetStreamContext_StreamNames_Call
func (*JetStreamContext_StreamNames_Call) Run ¶
func (_c *JetStreamContext_StreamNames_Call) Run(run func(opts ...nats.JSOpt)) *JetStreamContext_StreamNames_Call
func (*JetStreamContext_StreamNames_Call) RunAndReturn ¶
func (_c *JetStreamContext_StreamNames_Call) RunAndReturn(run func(...nats.JSOpt) <-chan string) *JetStreamContext_StreamNames_Call
type JetStreamContext_StreamsInfo_Call ¶
JetStreamContext_StreamsInfo_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'StreamsInfo'
func (*JetStreamContext_StreamsInfo_Call) Return ¶
func (_c *JetStreamContext_StreamsInfo_Call) Return(_a0 <-chan *nats.StreamInfo) *JetStreamContext_StreamsInfo_Call
func (*JetStreamContext_StreamsInfo_Call) Run ¶
func (_c *JetStreamContext_StreamsInfo_Call) Run(run func(opts ...nats.JSOpt)) *JetStreamContext_StreamsInfo_Call
func (*JetStreamContext_StreamsInfo_Call) RunAndReturn ¶
func (_c *JetStreamContext_StreamsInfo_Call) RunAndReturn(run func(...nats.JSOpt) <-chan *nats.StreamInfo) *JetStreamContext_StreamsInfo_Call
type JetStreamContext_Streams_Call ¶
JetStreamContext_Streams_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Streams'
func (*JetStreamContext_Streams_Call) Return ¶
func (_c *JetStreamContext_Streams_Call) Return(_a0 <-chan *nats.StreamInfo) *JetStreamContext_Streams_Call
func (*JetStreamContext_Streams_Call) Run ¶
func (_c *JetStreamContext_Streams_Call) Run(run func(opts ...nats.JSOpt)) *JetStreamContext_Streams_Call
func (*JetStreamContext_Streams_Call) RunAndReturn ¶
func (_c *JetStreamContext_Streams_Call) RunAndReturn(run func(...nats.JSOpt) <-chan *nats.StreamInfo) *JetStreamContext_Streams_Call
type JetStreamContext_SubscribeSync_Call ¶
JetStreamContext_SubscribeSync_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'SubscribeSync'
func (*JetStreamContext_SubscribeSync_Call) Return ¶
func (_c *JetStreamContext_SubscribeSync_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_SubscribeSync_Call
func (*JetStreamContext_SubscribeSync_Call) Run ¶
func (_c *JetStreamContext_SubscribeSync_Call) Run(run func(subj string, opts ...nats.SubOpt)) *JetStreamContext_SubscribeSync_Call
func (*JetStreamContext_SubscribeSync_Call) RunAndReturn ¶
func (_c *JetStreamContext_SubscribeSync_Call) RunAndReturn(run func(string, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_SubscribeSync_Call
type JetStreamContext_Subscribe_Call ¶
JetStreamContext_Subscribe_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Subscribe'
func (*JetStreamContext_Subscribe_Call) Return ¶
func (_c *JetStreamContext_Subscribe_Call) Return(_a0 *nats.Subscription, _a1 error) *JetStreamContext_Subscribe_Call
func (*JetStreamContext_Subscribe_Call) Run ¶
func (_c *JetStreamContext_Subscribe_Call) Run(run func(subj string, cb nats.MsgHandler, opts ...nats.SubOpt)) *JetStreamContext_Subscribe_Call
func (*JetStreamContext_Subscribe_Call) RunAndReturn ¶
func (_c *JetStreamContext_Subscribe_Call) RunAndReturn(run func(string, nats.MsgHandler, ...nats.SubOpt) (*nats.Subscription, error)) *JetStreamContext_Subscribe_Call
type JetStreamContext_UpdateConsumer_Call ¶
JetStreamContext_UpdateConsumer_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'UpdateConsumer'
func (*JetStreamContext_UpdateConsumer_Call) Return ¶
func (_c *JetStreamContext_UpdateConsumer_Call) Return(_a0 *nats.ConsumerInfo, _a1 error) *JetStreamContext_UpdateConsumer_Call
func (*JetStreamContext_UpdateConsumer_Call) Run ¶
func (_c *JetStreamContext_UpdateConsumer_Call) Run(run func(stream string, cfg *nats.ConsumerConfig, opts ...nats.JSOpt)) *JetStreamContext_UpdateConsumer_Call
func (*JetStreamContext_UpdateConsumer_Call) RunAndReturn ¶
func (_c *JetStreamContext_UpdateConsumer_Call) RunAndReturn(run func(string, *nats.ConsumerConfig, ...nats.JSOpt) (*nats.ConsumerInfo, error)) *JetStreamContext_UpdateConsumer_Call
type JetStreamContext_UpdateStream_Call ¶
JetStreamContext_UpdateStream_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'UpdateStream'
func (*JetStreamContext_UpdateStream_Call) Return ¶
func (_c *JetStreamContext_UpdateStream_Call) Return(_a0 *nats.StreamInfo, _a1 error) *JetStreamContext_UpdateStream_Call
func (*JetStreamContext_UpdateStream_Call) Run ¶
func (_c *JetStreamContext_UpdateStream_Call) Run(run func(cfg *nats.StreamConfig, opts ...nats.JSOpt)) *JetStreamContext_UpdateStream_Call
func (*JetStreamContext_UpdateStream_Call) RunAndReturn ¶
func (_c *JetStreamContext_UpdateStream_Call) RunAndReturn(run func(*nats.StreamConfig, ...nats.JSOpt) (*nats.StreamInfo, error)) *JetStreamContext_UpdateStream_Call
type Manager ¶
Manager is an autogenerated mock type for the Manager type
func NewManager ¶
NewManager creates a new instance of Manager. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*Manager) AddHealthzCheck ¶
AddHealthzCheck provides a mock function with given fields: name, check
func (*Manager) AddMetricsExtraHandler ¶
AddMetricsExtraHandler provides a mock function with given fields: path, handler
func (*Manager) AddReadyzCheck ¶
AddReadyzCheck provides a mock function with given fields: name, check
func (*Manager) EXPECT ¶
func (_m *Manager) EXPECT() *Manager_Expecter
func (*Manager) Elected ¶
func (_m *Manager) Elected() <-chan struct{}
Elected provides a mock function with given fields:
func (*Manager) GetAPIReader ¶
GetAPIReader provides a mock function with given fields:
func (*Manager) GetControllerOptions ¶
func (_m *Manager) GetControllerOptions() config.Controller
GetControllerOptions provides a mock function with given fields:
func (*Manager) GetEventRecorderFor ¶
func (_m *Manager) GetEventRecorderFor(name string) record.EventRecorder
GetEventRecorderFor provides a mock function with given fields: name
func (*Manager) GetFieldIndexer ¶
func (_m *Manager) GetFieldIndexer() client.FieldIndexer
GetFieldIndexer provides a mock function with given fields:
func (*Manager) GetHTTPClient ¶
GetHTTPClient provides a mock function with given fields:
func (*Manager) GetRESTMapper ¶
func (_m *Manager) GetRESTMapper() meta.RESTMapper
GetRESTMapper provides a mock function with given fields:
func (*Manager) GetWebhookServer ¶
GetWebhookServer provides a mock function with given fields:
type Manager_AddHealthzCheck_Call ¶
Manager_AddHealthzCheck_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'AddHealthzCheck'
func (*Manager_AddHealthzCheck_Call) Return ¶
func (_c *Manager_AddHealthzCheck_Call) Return(_a0 error) *Manager_AddHealthzCheck_Call
func (*Manager_AddHealthzCheck_Call) Run ¶
func (_c *Manager_AddHealthzCheck_Call) Run(run func(name string, check healthz.Checker)) *Manager_AddHealthzCheck_Call
func (*Manager_AddHealthzCheck_Call) RunAndReturn ¶
func (_c *Manager_AddHealthzCheck_Call) RunAndReturn(run func(string, healthz.Checker) error) *Manager_AddHealthzCheck_Call
type Manager_AddMetricsExtraHandler_Call ¶
Manager_AddMetricsExtraHandler_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'AddMetricsExtraHandler'
func (*Manager_AddMetricsExtraHandler_Call) Return ¶
func (_c *Manager_AddMetricsExtraHandler_Call) Return(_a0 error) *Manager_AddMetricsExtraHandler_Call
func (*Manager_AddMetricsExtraHandler_Call) Run ¶
func (_c *Manager_AddMetricsExtraHandler_Call) Run(run func(path string, handler http.Handler)) *Manager_AddMetricsExtraHandler_Call
func (*Manager_AddMetricsExtraHandler_Call) RunAndReturn ¶
func (_c *Manager_AddMetricsExtraHandler_Call) RunAndReturn(run func(string, http.Handler) error) *Manager_AddMetricsExtraHandler_Call
type Manager_AddReadyzCheck_Call ¶
Manager_AddReadyzCheck_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'AddReadyzCheck'
func (*Manager_AddReadyzCheck_Call) Return ¶
func (_c *Manager_AddReadyzCheck_Call) Return(_a0 error) *Manager_AddReadyzCheck_Call
func (*Manager_AddReadyzCheck_Call) Run ¶
func (_c *Manager_AddReadyzCheck_Call) Run(run func(name string, check healthz.Checker)) *Manager_AddReadyzCheck_Call
func (*Manager_AddReadyzCheck_Call) RunAndReturn ¶
func (_c *Manager_AddReadyzCheck_Call) RunAndReturn(run func(string, healthz.Checker) error) *Manager_AddReadyzCheck_Call
type Manager_Add_Call ¶
Manager_Add_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Add'
func (*Manager_Add_Call) Return ¶
func (_c *Manager_Add_Call) Return(_a0 error) *Manager_Add_Call
func (*Manager_Add_Call) Run ¶
func (_c *Manager_Add_Call) Run(run func(_a0 manager.Runnable)) *Manager_Add_Call
func (*Manager_Add_Call) RunAndReturn ¶
func (_c *Manager_Add_Call) RunAndReturn(run func(manager.Runnable) error) *Manager_Add_Call
type Manager_Elected_Call ¶
Manager_Elected_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Elected'
func (*Manager_Elected_Call) Return ¶
func (_c *Manager_Elected_Call) Return(_a0 <-chan struct{}) *Manager_Elected_Call
func (*Manager_Elected_Call) Run ¶
func (_c *Manager_Elected_Call) Run(run func()) *Manager_Elected_Call
func (*Manager_Elected_Call) RunAndReturn ¶
func (_c *Manager_Elected_Call) RunAndReturn(run func() <-chan struct{}) *Manager_Elected_Call
type Manager_Expecter ¶
type Manager_Expecter struct {
// contains filtered or unexported fields
}
func (*Manager_Expecter) Add ¶
func (_e *Manager_Expecter) Add(_a0 interface{}) *Manager_Add_Call
Add is a helper method to define mock.On call
- _a0 manager.Runnable
func (*Manager_Expecter) AddHealthzCheck ¶
func (_e *Manager_Expecter) AddHealthzCheck(name interface{}, check interface{}) *Manager_AddHealthzCheck_Call
AddHealthzCheck is a helper method to define mock.On call
- name string
- check healthz.Checker
func (*Manager_Expecter) AddMetricsExtraHandler ¶
func (_e *Manager_Expecter) AddMetricsExtraHandler(path interface{}, handler interface{}) *Manager_AddMetricsExtraHandler_Call
AddMetricsExtraHandler is a helper method to define mock.On call
- path string
- handler http.Handler
func (*Manager_Expecter) AddReadyzCheck ¶
func (_e *Manager_Expecter) AddReadyzCheck(name interface{}, check interface{}) *Manager_AddReadyzCheck_Call
AddReadyzCheck is a helper method to define mock.On call
- name string
- check healthz.Checker
func (*Manager_Expecter) Elected ¶
func (_e *Manager_Expecter) Elected() *Manager_Elected_Call
Elected is a helper method to define mock.On call
func (*Manager_Expecter) GetAPIReader ¶
func (_e *Manager_Expecter) GetAPIReader() *Manager_GetAPIReader_Call
GetAPIReader is a helper method to define mock.On call
func (*Manager_Expecter) GetCache ¶
func (_e *Manager_Expecter) GetCache() *Manager_GetCache_Call
GetCache is a helper method to define mock.On call
func (*Manager_Expecter) GetClient ¶
func (_e *Manager_Expecter) GetClient() *Manager_GetClient_Call
GetClient is a helper method to define mock.On call
func (*Manager_Expecter) GetConfig ¶
func (_e *Manager_Expecter) GetConfig() *Manager_GetConfig_Call
GetConfig is a helper method to define mock.On call
func (*Manager_Expecter) GetControllerOptions ¶
func (_e *Manager_Expecter) GetControllerOptions() *Manager_GetControllerOptions_Call
GetControllerOptions is a helper method to define mock.On call
func (*Manager_Expecter) GetEventRecorderFor ¶
func (_e *Manager_Expecter) GetEventRecorderFor(name interface{}) *Manager_GetEventRecorderFor_Call
GetEventRecorderFor is a helper method to define mock.On call
- name string
func (*Manager_Expecter) GetFieldIndexer ¶
func (_e *Manager_Expecter) GetFieldIndexer() *Manager_GetFieldIndexer_Call
GetFieldIndexer is a helper method to define mock.On call
func (*Manager_Expecter) GetHTTPClient ¶
func (_e *Manager_Expecter) GetHTTPClient() *Manager_GetHTTPClient_Call
GetHTTPClient is a helper method to define mock.On call
func (*Manager_Expecter) GetLogger ¶
func (_e *Manager_Expecter) GetLogger() *Manager_GetLogger_Call
GetLogger is a helper method to define mock.On call
func (*Manager_Expecter) GetRESTMapper ¶
func (_e *Manager_Expecter) GetRESTMapper() *Manager_GetRESTMapper_Call
GetRESTMapper is a helper method to define mock.On call
func (*Manager_Expecter) GetScheme ¶
func (_e *Manager_Expecter) GetScheme() *Manager_GetScheme_Call
GetScheme is a helper method to define mock.On call
func (*Manager_Expecter) GetWebhookServer ¶
func (_e *Manager_Expecter) GetWebhookServer() *Manager_GetWebhookServer_Call
GetWebhookServer is a helper method to define mock.On call
func (*Manager_Expecter) Start ¶
func (_e *Manager_Expecter) Start(ctx interface{}) *Manager_Start_Call
Start is a helper method to define mock.On call
- ctx context.Context
type Manager_GetAPIReader_Call ¶
Manager_GetAPIReader_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetAPIReader'
func (*Manager_GetAPIReader_Call) Return ¶
func (_c *Manager_GetAPIReader_Call) Return(_a0 client.Reader) *Manager_GetAPIReader_Call
func (*Manager_GetAPIReader_Call) Run ¶
func (_c *Manager_GetAPIReader_Call) Run(run func()) *Manager_GetAPIReader_Call
func (*Manager_GetAPIReader_Call) RunAndReturn ¶
func (_c *Manager_GetAPIReader_Call) RunAndReturn(run func() client.Reader) *Manager_GetAPIReader_Call
type Manager_GetCache_Call ¶
Manager_GetCache_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetCache'
func (*Manager_GetCache_Call) Return ¶
func (_c *Manager_GetCache_Call) Return(_a0 cache.Cache) *Manager_GetCache_Call
func (*Manager_GetCache_Call) Run ¶
func (_c *Manager_GetCache_Call) Run(run func()) *Manager_GetCache_Call
func (*Manager_GetCache_Call) RunAndReturn ¶
func (_c *Manager_GetCache_Call) RunAndReturn(run func() cache.Cache) *Manager_GetCache_Call
type Manager_GetClient_Call ¶
Manager_GetClient_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetClient'
func (*Manager_GetClient_Call) Return ¶
func (_c *Manager_GetClient_Call) Return(_a0 client.Client) *Manager_GetClient_Call
func (*Manager_GetClient_Call) Run ¶
func (_c *Manager_GetClient_Call) Run(run func()) *Manager_GetClient_Call
func (*Manager_GetClient_Call) RunAndReturn ¶
func (_c *Manager_GetClient_Call) RunAndReturn(run func() client.Client) *Manager_GetClient_Call
type Manager_GetConfig_Call ¶
Manager_GetConfig_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetConfig'
func (*Manager_GetConfig_Call) Return ¶
func (_c *Manager_GetConfig_Call) Return(_a0 *rest.Config) *Manager_GetConfig_Call
func (*Manager_GetConfig_Call) Run ¶
func (_c *Manager_GetConfig_Call) Run(run func()) *Manager_GetConfig_Call
func (*Manager_GetConfig_Call) RunAndReturn ¶
func (_c *Manager_GetConfig_Call) RunAndReturn(run func() *rest.Config) *Manager_GetConfig_Call
type Manager_GetControllerOptions_Call ¶
Manager_GetControllerOptions_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetControllerOptions'
func (*Manager_GetControllerOptions_Call) Return ¶
func (_c *Manager_GetControllerOptions_Call) Return(_a0 config.Controller) *Manager_GetControllerOptions_Call
func (*Manager_GetControllerOptions_Call) Run ¶
func (_c *Manager_GetControllerOptions_Call) Run(run func()) *Manager_GetControllerOptions_Call
func (*Manager_GetControllerOptions_Call) RunAndReturn ¶
func (_c *Manager_GetControllerOptions_Call) RunAndReturn(run func() config.Controller) *Manager_GetControllerOptions_Call
type Manager_GetEventRecorderFor_Call ¶
Manager_GetEventRecorderFor_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetEventRecorderFor'
func (*Manager_GetEventRecorderFor_Call) Return ¶
func (_c *Manager_GetEventRecorderFor_Call) Return(_a0 record.EventRecorder) *Manager_GetEventRecorderFor_Call
func (*Manager_GetEventRecorderFor_Call) Run ¶
func (_c *Manager_GetEventRecorderFor_Call) Run(run func(name string)) *Manager_GetEventRecorderFor_Call
func (*Manager_GetEventRecorderFor_Call) RunAndReturn ¶
func (_c *Manager_GetEventRecorderFor_Call) RunAndReturn(run func(string) record.EventRecorder) *Manager_GetEventRecorderFor_Call
type Manager_GetFieldIndexer_Call ¶
Manager_GetFieldIndexer_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetFieldIndexer'
func (*Manager_GetFieldIndexer_Call) Return ¶
func (_c *Manager_GetFieldIndexer_Call) Return(_a0 client.FieldIndexer) *Manager_GetFieldIndexer_Call
func (*Manager_GetFieldIndexer_Call) Run ¶
func (_c *Manager_GetFieldIndexer_Call) Run(run func()) *Manager_GetFieldIndexer_Call
func (*Manager_GetFieldIndexer_Call) RunAndReturn ¶
func (_c *Manager_GetFieldIndexer_Call) RunAndReturn(run func() client.FieldIndexer) *Manager_GetFieldIndexer_Call
type Manager_GetHTTPClient_Call ¶
Manager_GetHTTPClient_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetHTTPClient'
func (*Manager_GetHTTPClient_Call) Return ¶
func (_c *Manager_GetHTTPClient_Call) Return(_a0 *http.Client) *Manager_GetHTTPClient_Call
func (*Manager_GetHTTPClient_Call) Run ¶
func (_c *Manager_GetHTTPClient_Call) Run(run func()) *Manager_GetHTTPClient_Call
func (*Manager_GetHTTPClient_Call) RunAndReturn ¶
func (_c *Manager_GetHTTPClient_Call) RunAndReturn(run func() *http.Client) *Manager_GetHTTPClient_Call
type Manager_GetLogger_Call ¶
Manager_GetLogger_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetLogger'
func (*Manager_GetLogger_Call) Return ¶
func (_c *Manager_GetLogger_Call) Return(_a0 logr.Logger) *Manager_GetLogger_Call
func (*Manager_GetLogger_Call) Run ¶
func (_c *Manager_GetLogger_Call) Run(run func()) *Manager_GetLogger_Call
func (*Manager_GetLogger_Call) RunAndReturn ¶
func (_c *Manager_GetLogger_Call) RunAndReturn(run func() logr.Logger) *Manager_GetLogger_Call
type Manager_GetRESTMapper_Call ¶
Manager_GetRESTMapper_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetRESTMapper'
func (*Manager_GetRESTMapper_Call) Return ¶
func (_c *Manager_GetRESTMapper_Call) Return(_a0 meta.RESTMapper) *Manager_GetRESTMapper_Call
func (*Manager_GetRESTMapper_Call) Run ¶
func (_c *Manager_GetRESTMapper_Call) Run(run func()) *Manager_GetRESTMapper_Call
func (*Manager_GetRESTMapper_Call) RunAndReturn ¶
func (_c *Manager_GetRESTMapper_Call) RunAndReturn(run func() meta.RESTMapper) *Manager_GetRESTMapper_Call
type Manager_GetScheme_Call ¶
Manager_GetScheme_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetScheme'
func (*Manager_GetScheme_Call) Return ¶
func (_c *Manager_GetScheme_Call) Return(_a0 *runtime.Scheme) *Manager_GetScheme_Call
func (*Manager_GetScheme_Call) Run ¶
func (_c *Manager_GetScheme_Call) Run(run func()) *Manager_GetScheme_Call
func (*Manager_GetScheme_Call) RunAndReturn ¶
func (_c *Manager_GetScheme_Call) RunAndReturn(run func() *runtime.Scheme) *Manager_GetScheme_Call
type Manager_GetWebhookServer_Call ¶
Manager_GetWebhookServer_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'GetWebhookServer'
func (*Manager_GetWebhookServer_Call) Return ¶
func (_c *Manager_GetWebhookServer_Call) Return(_a0 webhook.Server) *Manager_GetWebhookServer_Call
func (*Manager_GetWebhookServer_Call) Run ¶
func (_c *Manager_GetWebhookServer_Call) Run(run func()) *Manager_GetWebhookServer_Call
func (*Manager_GetWebhookServer_Call) RunAndReturn ¶
func (_c *Manager_GetWebhookServer_Call) RunAndReturn(run func() webhook.Server) *Manager_GetWebhookServer_Call
type Manager_Start_Call ¶
Manager_Start_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Start'
func (*Manager_Start_Call) Return ¶
func (_c *Manager_Start_Call) Return(_a0 error) *Manager_Start_Call
func (*Manager_Start_Call) Run ¶
func (_c *Manager_Start_Call) Run(run func(ctx context.Context)) *Manager_Start_Call
func (*Manager_Start_Call) RunAndReturn ¶
func (_c *Manager_Start_Call) RunAndReturn(run func(context.Context) error) *Manager_Start_Call
type NatsConn ¶
NatsConn is an autogenerated mock type for the NatsConn type
func NewNatsConn ¶
NewNatsConn creates a new instance of NatsConn. It also registers a testing interface on the mock and a cleanup function to assert the mocks expectations. The first argument is typically a *testing.T value.
func (*NatsConn) Close ¶
func (_m *NatsConn) Close()
Close provides a mock function with given fields:
func (*NatsConn) EXPECT ¶
func (_m *NatsConn) EXPECT() *NatsConn_Expecter
func (*NatsConn) IsConnected ¶
IsConnected provides a mock function with given fields:
type NatsConn_Close_Call ¶
NatsConn_Close_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Close'
func (*NatsConn_Close_Call) Return ¶
func (_c *NatsConn_Close_Call) Return() *NatsConn_Close_Call
func (*NatsConn_Close_Call) Run ¶
func (_c *NatsConn_Close_Call) Run(run func()) *NatsConn_Close_Call
func (*NatsConn_Close_Call) RunAndReturn ¶
func (_c *NatsConn_Close_Call) RunAndReturn(run func()) *NatsConn_Close_Call
type NatsConn_Expecter ¶
type NatsConn_Expecter struct {
// contains filtered or unexported fields
}
func (*NatsConn_Expecter) Close ¶
func (_e *NatsConn_Expecter) Close() *NatsConn_Close_Call
Close is a helper method to define mock.On call
func (*NatsConn_Expecter) IsConnected ¶
func (_e *NatsConn_Expecter) IsConnected() *NatsConn_IsConnected_Call
IsConnected is a helper method to define mock.On call
func (*NatsConn_Expecter) JetStream ¶
func (_e *NatsConn_Expecter) JetStream() *NatsConn_JetStream_Call
JetStream is a helper method to define mock.On call
func (*NatsConn_Expecter) Status ¶
func (_e *NatsConn_Expecter) Status() *NatsConn_Status_Call
Status is a helper method to define mock.On call
type NatsConn_IsConnected_Call ¶
NatsConn_IsConnected_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'IsConnected'
func (*NatsConn_IsConnected_Call) Return ¶
func (_c *NatsConn_IsConnected_Call) Return(_a0 bool) *NatsConn_IsConnected_Call
func (*NatsConn_IsConnected_Call) Run ¶
func (_c *NatsConn_IsConnected_Call) Run(run func()) *NatsConn_IsConnected_Call
func (*NatsConn_IsConnected_Call) RunAndReturn ¶
func (_c *NatsConn_IsConnected_Call) RunAndReturn(run func() bool) *NatsConn_IsConnected_Call
type NatsConn_JetStream_Call ¶
NatsConn_JetStream_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'JetStream'
func (*NatsConn_JetStream_Call) Return ¶
func (_c *NatsConn_JetStream_Call) Return(_a0 nats_go.JetStreamContext, _a1 error) *NatsConn_JetStream_Call
func (*NatsConn_JetStream_Call) Run ¶
func (_c *NatsConn_JetStream_Call) Run(run func()) *NatsConn_JetStream_Call
func (*NatsConn_JetStream_Call) RunAndReturn ¶
func (_c *NatsConn_JetStream_Call) RunAndReturn(run func() (nats_go.JetStreamContext, error)) *NatsConn_JetStream_Call
type NatsConn_Status_Call ¶
NatsConn_Status_Call is a *mock.Call that shadows Run/Return methods with type explicit version for method 'Status'
func (*NatsConn_Status_Call) Return ¶
func (_c *NatsConn_Status_Call) Return(_a0 nats_go.Status) *NatsConn_Status_Call
func (*NatsConn_Status_Call) Run ¶
func (_c *NatsConn_Status_Call) Run(run func()) *NatsConn_Status_Call
func (*NatsConn_Status_Call) RunAndReturn ¶
func (_c *NatsConn_Status_Call) RunAndReturn(run func() nats_go.Status) *NatsConn_Status_Call