Versions in this module Expand all Collapse all v2 v2.3.1 Jun 21, 2025 v2.3.0 Jun 11, 2025 Changes in this version + func EntrySetFilterWithComparator[K comparable, V, E any](ctx context.Context, nm NamedMap[K, V], filter filters.Filter, ...) <-chan *StreamedEntry[K, V] type NamedMapClient + func (nm *NamedMapClient[K, V]) EntrySetFilterWithComparator(ctx context.Context, fltr filters.Filter, ...) <-chan *StreamedEntry[K, V] v2.3.0-rc2 May 29, 2025 v2.3.0-rc1 May 21, 2025 v2.2.0 May 12, 2025 Changes in this version + var ALL logLevel = 5 v2.1.0 Mar 19, 2025 v2.0.0 Dec 23, 2024 Changes in this version + const Closed + const Connected + const Destroyed + const Disconnected + const EntryDeleted + const EntryInserted + const EntryUpdated + const GB + const KB + const MB + const Reconnected + const Released + const Truncated + var DEBUG logLevel = "DEBUG:" + var ERROR logLevel = "ERROR:" + var ErrClosed = errors.New("the session is closed and is not usable") + var ErrDestroyed = errors.New("the NamedMap or NamedCache has been destroyed and is not usable") + var ErrDone = errors.New("iterator done") + var ErrInvalidFormat = errors.New("format can only be 'json'") + var ErrInvalidNearCache = errors.New("you must specify at least one near cache option") + var ErrInvalidNearCacheTTL = errors.New("minimum near cache TTL is 1/4 of a second") + var ErrInvalidNearCacheWithNoTTL = errors.New("you can only specify highUnits or highUnitsMemory, not both") + var ErrInvalidNearCacheWithTTL = errors.New(...) + var ErrInvalidPruneFactor = errors.New("prune factor must be between 0.1 and 1.0") + var ErrNegativeNearCacheOptions = errors.New("you cannot specify negative values for near cache options") + var ErrNotSupported = errors.New("this attribute is not support for gRPC v0 clients") + var ErrQueueDestroyedOrReleased = errors.New("this queue has been destroyed or released") + var ErrQueueFailedOffer = errors.New("did not return success for offer") + var ErrQueueNoSupported = errors.New(...) + var ErrReleased = errors.New("the NamedMap or NamedCache has been released and is not usable") + var ErrShutdown = errors.New("gRPC channel has been shutdown") + var INFO logLevel = "INFO:" + var RCV = "RCV" + var SND = "SND" + var WARNING logLevel = "WARN:" + func AddIndexWithComparator[K comparable, V, T, E any](ctx context.Context, nm NamedMap[K, V], ...) error + func AddIndex[K comparable, V, T, E any](ctx context.Context, nm NamedMap[K, V], ...) error + func AggregateFilter[K comparable, V, R any](ctx context.Context, nm NamedMap[K, V], filter filters.Filter, ...) (*R, error) + func AggregateKeys[K comparable, V, R any](ctx context.Context, nm NamedMap[K, V], keys []K, ...) (*R, error) + func Aggregate[K comparable, V, R any](ctx context.Context, nm NamedMap[K, V], aggr aggregators.Aggregator[R]) (*R, error) + func GetFilterListenerGroupMap[K comparable, V any](namedMap NamedMap[K, V]) map[filters.Filter]*listenerGroupV1[K, V] + func GetKeyListenerGroupMap[K comparable, V any](namedMap NamedMap[K, V]) map[K]*listenerGroupV1[K, V] + func GetNearCachePruneFactor[K comparable, V any](namedMap NamedMap[K, V]) float32 + func GetSessionCacheID(session *Session, cache string) *int32 + func GetSessionQueueID(session *Session, queue string) *int32 + func InvokeAllBlind[K comparable, V any](ctx context.Context, nm NamedMap[K, V], proc processors.Processor) error + func InvokeAllFilterBlind[K comparable, V any](ctx context.Context, nm NamedMap[K, V], fltr filters.Filter, ...) error + func InvokeAllFilter[K comparable, V any, R any](ctx context.Context, nm NamedMap[K, V], fltr filters.Filter, ...) <-chan *StreamedEntry[K, R] + func InvokeAllKeysBlind[K comparable, V any](ctx context.Context, nm NamedMap[K, V], keys []K, proc processors.Processor) error + func InvokeAllKeys[K comparable, V any, R any](ctx context.Context, nm NamedMap[K, V], keys []K, proc processors.Processor) <-chan *StreamedEntry[K, R] + func InvokeAll[K comparable, V any, R any](ctx context.Context, nm NamedMap[K, V], proc processors.Processor) <-chan *StreamedEntry[K, R] + func Invoke[K comparable, V, R any](ctx context.Context, nm NamedMap[K, V], key K, proc processors.Processor) (*R, error) + func NewEnsureCacheRequest(session *Session, cache string) (*pb1.ProxyRequest, error) + func NsLookupGrpcAddresses(address string) ([]string, error) + func RemoveIndex[K comparable, V, T, E any](ctx context.Context, nm NamedMap[K, V], ...) error + func TestAggregate(ctx context.Context, session *Session, cache string, agent []byte, ...) (*[]byte, error) + func TestClearCache(ctx context.Context, session *Session, cache string) error + func TestContainsEntry(ctx context.Context, session *Session, cache string, key []byte, value []byte) (bool, error) + func TestContainsKey(ctx context.Context, session *Session, cache string, key []byte) (bool, error) + func TestContainsValue(ctx context.Context, session *Session, cache string, value []byte) (bool, error) + func TestDestroyCache(ctx context.Context, session *Session, cache string) error + func TestEnsureCache(ctx context.Context, session *Session, cache string) (*int32, error) + func TestGet(ctx context.Context, session *Session, cache string, key []byte) (*[]byte, error) + func TestGetAll(ctx context.Context, session *Session, cache string, keys [][]byte) (<-chan BinaryKeyAndValue, error) + func TestInvoke(ctx context.Context, session *Session, cache string, agent []byte, ...) (<-chan BinaryKeyAndValue, error) + func TestIsEmpty(ctx context.Context, session *Session, cache string) (bool, error) + func TestIsReady(ctx context.Context, session *Session, cache string) (bool, error) + func TestKeyAndValuePage(ctx context.Context, session *Session, cache string, cookie []byte) (<-chan BinaryKeyAndValue, error) + func TestMapListenerRequest(ctx context.Context, session *Session, cache string, subscribe bool, ...) error + func TestPut(ctx context.Context, session *Session, cache string, key []byte, value []byte, ...) (*[]byte, error) + func TestPutAll(ctx context.Context, session *Session, cache string, ...) error + func TestPutIfAbsent(ctx context.Context, session *Session, cache string, key []byte, value []byte) (*[]byte, error) + func TestRemove(ctx context.Context, session *Session, cache string, key []byte) (*[]byte, error) + func TestRemoveMapping(ctx context.Context, session *Session, cache string, key []byte, value []byte) (bool, error) + func TestReplace(ctx context.Context, session *Session, cache string, key []byte, value []byte) (*[]byte, error) + func TestReplaceMapping(ctx context.Context, session *Session, cache string, key []byte, ...) (bool, error) + func TestSize(ctx context.Context, session *Session, cache string) (int32, error) + func TestTruncateCache(ctx context.Context, session *Session, cache string) error + func WithAddress(host string) func(sessionOptions *SessionOptions) + func WithDisconnectTimeout(timeout time.Duration) func(sessionOptions *SessionOptions) + func WithExpiry(ttl time.Duration) func(cacheOptions *CacheOptions) + func WithFormat(format string) func(sessionOptions *SessionOptions) + func WithIgnoreInvalidCerts() func(sessionOptions *SessionOptions) + func WithNearCache(options *NearCacheOptions) func(cacheOptions *CacheOptions) + func WithPlainText() func(sessionOptions *SessionOptions) + func WithReadyTimeout(timeout time.Duration) func(sessionOptions *SessionOptions) + func WithRequestTimeout(timeout time.Duration) func(sessionOptions *SessionOptions) + func WithScope(scope string) func(sessionOptions *SessionOptions) + func WithTLSCertsPath(path string) func(sessionOptions *SessionOptions) + func WithTLSClientCert(path string) func(sessionOptions *SessionOptions) + func WithTLSClientKey(path string) func(sessionOptions *SessionOptions) + func WithTLSConfig(tlsConfig *tls.Config) func(sessionOptions *SessionOptions) + type BinaryKey struct + Cookie []byte + Err error + Key []byte + type BinaryKeyAndValue struct + Cookie []byte + Err error + Key []byte + Value []byte + type BinaryValue struct + Cookie []byte + Err error + Value []byte + type CacheOptions struct + DefaultExpiry time.Duration + NearCacheOptions *NearCacheOptions + type CacheStats interface + GetCacheEntriesExpired func() int64 + GetCacheEntriesPruned func() int64 + GetCacheExpires func() int64 + GetCacheExpiresDuration func() time.Duration + GetCacheHits func() int64 + GetCacheMisses func() int64 + GetCacheMissesDuration func() time.Duration + GetCachePrunes func() int64 + GetCachePrunesDuration func() time.Duration + GetCachePuts func() int64 + GetHitRate func() float32 + GetTotalGets func() int64 + ResetStats func() + Size func() int + SizeBytes func() int64 + type Entry struct + Key K + Value V + type EventSubmitter interface + type InvalidationStrategyType int + const ListenAll + type JSONSerializer struct + func (s JSONSerializer[T]) Deserialize(data []byte) (*T, error) + func (s JSONSerializer[T]) Format() string + func (s JSONSerializer[T]) Serialize(object T) ([]byte, error) + type MapEvent interface + IsExpired func() (bool, error) + IsPriming func() (bool, error) + IsSynthetic func() (bool, error) + Key func() (*K, error) + NewValue func() (*V, error) + OldValue func() (*V, error) + Source func() NamedMap[K, V] + Type func() MapEventType + type MapEventType string + type MapLifecycleEvent interface + Source func() NamedMap[K, V] + Type func() MapLifecycleEventType + type MapLifecycleEventType string + type MapLifecycleListener interface + OnAny func(callback func(MapLifecycleEvent[K, V])) MapLifecycleListener[K, V] + OnDestroyed func(callback func(MapLifecycleEvent[K, V])) MapLifecycleListener[K, V] + OnReleased func(callback func(MapLifecycleEvent[K, V])) MapLifecycleListener[K, V] + OnTruncated func(callback func(MapLifecycleEvent[K, V])) MapLifecycleListener[K, V] + func NewMapLifecycleListener[K comparable, V any]() MapLifecycleListener[K, V] + type MapListener interface + IsPriming func() bool + IsSynchronous func() bool + OnAny func(callback func(MapEvent[K, V])) MapListener[K, V] + OnDeleted func(callback func(MapEvent[K, V])) MapListener[K, V] + OnInserted func(callback func(MapEvent[K, V])) MapListener[K, V] + OnUpdated func(callback func(MapEvent[K, V])) MapListener[K, V] + SetPriming func() + SetSynchronous func() + func GetFilterListenerGroupListeners[K comparable, V any](namedMap NamedMap[K, V], f filters.Filter) []MapListener[K, V] + func GetKeyListenerGroupListeners[K comparable, V any](namedMap NamedMap[K, V], key K) []MapListener[K, V] + func NewMapListener[K comparable, V any]() MapListener[K, V] + type NamedCache interface + PutWithExpiry func(ctx context.Context, key K, value V, ttl time.Duration) (*V, error) + func GetNamedCache[K comparable, V any](session *Session, cacheName string, options ...func(session *CacheOptions)) (NamedCache[K, V], error) + type NamedCacheClient struct + func (nc *NamedCacheClient[K, V]) AddFilterListener(ctx context.Context, listener MapListener[K, V], filter filters.Filter) error + func (nc *NamedCacheClient[K, V]) AddFilterListenerLite(ctx context.Context, listener MapListener[K, V], filter filters.Filter) error + func (nc *NamedCacheClient[K, V]) AddKeyListener(ctx context.Context, listener MapListener[K, V], key K) error + func (nc *NamedCacheClient[K, V]) AddKeyListenerLite(ctx context.Context, listener MapListener[K, V], key K) error + func (nc *NamedCacheClient[K, V]) AddLifecycleListener(listener MapLifecycleListener[K, V]) + func (nc *NamedCacheClient[K, V]) AddListener(ctx context.Context, listener MapListener[K, V]) error + func (nc *NamedCacheClient[K, V]) AddListenerLite(ctx context.Context, listener MapListener[K, V]) error + func (nc *NamedCacheClient[K, V]) Clear(ctx context.Context) error + func (nc *NamedCacheClient[K, V]) ContainsEntry(ctx context.Context, key K, value V) (bool, error) + func (nc *NamedCacheClient[K, V]) ContainsKey(ctx context.Context, key K) (bool, error) + func (nc *NamedCacheClient[K, V]) ContainsValue(ctx context.Context, value V) (bool, error) + func (nc *NamedCacheClient[K, V]) Destroy(ctx context.Context) error + func (nc *NamedCacheClient[K, V]) EntrySet(ctx context.Context) <-chan *StreamedEntry[K, V] + func (nc *NamedCacheClient[K, V]) EntrySetFilter(ctx context.Context, fltr filters.Filter) <-chan *StreamedEntry[K, V] + func (nc *NamedCacheClient[K, V]) Get(ctx context.Context, key K) (*V, error) + func (nc *NamedCacheClient[K, V]) GetAll(ctx context.Context, keys []K) <-chan *StreamedEntry[K, V] + func (nc *NamedCacheClient[K, V]) GetCacheName() string + func (nc *NamedCacheClient[K, V]) GetNearCacheStats() CacheStats + func (nc *NamedCacheClient[K, V]) GetOrDefault(ctx context.Context, key K, def V) (*V, error) + func (nc *NamedCacheClient[K, V]) GetSession() *Session + func (nc *NamedCacheClient[K, V]) IsEmpty(ctx context.Context) (bool, error) + func (nc *NamedCacheClient[K, V]) IsReady(ctx context.Context) (bool, error) + func (nc *NamedCacheClient[K, V]) KeySet(ctx context.Context) <-chan *StreamedKey[K] + func (nc *NamedCacheClient[K, V]) KeySetFilter(ctx context.Context, fltr filters.Filter) <-chan *StreamedKey[K] + func (nc *NamedCacheClient[K, V]) Name() string + func (nc *NamedCacheClient[K, V]) Put(ctx context.Context, key K, value V) (*V, error) + func (nc *NamedCacheClient[K, V]) PutAll(ctx context.Context, entries map[K]V) error + func (nc *NamedCacheClient[K, V]) PutAllWithExpiry(ctx context.Context, entries map[K]V, ttl time.Duration) error + func (nc *NamedCacheClient[K, V]) PutIfAbsent(ctx context.Context, key K, value V) (*V, error) + func (nc *NamedCacheClient[K, V]) PutWithExpiry(ctx context.Context, key K, value V, ttl time.Duration) (*V, error) + func (nc *NamedCacheClient[K, V]) Release() + func (nc *NamedCacheClient[K, V]) Remove(ctx context.Context, key K) (*V, error) + func (nc *NamedCacheClient[K, V]) RemoveFilterListener(ctx context.Context, listener MapListener[K, V], f filters.Filter) error + func (nc *NamedCacheClient[K, V]) RemoveKeyListener(ctx context.Context, listener MapListener[K, V], key K) error + func (nc *NamedCacheClient[K, V]) RemoveLifecycleListener(listener MapLifecycleListener[K, V]) + func (nc *NamedCacheClient[K, V]) RemoveListener(ctx context.Context, listener MapListener[K, V]) error + func (nc *NamedCacheClient[K, V]) RemoveMapping(ctx context.Context, key K, value V) (bool, error) + func (nc *NamedCacheClient[K, V]) Replace(ctx context.Context, key K, value V) (*V, error) + func (nc *NamedCacheClient[K, V]) ReplaceMapping(ctx context.Context, key K, prevValue V, newValue V) (bool, error) + func (nc *NamedCacheClient[K, V]) Size(ctx context.Context) (int, error) + func (nc *NamedCacheClient[K, V]) String() string + func (nc *NamedCacheClient[K, V]) Truncate(ctx context.Context) error + func (nc *NamedCacheClient[K, V]) Values(ctx context.Context) <-chan *StreamedValue[V] + func (nc *NamedCacheClient[K, V]) ValuesFilter(ctx context.Context, fltr filters.Filter) <-chan *StreamedValue[V] + type NamedDequeue interface + OfferHead func(ctx context.Context, value V) error + PeekTail func(ctx context.Context) (*V, error) + PollTail func(ctx context.Context) (*V, error) + func GetNamedDeQueue[V any](ctx context.Context, session *Session, queueName string) (NamedDequeue[V], error) + type NamedMap interface + AddFilterListener func(ctx context.Context, listener MapListener[K, V], filter filters.Filter) error + AddFilterListenerLite func(ctx context.Context, listener MapListener[K, V], filter filters.Filter) error + AddKeyListener func(ctx context.Context, listener MapListener[K, V], key K) error + AddKeyListenerLite func(ctx context.Context, listener MapListener[K, V], key K) error + AddLifecycleListener func(listener MapLifecycleListener[K, V]) + AddListener func(ctx context.Context, listener MapListener[K, V]) error + AddListenerLite func(ctx context.Context, listener MapListener[K, V]) error + Clear func(ctx context.Context) error + ContainsEntry func(ctx context.Context, key K, value V) (bool, error) + ContainsKey func(ctx context.Context, key K) (bool, error) + ContainsValue func(ctx context.Context, value V) (bool, error) + Destroy func(ctx context.Context) error + EntrySet func(ctx context.Context) <-chan *StreamedEntry[K, V] + EntrySetFilter func(ctx context.Context, filter filters.Filter) <-chan *StreamedEntry[K, V] + Get func(ctx context.Context, key K) (*V, error) + GetAll func(ctx context.Context, keys []K) <-chan *StreamedEntry[K, V] + GetCacheName func() string + GetNearCacheStats func() CacheStats + GetOrDefault func(ctx context.Context, key K, def V) (*V, error) + GetSession func() *Session + InvokeAll func(ctx context.Context, keysOrFilter any, proc processors.Processor) <-chan *StreamedValue[V] + IsEmpty func(ctx context.Context) (bool, error) + IsReady func(ctx context.Context) (bool, error) + KeySet func(ctx context.Context) <-chan *StreamedKey[K] + KeySetFilter func(ctx context.Context, filter filters.Filter) <-chan *StreamedKey[K] + Name func() string + Put func(ctx context.Context, key K, value V) (*V, error) + PutAll func(ctx context.Context, entries map[K]V) error + PutAllWithExpiry func(ctx context.Context, entries map[K]V, ttl time.Duration) error + PutIfAbsent func(ctx context.Context, key K, value V) (*V, error) + Release func() + Remove func(ctx context.Context, key K) (*V, error) + RemoveFilterListener func(ctx context.Context, listener MapListener[K, V], filter filters.Filter) error + RemoveKeyListener func(ctx context.Context, listener MapListener[K, V], key K) error + RemoveLifecycleListener func(listener MapLifecycleListener[K, V]) + RemoveListener func(ctx context.Context, listener MapListener[K, V]) error + RemoveMapping func(ctx context.Context, key K, value V) (bool, error) + Replace func(ctx context.Context, key K, value V) (*V, error) + ReplaceMapping func(ctx context.Context, key K, prevValue V, newValue V) (bool, error) + Size func(ctx context.Context) (int, error) + Truncate func(ctx context.Context) error + Values func(ctx context.Context) <-chan *StreamedValue[V] + ValuesFilter func(ctx context.Context, filter filters.Filter) <-chan *StreamedValue[V] + func GetNamedMap[K comparable, V any](session *Session, cacheName string, options ...func(session *CacheOptions)) (NamedMap[K, V], error) + type NamedMapClient struct + func (nm *NamedMapClient[K, V]) AddFilterListener(ctx context.Context, listener MapListener[K, V], filter filters.Filter) error + func (nm *NamedMapClient[K, V]) AddFilterListenerLite(ctx context.Context, listener MapListener[K, V], filter filters.Filter) error + func (nm *NamedMapClient[K, V]) AddKeyListener(ctx context.Context, listener MapListener[K, V], key K) error + func (nm *NamedMapClient[K, V]) AddKeyListenerLite(ctx context.Context, listener MapListener[K, V], key K) error + func (nm *NamedMapClient[K, V]) AddLifecycleListener(listener MapLifecycleListener[K, V]) + func (nm *NamedMapClient[K, V]) AddListener(ctx context.Context, listener MapListener[K, V]) error + func (nm *NamedMapClient[K, V]) AddListenerLite(ctx context.Context, listener MapListener[K, V]) error + func (nm *NamedMapClient[K, V]) Clear(ctx context.Context) error + func (nm *NamedMapClient[K, V]) ContainsEntry(ctx context.Context, key K, value V) (bool, error) + func (nm *NamedMapClient[K, V]) ContainsKey(ctx context.Context, key K) (bool, error) + func (nm *NamedMapClient[K, V]) ContainsValue(ctx context.Context, value V) (bool, error) + func (nm *NamedMapClient[K, V]) Destroy(ctx context.Context) error + func (nm *NamedMapClient[K, V]) EntrySet(ctx context.Context) <-chan *StreamedEntry[K, V] + func (nm *NamedMapClient[K, V]) EntrySetFilter(ctx context.Context, fltr filters.Filter) <-chan *StreamedEntry[K, V] + func (nm *NamedMapClient[K, V]) Get(ctx context.Context, key K) (*V, error) + func (nm *NamedMapClient[K, V]) GetAll(ctx context.Context, keys []K) <-chan *StreamedEntry[K, V] + func (nm *NamedMapClient[K, V]) GetCacheName() string + func (nm *NamedMapClient[K, V]) GetNearCacheStats() CacheStats + func (nm *NamedMapClient[K, V]) GetOrDefault(ctx context.Context, key K, def V) (*V, error) + func (nm *NamedMapClient[K, V]) GetSession() *Session + func (nm *NamedMapClient[K, V]) IsEmpty(ctx context.Context) (bool, error) + func (nm *NamedMapClient[K, V]) IsReady(ctx context.Context) (bool, error) + func (nm *NamedMapClient[K, V]) KeySet(ctx context.Context) <-chan *StreamedKey[K] + func (nm *NamedMapClient[K, V]) KeySetFilter(ctx context.Context, fltr filters.Filter) <-chan *StreamedKey[K] + func (nm *NamedMapClient[K, V]) Name() string + func (nm *NamedMapClient[K, V]) Put(ctx context.Context, key K, value V) (*V, error) + func (nm *NamedMapClient[K, V]) PutAll(ctx context.Context, entries map[K]V) error + func (nm *NamedMapClient[K, V]) PutIfAbsent(ctx context.Context, key K, value V) (*V, error) + func (nm *NamedMapClient[K, V]) Release() + func (nm *NamedMapClient[K, V]) Remove(ctx context.Context, key K) (*V, error) + func (nm *NamedMapClient[K, V]) RemoveFilterListener(ctx context.Context, listener MapListener[K, V], f filters.Filter) error + func (nm *NamedMapClient[K, V]) RemoveKeyListener(ctx context.Context, listener MapListener[K, V], key K) error + func (nm *NamedMapClient[K, V]) RemoveLifecycleListener(listener MapLifecycleListener[K, V]) + func (nm *NamedMapClient[K, V]) RemoveListener(ctx context.Context, listener MapListener[K, V]) error + func (nm *NamedMapClient[K, V]) RemoveMapping(ctx context.Context, key K, value V) (bool, error) + func (nm *NamedMapClient[K, V]) Replace(ctx context.Context, key K, value V) (*V, error) + func (nm *NamedMapClient[K, V]) ReplaceMapping(ctx context.Context, key K, prevValue V, newValue V) (bool, error) + func (nm *NamedMapClient[K, V]) Size(ctx context.Context) (int, error) + func (nm *NamedMapClient[K, V]) String() string + func (nm *NamedMapClient[K, V]) Truncate(ctx context.Context) error + func (nm *NamedMapClient[K, V]) Values(ctx context.Context) <-chan *StreamedValue[V] + func (nm *NamedMapClient[K, V]) ValuesFilter(ctx context.Context, fltr filters.Filter) <-chan *StreamedValue[V] + type NamedQueue interface + AddLifecycleListener func(listener QueueLifecycleListener[V]) error + Clear func(ctx context.Context) error + Destroy func(ctx context.Context) error + GetName func() string + GetType func() NamedQueueType + IsEmpty func(ctx context.Context) (bool, error) + IsReady func(ctx context.Context) (bool, error) + OfferTail func(ctx context.Context, value V) error + PeekHead func(ctx context.Context) (*V, error) + PollHead func(ctx context.Context) (*V, error) + Release func() + RemoveLifecycleListener func(listener QueueLifecycleListener[V]) error + Size func(ctx context.Context) (int32, error) + func GetNamedQueue[V any](ctx context.Context, session *Session, queueName string, ...) (NamedQueue[V], error) + type NamedQueueType int + const Dequeue + const PagedQueue + const Queue + func (qt NamedQueueType) String() string + type NearCacheOptions struct + HighUnits int64 + HighUnitsMemory int64 + InvalidationStrategy InvalidationStrategyType + PruneFactor float32 + TTL time.Duration + func (n NearCacheOptions) String() string + type QueueEventSubmitter interface + type QueueLifecycleEvent interface + Source func() NamedQueue[V] + Type func() QueueLifecycleEventType + type QueueLifecycleEventType string + const QueueDestroyed + const QueueReleased + const QueueTruncated + type QueueLifecycleListener interface + OnAny func(callback func(QueueLifecycleEvent[V])) QueueLifecycleListener[V] + OnDestroyed func(callback func(QueueLifecycleEvent[V])) QueueLifecycleListener[V] + OnReleased func(callback func(QueueLifecycleEvent[V])) QueueLifecycleListener[V] + OnTruncated func(callback func(QueueLifecycleEvent[V])) QueueLifecycleListener[V] + func NewQueueLifecycleListener[V any]() QueueLifecycleListener[V] + type Serializer interface + Deserialize func(data []byte) (*T, error) + Format func() string + Serialize func(object T) ([]byte, error) + func NewSerializer[T any](format string) Serializer[T] + type Session struct + func NewSession(ctx context.Context, options ...func(session *SessionOptions)) (*Session, error) + func (s *Session) AddSessionLifecycleListener(listener SessionLifecycleListener) + func (s *Session) Close() + func (s *Session) GetDisconnectTimeout() time.Duration + func (s *Session) GetOptions() *SessionOptions + func (s *Session) GetProtocolVersion() int32 + func (s *Session) GetReadyTimeout() time.Duration + func (s *Session) GetRequestTimeout() time.Duration + func (s *Session) ID() string + func (s *Session) IsClosed() bool + func (s *Session) NextFilterID() int64 + func (s *Session) NextRequestID() int64 + func (s *Session) RemoveSessionLifecycleListener(listener SessionLifecycleListener) + func (s *Session) String() string + type SessionLifecycleEvent interface + Source func() *Session + Type func() SessionLifecycleEventType + type SessionLifecycleEventType string + type SessionLifecycleListener interface + OnAny func(callback func(SessionLifecycleEvent)) SessionLifecycleListener + OnClosed func(callback func(SessionLifecycleEvent)) SessionLifecycleListener + OnConnected func(callback func(SessionLifecycleEvent)) SessionLifecycleListener + OnDisconnected func(callback func(SessionLifecycleEvent)) SessionLifecycleListener + OnReconnected func(callback func(SessionLifecycleEvent)) SessionLifecycleListener + func NewSessionLifecycleListener() SessionLifecycleListener + type SessionOptions struct + Address string + CaCertPath string + ClientCertPath string + ClientKeyPath string + DisconnectTimeout time.Duration + Format string + IgnoreInvalidCerts bool + PlainText bool + ReadyTimeout time.Duration + RequestTimeout time.Duration + Scope string + TlSConfig *tls.Config + func (s *SessionOptions) IsPlainText() bool + func (s *SessionOptions) String() string + type StreamedEntry struct + Err error + Key K + Value V + type StreamedKey struct + Err error + Key K + type StreamedValue struct + Err error + IsValueEmpty bool + Value V + type V1ProxyProtocol string + func GetCacheServiceProtocol() V1ProxyProtocol v2.0.0-rc3 Dec 13, 2024 v2.0.0-rc2 Dec 8, 2024 v2.0.0-rc1 Dec 5, 2024 Other modules containing this package github.com/oracle/coherence-go-client