// This file contains auto-generated code. // Generated from `SentinelInfo` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class SentinelInfo { public string MasterName { get => throw null; set => throw null; } public string[] RedisMasters { get => throw null; set => throw null; } public string[] RedisSlaves { get => throw null; set => throw null; } public SentinelInfo(string masterName, System.Collections.Generic.IEnumerable redisMasters, System.Collections.Generic.IEnumerable redisReplicas) => throw null; public override string ToString() => throw null; } namespace ServiceStack { namespace Redis { // Generated from `ServiceStack.Redis.BasicRedisClientManager` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class BasicRedisClientManager : System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.IRedisFailover, ServiceStack.Redis.IRedisClientsManagerAsync, ServiceStack.Redis.IRedisClientsManager, ServiceStack.Redis.IHasRedisResolver, ServiceStack.Caching.ICacheClientAsync, ServiceStack.Caching.ICacheClient { public bool Add(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Add(string key, T value, System.DateTime expiresAt) => throw null; public bool Add(string key, T value) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; public BasicRedisClientManager(params string[] readWriteHosts) => throw null; public BasicRedisClientManager(int initialDb, params string[] readWriteHosts) => throw null; public BasicRedisClientManager(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts, System.Int64? initalDb = default(System.Int64?)) => throw null; public BasicRedisClientManager(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts, System.Int64? initalDb = default(System.Int64?)) => throw null; public BasicRedisClientManager() => throw null; public System.Func ClientFactory { get => throw null; set => throw null; } public int? ConnectTimeout { get => throw null; set => throw null; } public System.Action ConnectionFilter { get => throw null; set => throw null; } public System.Int64? Db { get => throw null; set => throw null; } public System.Int64 Decrement(string key, System.UInt32 amount) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.DecrementAsync(string key, System.UInt32 amount, System.Threading.CancellationToken token) => throw null; public void Dispose() => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; public void FailoverTo(params string[] readWriteHosts) => throw null; public void FailoverTo(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts) => throw null; public void FlushAll() => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.FlushAllAsync(System.Threading.CancellationToken token) => throw null; public T Get(string key) => throw null; public System.Collections.Generic.IDictionary GetAll(System.Collections.Generic.IEnumerable keys) => throw null; System.Threading.Tasks.Task> ServiceStack.Caching.ICacheClientAsync.GetAllAsync(System.Collections.Generic.IEnumerable keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.GetAsync(string key, System.Threading.CancellationToken token) => throw null; public ServiceStack.Caching.ICacheClient GetCacheClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetCacheClientAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.IRedisClient GetClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetClientAsync(System.Threading.CancellationToken token) => throw null; System.Collections.Generic.IAsyncEnumerable ServiceStack.Caching.ICacheClientAsync.GetKeysByPatternAsync(string pattern, System.Threading.CancellationToken token) => throw null; public ServiceStack.Caching.ICacheClient GetReadOnlyCacheClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetReadOnlyCacheClientAsync(System.Threading.CancellationToken token) => throw null; public virtual ServiceStack.Redis.IRedisClient GetReadOnlyClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetReadOnlyClientAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.GetTimeToLiveAsync(string key, System.Threading.CancellationToken token) => throw null; public int? IdleTimeOutSecs { get => throw null; set => throw null; } public System.Int64 Increment(string key, System.UInt32 amount) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.IncrementAsync(string key, System.UInt32 amount, System.Threading.CancellationToken token) => throw null; public static ServiceStack.Logging.ILog Log; public string NamespacePrefix { get => throw null; set => throw null; } public System.Collections.Generic.List> OnFailover { get => throw null; set => throw null; } protected virtual void OnStart() => throw null; protected int RedisClientCounter; public ServiceStack.Redis.IRedisResolver RedisResolver { get => throw null; set => throw null; } public bool Remove(string key) => throw null; public void RemoveAll(System.Collections.Generic.IEnumerable keys) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveAllAsync(System.Collections.Generic.IEnumerable keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveAsync(string key, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveExpiredEntriesAsync(System.Threading.CancellationToken token) => throw null; public bool Replace(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Replace(string key, T value, System.DateTime expiresAt) => throw null; public bool Replace(string key, T value) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; public bool Set(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Set(string key, T value, System.DateTime expiresAt) => throw null; public bool Set(string key, T value) => throw null; public void SetAll(System.Collections.Generic.IDictionary values) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAllAsync(System.Collections.Generic.IDictionary values, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; public int? SocketReceiveTimeout { get => throw null; set => throw null; } public int? SocketSendTimeout { get => throw null; set => throw null; } public void Start() => throw null; } // Generated from `ServiceStack.Redis.BasicRedisResolver` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class BasicRedisResolver : ServiceStack.Redis.IRedisResolverExtended, ServiceStack.Redis.IRedisResolver { public BasicRedisResolver(System.Collections.Generic.IEnumerable masters, System.Collections.Generic.IEnumerable replicas) => throw null; public System.Func ClientFactory { get => throw null; set => throw null; } public ServiceStack.Redis.RedisClient CreateMasterClient(int desiredIndex) => throw null; public ServiceStack.Redis.RedisClient CreateRedisClient(ServiceStack.Redis.RedisEndpoint config, bool master) => throw null; public ServiceStack.Redis.RedisClient CreateSlaveClient(int desiredIndex) => throw null; public ServiceStack.Redis.RedisEndpoint GetReadOnlyHost(int desiredIndex) => throw null; public ServiceStack.Redis.RedisEndpoint GetReadWriteHost(int desiredIndex) => throw null; public ServiceStack.Redis.RedisEndpoint[] Masters { get => throw null; } public int ReadOnlyHostsCount { get => throw null; set => throw null; } public int ReadWriteHostsCount { get => throw null; set => throw null; } public ServiceStack.Redis.RedisEndpoint[] Replicas { get => throw null; } public virtual void ResetMasters(System.Collections.Generic.List newMasters) => throw null; public virtual void ResetMasters(System.Collections.Generic.IEnumerable hosts) => throw null; public virtual void ResetSlaves(System.Collections.Generic.List newReplicas) => throw null; public virtual void ResetSlaves(System.Collections.Generic.IEnumerable hosts) => throw null; } // Generated from `ServiceStack.Redis.Commands` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class Commands { public static System.Byte[] Addr; public static System.Byte[] After; public static System.Byte[] Alpha; public static System.Byte[] Append; public static System.Byte[] Asc; public static System.Byte[] Auth; public static System.Byte[] BLPop; public static System.Byte[] BRPop; public static System.Byte[] BRPopLPush; public static System.Byte[] Before; public static System.Byte[] BgRewriteAof; public static System.Byte[] BgSave; public static System.Byte[] BitCount; public static System.Byte[] By; public static System.Byte[] Client; public static System.Byte[] Config; public static System.Byte[] Count; public static System.Byte[] DbSize; public static System.Byte[] Debug; public static System.Byte[] Decr; public static System.Byte[] DecrBy; public static System.Byte[] Del; public static System.Byte[] Desc; public static System.Byte[] Discard; public static System.Byte[] Dump; public static System.Byte[] Echo; public static System.Byte[] Eval; public static System.Byte[] EvalSha; public static System.Byte[] Ex; public static System.Byte[] Exec; public static System.Byte[] Exists; public static System.Byte[] Expire; public static System.Byte[] ExpireAt; public static System.Byte[] Failover; public static System.Byte[] Feet; public static System.Byte[] Flush; public static System.Byte[] FlushAll; public static System.Byte[] FlushDb; public static System.Byte[] GeoAdd; public static System.Byte[] GeoDist; public static System.Byte[] GeoHash; public static System.Byte[] GeoPos; public static System.Byte[] GeoRadius; public static System.Byte[] GeoRadiusByMember; public static System.Byte[] Get; public static System.Byte[] GetBit; public static System.Byte[] GetMasterAddrByName; public static System.Byte[] GetName; public static System.Byte[] GetRange; public static System.Byte[] GetSet; public static System.Byte[] GetUnit(string unit) => throw null; public static System.Byte[] HDel; public static System.Byte[] HExists; public static System.Byte[] HGet; public static System.Byte[] HGetAll; public static System.Byte[] HIncrBy; public static System.Byte[] HIncrByFloat; public static System.Byte[] HKeys; public static System.Byte[] HLen; public static System.Byte[] HMGet; public static System.Byte[] HMSet; public static System.Byte[] HScan; public static System.Byte[] HSet; public static System.Byte[] HSetNx; public static System.Byte[] HVals; public static System.Byte[] Id; public static System.Byte[] IdleTime; public static System.Byte[] Incr; public static System.Byte[] IncrBy; public static System.Byte[] IncrByFloat; public static System.Byte[] Info; public static System.Byte[] Keys; public static System.Byte[] Kill; public static System.Byte[] Kilometers; public static System.Byte[] LIndex; public static System.Byte[] LInsert; public static System.Byte[] LLen; public static System.Byte[] LPop; public static System.Byte[] LPush; public static System.Byte[] LPushX; public static System.Byte[] LRange; public static System.Byte[] LRem; public static System.Byte[] LSet; public static System.Byte[] LTrim; public static System.Byte[] LastSave; public static System.Byte[] Limit; public static System.Byte[] List; public static System.Byte[] Load; public static System.Byte[] MGet; public static System.Byte[] MSet; public static System.Byte[] MSetNx; public static System.Byte[] Master; public static System.Byte[] Masters; public static System.Byte[] Match; public static System.Byte[] Meters; public static System.Byte[] Migrate; public static System.Byte[] Miles; public static System.Byte[] Monitor; public static System.Byte[] Move; public static System.Byte[] Multi; public static System.Byte[] No; public static System.Byte[] NoSave; public static System.Byte[] Nx; public static System.Byte[] Object; public static System.Byte[] One; public static System.Byte[] PExpire; public static System.Byte[] PExpireAt; public static System.Byte[] PSetEx; public static System.Byte[] PSubscribe; public static System.Byte[] PTtl; public static System.Byte[] PUnSubscribe; public static System.Byte[] Pause; public static System.Byte[] Persist; public static System.Byte[] PfAdd; public static System.Byte[] PfCount; public static System.Byte[] PfMerge; public static System.Byte[] Ping; public static System.Byte[] Publish; public static System.Byte[] Px; public static System.Byte[] Quit; public static System.Byte[] RPop; public static System.Byte[] RPopLPush; public static System.Byte[] RPush; public static System.Byte[] RPushX; public static System.Byte[] RandomKey; public static System.Byte[] Rename; public static System.Byte[] RenameNx; public static System.Byte[] ResetStat; public static System.Byte[] Restore; public static System.Byte[] Rewrite; public static System.Byte[] Role; public static System.Byte[] SAdd; public static System.Byte[] SCard; public static System.Byte[] SDiff; public static System.Byte[] SDiffStore; public static System.Byte[] SInter; public static System.Byte[] SInterStore; public static System.Byte[] SIsMember; public static System.Byte[] SMembers; public static System.Byte[] SMove; public static System.Byte[] SPop; public static System.Byte[] SRandMember; public static System.Byte[] SRem; public static System.Byte[] SScan; public static System.Byte[] SUnion; public static System.Byte[] SUnionStore; public static System.Byte[] Save; public static System.Byte[] Scan; public static System.Byte[] Script; public static System.Byte[] Segfault; public static System.Byte[] Select; public static System.Byte[] Sentinel; public static System.Byte[] Sentinels; public static System.Byte[] Set; public static System.Byte[] SetBit; public static System.Byte[] SetEx; public static System.Byte[] SetName; public static System.Byte[] SetNx; public static System.Byte[] SetRange; public static System.Byte[] Shutdown; public static System.Byte[] SkipMe; public static System.Byte[] SlaveOf; public static System.Byte[] Slaves; public static System.Byte[] Sleep; public static System.Byte[] Slowlog; public static System.Byte[] Sort; public static System.Byte[] Store; public static System.Byte[] StrLen; public static System.Byte[] Subscribe; public static System.Byte[] Time; public static System.Byte[] Ttl; public static System.Byte[] Type; public static System.Byte[] UnSubscribe; public static System.Byte[] UnWatch; public static System.Byte[] Watch; public static System.Byte[] WithCoord; public static System.Byte[] WithDist; public static System.Byte[] WithHash; public static System.Byte[] WithScores; public static System.Byte[] Xx; public static System.Byte[] ZAdd; public static System.Byte[] ZCard; public static System.Byte[] ZCount; public static System.Byte[] ZIncrBy; public static System.Byte[] ZInterStore; public static System.Byte[] ZLexCount; public static System.Byte[] ZRange; public static System.Byte[] ZRangeByLex; public static System.Byte[] ZRangeByScore; public static System.Byte[] ZRank; public static System.Byte[] ZRem; public static System.Byte[] ZRemRangeByLex; public static System.Byte[] ZRemRangeByRank; public static System.Byte[] ZRemRangeByScore; public static System.Byte[] ZRevRange; public static System.Byte[] ZRevRangeByScore; public static System.Byte[] ZRevRank; public static System.Byte[] ZScan; public static System.Byte[] ZScore; public static System.Byte[] ZUnionStore; } // Generated from `ServiceStack.Redis.IHandleClientDispose` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IHandleClientDispose { void DisposeClient(ServiceStack.Redis.RedisNativeClient client); } // Generated from `ServiceStack.Redis.IHasRedisResolver` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IHasRedisResolver { ServiceStack.Redis.IRedisResolver RedisResolver { get; set; } } // Generated from `ServiceStack.Redis.IRedisFailover` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IRedisFailover { void FailoverTo(params string[] readWriteHosts); void FailoverTo(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts); System.Collections.Generic.List> OnFailover { get; } } // Generated from `ServiceStack.Redis.IRedisResolver` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IRedisResolver { System.Func ClientFactory { get; set; } ServiceStack.Redis.RedisClient CreateMasterClient(int desiredIndex); ServiceStack.Redis.RedisClient CreateSlaveClient(int desiredIndex); int ReadOnlyHostsCount { get; } int ReadWriteHostsCount { get; } void ResetMasters(System.Collections.Generic.IEnumerable hosts); void ResetSlaves(System.Collections.Generic.IEnumerable hosts); } // Generated from `ServiceStack.Redis.IRedisResolverExtended` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IRedisResolverExtended : ServiceStack.Redis.IRedisResolver { ServiceStack.Redis.RedisClient CreateRedisClient(ServiceStack.Redis.RedisEndpoint config, bool master); ServiceStack.Redis.RedisEndpoint GetReadOnlyHost(int desiredIndex); ServiceStack.Redis.RedisEndpoint GetReadWriteHost(int desiredIndex); } // Generated from `ServiceStack.Redis.IRedisSentinel` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IRedisSentinel : System.IDisposable { ServiceStack.Redis.IRedisClientsManager Start(); } // Generated from `ServiceStack.Redis.InvalidAccessException` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class InvalidAccessException : ServiceStack.Redis.RedisException { public InvalidAccessException(int threadId, string stackTrace) : base(default(string)) => throw null; } // Generated from `ServiceStack.Redis.PooledRedisClientManager` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class PooledRedisClientManager : System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.IRedisFailover, ServiceStack.Redis.IRedisClientsManagerAsync, ServiceStack.Redis.IRedisClientsManager, ServiceStack.Redis.IRedisClientCacheManager, ServiceStack.Redis.IHasRedisResolver, ServiceStack.Redis.IHandleClientDispose { public bool AssertAccessOnlyOnSameThread { get => throw null; set => throw null; } protected ServiceStack.Redis.RedisClientManagerConfig Config { get => throw null; set => throw null; } public int? ConnectTimeout { get => throw null; set => throw null; } public System.Action ConnectionFilter { get => throw null; set => throw null; } public System.Int64? Db { get => throw null; set => throw null; } // Generated from `ServiceStack.Redis.PooledRedisClientManager+DisposablePooledClient<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class DisposablePooledClient : System.IDisposable where T : ServiceStack.Redis.RedisNativeClient { public T Client { get => throw null; } public DisposablePooledClient(ServiceStack.Redis.PooledRedisClientManager clientManager) => throw null; public void Dispose() => throw null; } public void Dispose() => throw null; protected void Dispose(ServiceStack.Redis.RedisClient redisClient) => throw null; protected virtual void Dispose(bool disposing) => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; public void DisposeClient(ServiceStack.Redis.RedisNativeClient client) => throw null; public void DisposeReadOnlyClient(ServiceStack.Redis.RedisNativeClient client) => throw null; public void DisposeWriteClient(ServiceStack.Redis.RedisNativeClient client) => throw null; public void FailoverTo(params string[] readWriteHosts) => throw null; public void FailoverTo(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts) => throw null; public ServiceStack.Caching.ICacheClient GetCacheClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetCacheClientAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.IRedisClient GetClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetClientAsync(System.Threading.CancellationToken token) => throw null; public int[] GetClientPoolActiveStates() => throw null; public ServiceStack.Redis.PooledRedisClientManager.DisposablePooledClient GetDisposableClient() where T : ServiceStack.Redis.RedisNativeClient => throw null; public ServiceStack.Caching.ICacheClient GetReadOnlyCacheClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetReadOnlyCacheClientAsync(System.Threading.CancellationToken token) => throw null; public virtual ServiceStack.Redis.IRedisClient GetReadOnlyClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetReadOnlyClientAsync(System.Threading.CancellationToken token) => throw null; public int[] GetReadOnlyClientPoolActiveStates() => throw null; public System.Collections.Generic.Dictionary GetStats() => throw null; public int? IdleTimeOutSecs { get => throw null; set => throw null; } public string NamespacePrefix { get => throw null; set => throw null; } public System.Collections.Generic.List> OnFailover { get => throw null; set => throw null; } protected virtual void OnStart() => throw null; protected int PoolSizeMultiplier; public int? PoolTimeout { get => throw null; set => throw null; } public PooledRedisClientManager(params string[] readWriteHosts) => throw null; public PooledRedisClientManager(int poolSize, int poolTimeOutSeconds, params string[] readWriteHosts) => throw null; public PooledRedisClientManager(System.Int64 initialDb, params string[] readWriteHosts) => throw null; public PooledRedisClientManager(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts, System.Int64 initialDb) => throw null; public PooledRedisClientManager(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts, ServiceStack.Redis.RedisClientManagerConfig config, System.Int64? initialDb, int? poolSizeMultiplier, int? poolTimeOutSeconds) => throw null; public PooledRedisClientManager(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts, ServiceStack.Redis.RedisClientManagerConfig config) => throw null; public PooledRedisClientManager(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts) => throw null; public PooledRedisClientManager() => throw null; protected int ReadPoolIndex; public int RecheckPoolAfterMs; protected int RedisClientCounter; public ServiceStack.Redis.IRedisResolver RedisResolver { get => throw null; set => throw null; } public int? SocketReceiveTimeout { get => throw null; set => throw null; } public int? SocketSendTimeout { get => throw null; set => throw null; } public void Start() => throw null; public static bool UseGetClientBlocking; protected int WritePoolIndex; // ERR: Stub generator didn't handle member: ~PooledRedisClientManager } // Generated from `ServiceStack.Redis.RedisAllPurposePipeline` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisAllPurposePipeline : ServiceStack.Redis.RedisCommandQueue, System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync, ServiceStack.Redis.Pipeline.IRedisQueueableOperation, ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync, ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperation, ServiceStack.Redis.Pipeline.IRedisPipelineSharedAsync, ServiceStack.Redis.Pipeline.IRedisPipelineShared, ServiceStack.Redis.Pipeline.IRedisPipelineAsync, ServiceStack.Redis.Pipeline.IRedisPipeline { protected void ClosePipeline() => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteBytesQueuedCommandAsync(System.Func> bytesReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteDoubleQueuedCommandAsync(System.Func> doubleReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteIntQueuedCommandAsync(System.Func> intReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteLongQueuedCommandAsync(System.Func> longReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteMultiBytesQueuedCommandAsync(System.Func> multiBytesReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteMultiStringQueuedCommandAsync(System.Func>> multiStringReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteRedisDataQueuedCommandAsync(System.Func> redisDataReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteStringQueuedCommandAsync(System.Func> stringReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteVoidQueuedCommandAsync(System.Func voidReadCommand) => throw null; public virtual void Dispose() => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; protected void Execute() => throw null; protected System.Threading.Tasks.ValueTask ExecuteAsync() => throw null; public void Flush() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Pipeline.IRedisPipelineSharedAsync.FlushAsync(System.Threading.CancellationToken token) => throw null; protected virtual void Init() => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func>> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func>> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func>> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync.QueueCommand(System.Func> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public RedisAllPurposePipeline(ServiceStack.Redis.RedisClient redisClient) : base(default(ServiceStack.Redis.RedisClient)) => throw null; public virtual bool Replay() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Pipeline.IRedisPipelineSharedAsync.ReplayAsync(System.Threading.CancellationToken token) => throw null; } // Generated from `ServiceStack.Redis.RedisClient` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisClient : ServiceStack.Redis.RedisNativeClient, System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.IRedisClientAsync, ServiceStack.Redis.IRedisClient, ServiceStack.Data.IEntityStoreAsync, ServiceStack.Data.IEntityStore, ServiceStack.Caching.IRemoveByPatternAsync, ServiceStack.Caching.IRemoveByPattern, ServiceStack.Caching.ICacheClientExtended, ServiceStack.Caching.ICacheClientAsync, ServiceStack.Caching.ICacheClient { public System.IDisposable AcquireLock(string key, System.TimeSpan timeOut) => throw null; public System.IDisposable AcquireLock(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AcquireLockAsync(string key, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public bool Add(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Add(string key, T value, System.DateTime expiresAt) => throw null; public bool Add(string key, T value) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; public System.Int64 AddGeoMember(string key, double longitude, double latitude, string member) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddGeoMemberAsync(string key, double longitude, double latitude, string member, System.Threading.CancellationToken token) => throw null; public System.Int64 AddGeoMembers(string key, params ServiceStack.Redis.RedisGeo[] geoPoints) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddGeoMembersAsync(string key, params ServiceStack.Redis.RedisGeo[] geoPoints) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddGeoMembersAsync(string key, ServiceStack.Redis.RedisGeo[] geoPoints, System.Threading.CancellationToken token) => throw null; public void AddItemToList(string listId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddItemToListAsync(string listId, string value, System.Threading.CancellationToken token) => throw null; public void AddItemToSet(string setId, string item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddItemToSetAsync(string setId, string item, System.Threading.CancellationToken token) => throw null; public bool AddItemToSortedSet(string setId, string value, double score) => throw null; public bool AddItemToSortedSet(string setId, string value, System.Int64 score) => throw null; public bool AddItemToSortedSet(string setId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddItemToSortedSetAsync(string setId, string value, double score, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddItemToSortedSetAsync(string setId, string value, System.Threading.CancellationToken token) => throw null; public void AddRangeToList(string listId, System.Collections.Generic.List values) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddRangeToListAsync(string listId, System.Collections.Generic.List values, System.Threading.CancellationToken token) => throw null; public void AddRangeToSet(string setId, System.Collections.Generic.List items) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddRangeToSetAsync(string setId, System.Collections.Generic.List items, System.Threading.CancellationToken token) => throw null; public bool AddRangeToSortedSet(string setId, System.Collections.Generic.List values, double score) => throw null; public bool AddRangeToSortedSet(string setId, System.Collections.Generic.List values, System.Int64 score) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddRangeToSortedSetAsync(string setId, System.Collections.Generic.List values, double score, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddRangeToSortedSetAsync(string setId, System.Collections.Generic.List values, System.Int64 score, System.Threading.CancellationToken token) => throw null; public bool AddToHyperLog(string key, params string[] elements) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddToHyperLogAsync(string key, string[] elements, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AddToHyperLogAsync(string key, params string[] elements) => throw null; public System.Int64 AppendToValue(string key, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.AppendToValueAsync(string key, string value, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.Generic.IRedisTypedClient As() => throw null; ServiceStack.Redis.Generic.IRedisTypedClientAsync ServiceStack.Redis.IRedisClientAsync.As() => throw null; public ServiceStack.Redis.IRedisClientAsync AsAsync() => throw null; public void AssertNotInTransaction() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BackgroundRewriteAppendOnlyFileAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BackgroundSaveAsync(System.Threading.CancellationToken token) => throw null; public string BlockingDequeueItemFromList(string listId, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BlockingDequeueItemFromListAsync(string listId, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.ItemRef BlockingDequeueItemFromLists(string[] listIds, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BlockingDequeueItemFromListsAsync(string[] listIds, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public string BlockingPopAndPushItemBetweenLists(string fromListId, string toListId, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BlockingPopAndPushItemBetweenListsAsync(string fromListId, string toListId, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public string BlockingPopItemFromList(string listId, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BlockingPopItemFromListAsync(string listId, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.ItemRef BlockingPopItemFromLists(string[] listIds, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BlockingPopItemFromListsAsync(string[] listIds, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public string BlockingRemoveStartFromList(string listId, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BlockingRemoveStartFromListAsync(string listId, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.ItemRef BlockingRemoveStartFromLists(string[] listIds, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.BlockingRemoveStartFromListsAsync(string[] listIds, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public double CalculateDistanceBetweenGeoMembers(string key, string fromMember, string toMember, string unit = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.CalculateDistanceBetweenGeoMembersAsync(string key, string fromMember, string toMember, string unit, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.CalculateSha1Async(string luaBody, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisClient CloneClient() => throw null; public bool ContainsKey(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ContainsKeyAsync(string key, System.Threading.CancellationToken token) => throw null; public static System.Func> ConvertToHashFn; public System.DateTime ConvertToServerDate(System.DateTime expiresAt) => throw null; public System.Int64 CountHyperLog(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.CountHyperLogAsync(string key, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.Pipeline.IRedisPipeline CreatePipeline() => throw null; ServiceStack.Redis.Pipeline.IRedisPipelineAsync ServiceStack.Redis.IRedisClientAsync.CreatePipeline() => throw null; public override ServiceStack.Redis.IRedisSubscription CreateSubscription() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.CreateSubscriptionAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.IRedisTransaction CreateTransaction() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.CreateTransactionAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisText Custom(params object[] cmdWithArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.CustomAsync(params object[] cmdWithArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.CustomAsync(object[] cmdWithArgs, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.DbSizeAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 Decrement(string key, System.UInt32 amount) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.DecrementAsync(string key, System.UInt32 amount, System.Threading.CancellationToken token) => throw null; public System.Int64 DecrementValue(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.DecrementValueAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Int64 DecrementValueBy(string key, int count) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.DecrementValueByAsync(string key, int count, System.Threading.CancellationToken token) => throw null; public void Delete(T entity) => throw null; public void DeleteAll() => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.DeleteAllAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.DeleteAsync(T entity, System.Threading.CancellationToken token) => throw null; public void DeleteById(object id) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.DeleteByIdAsync(object id, System.Threading.CancellationToken token) => throw null; public void DeleteByIds(System.Collections.ICollection ids) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.DeleteByIdsAsync(System.Collections.ICollection ids, System.Threading.CancellationToken token) => throw null; public string DequeueItemFromList(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.DequeueItemFromListAsync(string listId, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.EchoAsync(string text, System.Threading.CancellationToken token) => throw null; public void EnqueueItemOnList(string listId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.EnqueueItemOnListAsync(string listId, string value, System.Threading.CancellationToken token) => throw null; public void Exec(System.Action action) => throw null; public T Exec(System.Func action) => throw null; public T ExecCachedLua(string scriptBody, System.Func scriptSha1) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecCachedLuaAsync(string scriptBody, System.Func> scriptSha1, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisText ExecLua(string luaBody, string[] keys, string[] args) => throw null; public ServiceStack.Redis.RedisText ExecLua(string body, params string[] args) => throw null; public System.Int64 ExecLuaAsInt(string luaBody, string[] keys, string[] args) => throw null; public System.Int64 ExecLuaAsInt(string body, params string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsIntAsync(string luaBody, params string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsIntAsync(string body, string[] keys, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsIntAsync(string body, string[] args, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List ExecLuaAsList(string luaBody, string[] keys, string[] args) => throw null; public System.Collections.Generic.List ExecLuaAsList(string body, params string[] args) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.ExecLuaAsListAsync(string luaBody, params string[] args) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.ExecLuaAsListAsync(string body, string[] keys, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.ExecLuaAsListAsync(string body, string[] args, System.Threading.CancellationToken token) => throw null; public string ExecLuaAsString(string sha1, string[] keys, string[] args) => throw null; public string ExecLuaAsString(string body, params string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsStringAsync(string luaBody, string[] keys, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsStringAsync(string luaBody, params string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsStringAsync(string body, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsync(string luaBody, string[] keys, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsync(string body, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaAsync(string body, params string[] args) => throw null; public ServiceStack.Redis.RedisText ExecLuaSha(string sha1, string[] keys, string[] args) => throw null; public ServiceStack.Redis.RedisText ExecLuaSha(string sha1, params string[] args) => throw null; public System.Int64 ExecLuaShaAsInt(string sha1, string[] keys, string[] args) => throw null; public System.Int64 ExecLuaShaAsInt(string sha1, params string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsIntAsync(string sha1, string[] keys, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsIntAsync(string sha1, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsIntAsync(string sha1, params string[] args) => throw null; public System.Collections.Generic.List ExecLuaShaAsList(string sha1, string[] keys, string[] args) => throw null; public System.Collections.Generic.List ExecLuaShaAsList(string sha1, params string[] args) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsListAsync(string sha1, string[] keys, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsListAsync(string sha1, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsListAsync(string sha1, params string[] args) => throw null; public string ExecLuaShaAsString(string sha1, string[] keys, string[] args) => throw null; public string ExecLuaShaAsString(string sha1, params string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsStringAsync(string sha1, string[] keys, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsStringAsync(string sha1, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsStringAsync(string sha1, params string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsync(string sha1, string[] keys, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsync(string sha1, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExecLuaShaAsync(string sha1, params string[] args) => throw null; public bool ExpireEntryAt(string key, System.DateTime expireAt) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExpireEntryAtAsync(string key, System.DateTime expireAt, System.Threading.CancellationToken token) => throw null; public bool ExpireEntryIn(string key, System.TimeSpan expireIn) => throw null; public bool ExpireEntryIn(System.Byte[] key, System.TimeSpan expireIn) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ExpireEntryInAsync(string key, System.TimeSpan expireIn, System.Threading.CancellationToken token) => throw null; public string[] FindGeoMembersInRadius(string key, string member, double radius, string unit) => throw null; public string[] FindGeoMembersInRadius(string key, double longitude, double latitude, double radius, string unit) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.FindGeoMembersInRadiusAsync(string key, string member, double radius, string unit, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.FindGeoMembersInRadiusAsync(string key, double longitude, double latitude, double radius, string unit, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List FindGeoResultsInRadius(string key, string member, double radius, string unit, int? count = default(int?), bool? sortByNearest = default(bool?)) => throw null; public System.Collections.Generic.List FindGeoResultsInRadius(string key, double longitude, double latitude, double radius, string unit, int? count = default(int?), bool? sortByNearest = default(bool?)) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.FindGeoResultsInRadiusAsync(string key, string member, double radius, string unit, int? count, bool? sortByNearest, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.FindGeoResultsInRadiusAsync(string key, double longitude, double latitude, double radius, string unit, int? count, bool? sortByNearest, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.FlushAllAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.FlushDbAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ForegroundSaveAsync(System.Threading.CancellationToken token) => throw null; public T Get(string key) => throw null; public System.Collections.Generic.IList GetAll() => throw null; public System.Collections.Generic.IDictionary GetAll(System.Collections.Generic.IEnumerable keys) => throw null; System.Threading.Tasks.Task> ServiceStack.Caching.ICacheClientAsync.GetAllAsync(System.Collections.Generic.IEnumerable keys, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.Dictionary GetAllEntriesFromHash(string hashId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetAllEntriesFromHashAsync(string hashId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetAllItemsFromList(string listId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetAllItemsFromListAsync(string listId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.HashSet GetAllItemsFromSet(string setId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetAllItemsFromSetAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetAllItemsFromSortedSet(string setId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetAllItemsFromSortedSetAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetAllItemsFromSortedSetDesc(string setId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetAllItemsFromSortedSetDescAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetAllKeys() => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetAllKeysAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetAllWithScoresFromSortedSet(string setId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetAllWithScoresFromSortedSetAsync(string setId, System.Threading.CancellationToken token) => throw null; public string GetAndSetValue(string key, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetAndSetValueAsync(string key, string value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.GetAsync(string key, System.Threading.CancellationToken token) => throw null; public T GetById(object id) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.GetByIdAsync(object id, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IList GetByIds(System.Collections.ICollection ids) => throw null; System.Threading.Tasks.Task> ServiceStack.Data.IEntityStoreAsync.GetByIdsAsync(System.Collections.ICollection ids, System.Threading.CancellationToken token) => throw null; public string GetClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetClientAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List> GetClientsInfo() => throw null; System.Threading.Tasks.ValueTask>> ServiceStack.Redis.IRedisClientAsync.GetClientsInfoAsync(System.Threading.CancellationToken token) => throw null; public string GetConfig(string configItem) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetConfigAsync(string configItem, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.HashSet GetDifferencesFromSet(string fromSetId, params string[] withSetIds) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetDifferencesFromSetAsync(string fromSetId, string[] withSetIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetDifferencesFromSetAsync(string fromSetId, params string[] withSetIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetEntryTypeAsync(string key, System.Threading.CancellationToken token) => throw null; public T GetFromHash(object id) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetFromHashAsync(object id, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetGeoCoordinates(string key, params string[] members) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetGeoCoordinatesAsync(string key, string[] members, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetGeoCoordinatesAsync(string key, params string[] members) => throw null; public string[] GetGeohashes(string key, params string[] members) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetGeohashesAsync(string key, string[] members, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetGeohashesAsync(string key, params string[] members) => throw null; public System.Int64 GetHashCount(string hashId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetHashCountAsync(string hashId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetHashKeys(string hashId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetHashKeysAsync(string hashId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetHashValues(string hashId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetHashValuesAsync(string hashId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.HashSet GetIntersectFromSets(params string[] setIds) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetIntersectFromSetsAsync(string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetIntersectFromSetsAsync(params string[] setIds) => throw null; public string GetItemFromList(string listId, int listIndex) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetItemFromListAsync(string listId, int listIndex, System.Threading.CancellationToken token) => throw null; public System.Int64 GetItemIndexInSortedSet(string setId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetItemIndexInSortedSetAsync(string setId, string value, System.Threading.CancellationToken token) => throw null; public System.Int64 GetItemIndexInSortedSetDesc(string setId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetItemIndexInSortedSetDescAsync(string setId, string value, System.Threading.CancellationToken token) => throw null; public double GetItemScoreInSortedSet(string setId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetItemScoreInSortedSetAsync(string setId, string value, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IEnumerable GetKeysByPattern(string pattern) => throw null; System.Collections.Generic.IAsyncEnumerable ServiceStack.Caching.ICacheClientAsync.GetKeysByPatternAsync(string pattern, System.Threading.CancellationToken token) => throw null; public static double GetLexicalScore(string value) => throw null; public System.Int64 GetListCount(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetListCountAsync(string listId, System.Threading.CancellationToken token) => throw null; public string GetRandomItemFromSet(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetRandomItemFromSetAsync(string setId, System.Threading.CancellationToken token) => throw null; public string GetRandomKey() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetRandomKeyAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromList(string listId, int startingFrom, int endingAt) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromListAsync(string listId, int startingFrom, int endingAt, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedList(string listId, int startingFrom, int endingAt) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedListAsync(string listId, int startingFrom, int endingAt, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedSet(string setId, int fromRank, int toRank) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetAsync(string setId, int fromRank, int toRank, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(string setId, string fromStringScore, string toStringScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(string setId, string fromStringScore, string toStringScore) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(string setId, double fromScore, double toScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(string setId, double fromScore, double toScore) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(string setId, System.Int64 fromScore, System.Int64 toScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(string setId, System.Int64 fromScore, System.Int64 toScore) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByHighestScoreAsync(string setId, string fromStringScore, string toStringScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByHighestScoreAsync(string setId, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByHighestScoreAsync(string setId, double fromScore, double toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByHighestScoreAsync(string setId, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByHighestScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByHighestScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(string setId, string fromStringScore, string toStringScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(string setId, string fromStringScore, string toStringScore) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(string setId, double fromScore, double toScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(string setId, double fromScore, double toScore) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(string setId, System.Int64 fromScore, System.Int64 toScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(string setId, System.Int64 fromScore, System.Int64 toScore) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByLowestScoreAsync(string setId, string fromStringScore, string toStringScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByLowestScoreAsync(string setId, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByLowestScoreAsync(string setId, double fromScore, double toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByLowestScoreAsync(string setId, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByLowestScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetByLowestScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetDesc(string setId, int fromRank, int toRank) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeFromSortedSetDescAsync(string setId, int fromRank, int toRank, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSet(string setId, int fromRank, int toRank) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetAsync(string setId, int fromRank, int toRank, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(string setId, string fromStringScore, string toStringScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(string setId, string fromStringScore, string toStringScore) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(string setId, double fromScore, double toScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(string setId, double fromScore, double toScore) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(string setId, System.Int64 fromScore, System.Int64 toScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(string setId, System.Int64 fromScore, System.Int64 toScore) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(string setId, string fromStringScore, string toStringScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(string setId, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(string setId, double fromScore, double toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(string setId, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(string setId, string fromStringScore, string toStringScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(string setId, string fromStringScore, string toStringScore) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(string setId, double fromScore, double toScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(string setId, double fromScore, double toScore) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(string setId, System.Int64 fromScore, System.Int64 toScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(string setId, System.Int64 fromScore, System.Int64 toScore) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(string setId, string fromStringScore, string toStringScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(string setId, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(string setId, double fromScore, double toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(string setId, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetDesc(string setId, int fromRank, int toRank) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetRangeWithScoresFromSortedSetDescAsync(string setId, int fromRank, int toRank, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisServerRole GetServerRole() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetServerRoleAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisText GetServerRoleInfo() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetServerRoleInfoAsync(System.Threading.CancellationToken token) => throw null; public System.DateTime GetServerTime() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetServerTimeAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 GetSetCount(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetSetCountAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IEnumerable GetSlowlog(int? numberOfRecords = default(int?)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetSlowlogAsync(int? numberOfRecords, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetSortedEntryValues(string setId, int startingFrom, int endingAt) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetSortedEntryValuesAsync(string setId, int startingFrom, int endingAt, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetSortedItemsFromList(string listId, ServiceStack.Redis.SortOptions sortOptions) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetSortedItemsFromListAsync(string listId, ServiceStack.Redis.SortOptions sortOptions, System.Threading.CancellationToken token) => throw null; public System.Int64 GetSortedSetCount(string setId, string fromStringScore, string toStringScore) => throw null; public System.Int64 GetSortedSetCount(string setId, double fromScore, double toScore) => throw null; public System.Int64 GetSortedSetCount(string setId, System.Int64 fromScore, System.Int64 toScore) => throw null; public System.Int64 GetSortedSetCount(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetSortedSetCountAsync(string setId, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetSortedSetCountAsync(string setId, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetSortedSetCountAsync(string setId, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetSortedSetCountAsync(string setId, System.Int64 fromScore, System.Int64 toScore, System.Threading.CancellationToken token) => throw null; public System.Int64 GetStringCount(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetStringCountAsync(string key, System.Threading.CancellationToken token) => throw null; public System.TimeSpan? GetTimeToLive(string key) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.GetTimeToLiveAsync(string key, System.Threading.CancellationToken token) => throw null; public string GetTypeIdsSetKey() => throw null; public string GetTypeIdsSetKey(System.Type type) => throw null; public string GetTypeSequenceKey() => throw null; public System.Collections.Generic.HashSet GetUnionFromSets(params string[] setIds) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetUnionFromSetsAsync(string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetUnionFromSetsAsync(params string[] setIds) => throw null; public string GetValue(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetValueAsync(string key, System.Threading.CancellationToken token) => throw null; public string GetValueFromHash(string hashId, string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.GetValueFromHashAsync(string hashId, string key, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetValues(System.Collections.Generic.List keys) => throw null; public System.Collections.Generic.List GetValues(System.Collections.Generic.List keys) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetValuesAsync(System.Collections.Generic.List keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetValuesAsync(System.Collections.Generic.List keys, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetValuesFromHash(string hashId, params string[] keys) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetValuesFromHashAsync(string hashId, string[] keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetValuesFromHashAsync(string hashId, params string[] keys) => throw null; public System.Collections.Generic.Dictionary GetValuesMap(System.Collections.Generic.List keys) => throw null; public System.Collections.Generic.Dictionary GetValuesMap(System.Collections.Generic.List keys) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetValuesMapAsync(System.Collections.Generic.List keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.GetValuesMapAsync(System.Collections.Generic.List keys, System.Threading.CancellationToken token) => throw null; public bool HasLuaScript(string sha1Ref) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.HasLuaScriptAsync(string sha1Ref, System.Threading.CancellationToken token) => throw null; public bool HashContainsEntry(string hashId, string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.HashContainsEntryAsync(string hashId, string key, System.Threading.CancellationToken token) => throw null; public ServiceStack.Model.IHasNamed Hashes { get => throw null; set => throw null; } ServiceStack.Model.IHasNamed ServiceStack.Redis.IRedisClientAsync.Hashes { get => throw null; } public System.Int64 Increment(string key, System.UInt32 amount) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.IncrementAsync(string key, System.UInt32 amount, System.Threading.CancellationToken token) => throw null; public double IncrementItemInSortedSet(string setId, string value, double incrementBy) => throw null; public double IncrementItemInSortedSet(string setId, string value, System.Int64 incrementBy) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.IncrementItemInSortedSetAsync(string setId, string value, double incrementBy, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.IncrementItemInSortedSetAsync(string setId, string value, System.Int64 incrementBy, System.Threading.CancellationToken token) => throw null; public System.Int64 IncrementValue(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.IncrementValueAsync(string key, System.Threading.CancellationToken token) => throw null; public double IncrementValueBy(string key, double count) => throw null; public System.Int64 IncrementValueBy(string key, int count) => throw null; public System.Int64 IncrementValueBy(string key, System.Int64 count) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.IncrementValueByAsync(string key, double count, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.IncrementValueByAsync(string key, int count, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.IncrementValueByAsync(string key, System.Int64 count, System.Threading.CancellationToken token) => throw null; public double IncrementValueInHash(string hashId, string key, double incrementBy) => throw null; public System.Int64 IncrementValueInHash(string hashId, string key, int incrementBy) => throw null; public System.Int64 IncrementValueInHash(string hashId, string key, System.Int64 incrementBy) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.IncrementValueInHashAsync(string hashId, string key, double incrementBy, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.IncrementValueInHashAsync(string hashId, string key, int incrementBy, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.InfoAsync(System.Threading.CancellationToken token) => throw null; public void Init() => throw null; public string this[string key] { get => throw null; set => throw null; } public void KillClient(string address) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.KillClientAsync(string address, System.Threading.CancellationToken token) => throw null; public System.Int64 KillClients(string fromAddress = default(string), string withId = default(string), ServiceStack.Redis.RedisClientType? ofType = default(ServiceStack.Redis.RedisClientType?), bool? skipMe = default(bool?)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.KillClientsAsync(string fromAddress, string withId, ServiceStack.Redis.RedisClientType? ofType, bool? skipMe, System.Threading.CancellationToken token) => throw null; public void KillRunningLuaScript() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.KillRunningLuaScriptAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.LastSaveAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Model.IHasNamed Lists { get => throw null; set => throw null; } ServiceStack.Model.IHasNamed ServiceStack.Redis.IRedisClientAsync.Lists { get => throw null; } public string LoadLuaScript(string body) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.LoadLuaScriptAsync(string body, System.Threading.CancellationToken token) => throw null; public void MergeHyperLogs(string toKey, params string[] fromKeys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.MergeHyperLogsAsync(string toKey, string[] fromKeys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.MergeHyperLogsAsync(string toKey, params string[] fromKeys) => throw null; public void MoveBetweenSets(string fromSetId, string toSetId, string item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.MoveBetweenSetsAsync(string fromSetId, string toSetId, string item, System.Threading.CancellationToken token) => throw null; public static ServiceStack.Redis.RedisClient New() => throw null; public static System.Func NewFactoryFn; public override void OnConnected() => throw null; public void PauseAllClients(System.TimeSpan duration) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PauseAllClientsAsync(System.TimeSpan duration, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PingAsync(System.Threading.CancellationToken token) => throw null; public string PopAndPushItemBetweenLists(string fromListId, string toListId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PopAndPushItemBetweenListsAsync(string fromListId, string toListId, System.Threading.CancellationToken token) => throw null; public string PopItemFromList(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PopItemFromListAsync(string listId, System.Threading.CancellationToken token) => throw null; public string PopItemFromSet(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PopItemFromSetAsync(string setId, System.Threading.CancellationToken token) => throw null; public string PopItemWithHighestScoreFromSortedSet(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PopItemWithHighestScoreFromSortedSetAsync(string setId, System.Threading.CancellationToken token) => throw null; public string PopItemWithLowestScoreFromSortedSet(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PopItemWithLowestScoreFromSortedSetAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List PopItemsFromSet(string setId, int count) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.PopItemsFromSetAsync(string setId, int count, System.Threading.CancellationToken token) => throw null; public void PrependItemToList(string listId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PrependItemToListAsync(string listId, string value, System.Threading.CancellationToken token) => throw null; public void PrependRangeToList(string listId, System.Collections.Generic.List values) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PrependRangeToListAsync(string listId, System.Collections.Generic.List values, System.Threading.CancellationToken token) => throw null; public System.Int64 PublishMessage(string toChannel, string message) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PublishMessageAsync(string toChannel, string message, System.Threading.CancellationToken token) => throw null; public void PushItemToList(string listId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.PushItemToListAsync(string listId, string value, System.Threading.CancellationToken token) => throw null; public RedisClient(string host, int port, string password = default(string), System.Int64 db = default(System.Int64)) => throw null; public RedisClient(string host, int port) => throw null; public RedisClient(string host) => throw null; public RedisClient(System.Uri uri) => throw null; public RedisClient(ServiceStack.Redis.RedisEndpoint config) => throw null; public RedisClient() => throw null; public bool Remove(string key) => throw null; public bool Remove(System.Byte[] key) => throw null; public void RemoveAll(System.Collections.Generic.IEnumerable keys) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveAllAsync(System.Collections.Generic.IEnumerable keys, System.Threading.CancellationToken token) => throw null; public void RemoveAllFromList(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveAllFromListAsync(string listId, System.Threading.CancellationToken token) => throw null; public void RemoveAllLuaScripts() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveAllLuaScriptsAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveAsync(string key, System.Threading.CancellationToken token) => throw null; public void RemoveByPattern(string pattern) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.IRemoveByPatternAsync.RemoveByPatternAsync(string pattern, System.Threading.CancellationToken token) => throw null; public void RemoveByRegex(string pattern) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.IRemoveByPatternAsync.RemoveByRegexAsync(string regex, System.Threading.CancellationToken token) => throw null; public string RemoveEndFromList(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveEndFromListAsync(string listId, System.Threading.CancellationToken token) => throw null; public bool RemoveEntry(params string[] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveEntryAsync(string[] keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveEntryAsync(params string[] args) => throw null; public bool RemoveEntryFromHash(string hashId, string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveEntryFromHashAsync(string hashId, string key, System.Threading.CancellationToken token) => throw null; public void RemoveExpiredEntries() => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveExpiredEntriesAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 RemoveItemFromList(string listId, string value, int noOfMatches) => throw null; public System.Int64 RemoveItemFromList(string listId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveItemFromListAsync(string listId, string value, int noOfMatches, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveItemFromListAsync(string listId, string value, System.Threading.CancellationToken token) => throw null; public void RemoveItemFromSet(string setId, string item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveItemFromSetAsync(string setId, string item, System.Threading.CancellationToken token) => throw null; public bool RemoveItemFromSortedSet(string setId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveItemFromSortedSetAsync(string setId, string value, System.Threading.CancellationToken token) => throw null; public System.Int64 RemoveItemsFromSortedSet(string setId, System.Collections.Generic.List values) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveItemsFromSortedSetAsync(string setId, System.Collections.Generic.List values, System.Threading.CancellationToken token) => throw null; public System.Int64 RemoveRangeFromSortedSet(string setId, int minRank, int maxRank) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveRangeFromSortedSetAsync(string setId, int minRank, int maxRank, System.Threading.CancellationToken token) => throw null; public System.Int64 RemoveRangeFromSortedSetByScore(string setId, double fromScore, double toScore) => throw null; public System.Int64 RemoveRangeFromSortedSetByScore(string setId, System.Int64 fromScore, System.Int64 toScore) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveRangeFromSortedSetByScoreAsync(string setId, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveRangeFromSortedSetByScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, System.Threading.CancellationToken token) => throw null; public System.Int64 RemoveRangeFromSortedSetBySearch(string setId, string start = default(string), string end = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveRangeFromSortedSetBySearchAsync(string setId, string start, string end, System.Threading.CancellationToken token) => throw null; public string RemoveStartFromList(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RemoveStartFromListAsync(string listId, System.Threading.CancellationToken token) => throw null; public void RenameKey(string fromName, string toName) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.RenameKeyAsync(string fromName, string toName, System.Threading.CancellationToken token) => throw null; public bool Replace(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Replace(string key, T value, System.DateTime expiresAt) => throw null; public bool Replace(string key, T value) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; public void ResetInfoStats() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ResetInfoStatsAsync(System.Threading.CancellationToken token) => throw null; public void RewriteAppendOnlyFileAsync() => throw null; public void SaveConfig() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SaveConfigAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IEnumerable> ScanAllHashEntries(string hashId, string pattern = default(string), int pageSize = default(int)) => throw null; System.Collections.Generic.IAsyncEnumerable> ServiceStack.Redis.IRedisClientAsync.ScanAllHashEntriesAsync(string hashId, string pattern, int pageSize, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IEnumerable ScanAllKeys(string pattern = default(string), int pageSize = default(int)) => throw null; System.Collections.Generic.IAsyncEnumerable ServiceStack.Redis.IRedisClientAsync.ScanAllKeysAsync(string pattern, int pageSize, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IEnumerable ScanAllSetItems(string setId, string pattern = default(string), int pageSize = default(int)) => throw null; System.Collections.Generic.IAsyncEnumerable ServiceStack.Redis.IRedisClientAsync.ScanAllSetItemsAsync(string setId, string pattern, int pageSize, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IEnumerable> ScanAllSortedSetItems(string setId, string pattern = default(string), int pageSize = default(int)) => throw null; System.Collections.Generic.IAsyncEnumerable> ServiceStack.Redis.IRedisClientAsync.ScanAllSortedSetItemsAsync(string setId, string pattern, int pageSize, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List SearchKeys(string pattern) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.SearchKeysAsync(string pattern, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List SearchSortedSet(string setId, string start = default(string), string end = default(string), int? skip = default(int?), int? take = default(int?)) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.SearchSortedSetAsync(string setId, string start, string end, int? skip, int? take, System.Threading.CancellationToken token) => throw null; public System.Int64 SearchSortedSetCount(string setId, string start = default(string), string end = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SearchSortedSetCountAsync(string setId, string start, string end, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SelectAsync(System.Int64 db, System.Threading.CancellationToken token) => throw null; public static System.Byte[] SerializeToUtf8Bytes(T value) => throw null; public bool Set(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Set(string key, T value, System.DateTime expiresAt) => throw null; public bool Set(string key, T value) => throw null; public void SetAll(System.Collections.Generic.IDictionary values) => throw null; public void SetAll(System.Collections.Generic.IEnumerable keys, System.Collections.Generic.IEnumerable values) => throw null; public void SetAll(System.Collections.Generic.Dictionary map) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetAllAsync(System.Collections.Generic.IEnumerable keys, System.Collections.Generic.IEnumerable values, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetAllAsync(System.Collections.Generic.IDictionary map, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAllAsync(System.Collections.Generic.IDictionary values, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; public void SetClient(string name) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetClientAsync(string name, System.Threading.CancellationToken token) => throw null; public void SetConfig(string configItem, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetConfigAsync(string configItem, string value, System.Threading.CancellationToken token) => throw null; public bool SetContainsItem(string setId, string item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetContainsItemAsync(string setId, string item, System.Threading.CancellationToken token) => throw null; public bool SetEntryInHash(string hashId, string key, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetEntryInHashAsync(string hashId, string key, string value, System.Threading.CancellationToken token) => throw null; public bool SetEntryInHashIfNotExists(string hashId, string key, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetEntryInHashIfNotExistsAsync(string hashId, string key, string value, System.Threading.CancellationToken token) => throw null; public void SetItemInList(string listId, int listIndex, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetItemInListAsync(string listId, int listIndex, string value, System.Threading.CancellationToken token) => throw null; public void SetRangeInHash(string hashId, System.Collections.Generic.IEnumerable> keyValuePairs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetRangeInHashAsync(string hashId, System.Collections.Generic.IEnumerable> keyValuePairs, System.Threading.CancellationToken token) => throw null; public void SetValue(string key, string value, System.TimeSpan expireIn) => throw null; public void SetValue(string key, string value) => throw null; public bool SetValue(System.Byte[] key, System.Byte[] value, System.TimeSpan expireIn) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetValueAsync(string key, string value, System.TimeSpan expireIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetValueAsync(string key, string value, System.Threading.CancellationToken token) => throw null; public bool SetValueIfExists(string key, string value, System.TimeSpan expireIn) => throw null; public bool SetValueIfExists(string key, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetValueIfExistsAsync(string key, string value, System.TimeSpan? expireIn, System.Threading.CancellationToken token) => throw null; public bool SetValueIfNotExists(string key, string value, System.TimeSpan expireIn) => throw null; public bool SetValueIfNotExists(string key, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetValueIfNotExistsAsync(string key, string value, System.TimeSpan? expireIn, System.Threading.CancellationToken token) => throw null; public void SetValues(System.Collections.Generic.Dictionary map) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SetValuesAsync(System.Collections.Generic.IDictionary map, System.Threading.CancellationToken token) => throw null; public ServiceStack.Model.IHasNamed Sets { get => throw null; set => throw null; } ServiceStack.Model.IHasNamed ServiceStack.Redis.IRedisClientAsync.Sets { get => throw null; } System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ShutdownAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.ShutdownNoSaveAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SlowlogResetAsync(System.Threading.CancellationToken token) => throw null; public bool SortedSetContainsItem(string setId, string value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.SortedSetContainsItemAsync(string setId, string value, System.Threading.CancellationToken token) => throw null; public ServiceStack.Model.IHasNamed SortedSets { get => throw null; set => throw null; } ServiceStack.Model.IHasNamed ServiceStack.Redis.IRedisClientAsync.SortedSets { get => throw null; } public T Store(T entity) => throw null; public void StoreAll(System.Collections.Generic.IEnumerable entities) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.StoreAllAsync(System.Collections.Generic.IEnumerable entities, System.Threading.CancellationToken token) => throw null; public void StoreAsHash(T entity) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreAsHashAsync(T entity, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.StoreAsync(T entity, System.Threading.CancellationToken token) => throw null; public void StoreDifferencesFromSet(string intoSetId, string fromSetId, params string[] withSetIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreDifferencesFromSetAsync(string intoSetId, string fromSetId, string[] withSetIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreDifferencesFromSetAsync(string intoSetId, string fromSetId, params string[] withSetIds) => throw null; public void StoreIntersectFromSets(string intoSetId, params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreIntersectFromSetsAsync(string intoSetId, string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreIntersectFromSetsAsync(string intoSetId, params string[] setIds) => throw null; public System.Int64 StoreIntersectFromSortedSets(string intoSetId, string[] setIds, string[] args) => throw null; public System.Int64 StoreIntersectFromSortedSets(string intoSetId, params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreIntersectFromSortedSetsAsync(string intoSetId, string[] setIds, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreIntersectFromSortedSetsAsync(string intoSetId, string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreIntersectFromSortedSetsAsync(string intoSetId, params string[] setIds) => throw null; public object StoreObject(object entity) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreObjectAsync(object entity, System.Threading.CancellationToken token) => throw null; public void StoreUnionFromSets(string intoSetId, params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreUnionFromSetsAsync(string intoSetId, string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreUnionFromSetsAsync(string intoSetId, params string[] setIds) => throw null; public System.Int64 StoreUnionFromSortedSets(string intoSetId, string[] setIds, string[] args) => throw null; public System.Int64 StoreUnionFromSortedSets(string intoSetId, params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreUnionFromSortedSetsAsync(string intoSetId, string[] setIds, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreUnionFromSortedSetsAsync(string intoSetId, string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.StoreUnionFromSortedSetsAsync(string intoSetId, params string[] setIds) => throw null; public void TrimList(string listId, int keepStartingFrom, int keepEndingAt) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.TrimListAsync(string listId, int keepStartingFrom, int keepEndingAt, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.TypeAsync(string key, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.UnWatchAsync(System.Threading.CancellationToken token) => throw null; public string UrnKey(object id) => throw null; public string UrnKey(T value) => throw null; public string UrnKey(System.Type type, object id) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.WatchAsync(string[] keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.WatchAsync(params string[] keys) => throw null; public System.Collections.Generic.Dictionary WhichLuaScriptsExists(params string[] sha1Refs) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.WhichLuaScriptsExistsAsync(string[] sha1Refs, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisClientAsync.WhichLuaScriptsExistsAsync(params string[] sha1Refs) => throw null; public void WriteAll(System.Collections.Generic.IEnumerable entities) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientAsync.WriteAllAsync(System.Collections.Generic.IEnumerable entities, System.Threading.CancellationToken token) => throw null; } // Generated from `ServiceStack.Redis.RedisClientExtensions` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class RedisClientExtensions { public static string GetHostString(this ServiceStack.Redis.RedisEndpoint config) => throw null; public static string GetHostString(this ServiceStack.Redis.IRedisClient redis) => throw null; } // Generated from `ServiceStack.Redis.RedisClientManagerCacheClient` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisClientManagerCacheClient : System.IDisposable, System.IAsyncDisposable, ServiceStack.Caching.IRemoveByPatternAsync, ServiceStack.Caching.IRemoveByPattern, ServiceStack.Caching.ICacheClientExtended, ServiceStack.Caching.ICacheClientAsync, ServiceStack.Caching.ICacheClient { public bool Add(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Add(string key, T value, System.DateTime expiresAt) => throw null; public bool Add(string key, T value) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.AddAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; public System.Int64 Decrement(string key, System.UInt32 amount) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.DecrementAsync(string key, System.UInt32 amount, System.Threading.CancellationToken token) => throw null; public void Dispose() => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; public void FlushAll() => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.FlushAllAsync(System.Threading.CancellationToken token) => throw null; public T Get(string key) => throw null; public System.Collections.Generic.IDictionary GetAll(System.Collections.Generic.IEnumerable keys) => throw null; System.Threading.Tasks.Task> ServiceStack.Caching.ICacheClientAsync.GetAllAsync(System.Collections.Generic.IEnumerable keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.GetAsync(string key, System.Threading.CancellationToken token) => throw null; public ServiceStack.Caching.ICacheClient GetClient() => throw null; public System.Collections.Generic.IEnumerable GetKeysByPattern(string pattern) => throw null; System.Collections.Generic.IAsyncEnumerable ServiceStack.Caching.ICacheClientAsync.GetKeysByPatternAsync(string pattern, System.Threading.CancellationToken token) => throw null; public System.TimeSpan? GetTimeToLive(string key) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.GetTimeToLiveAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Int64 Increment(string key, System.UInt32 amount) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.IncrementAsync(string key, System.UInt32 amount, System.Threading.CancellationToken token) => throw null; public bool ReadOnly { get => throw null; set => throw null; } public RedisClientManagerCacheClient(ServiceStack.Redis.IRedisClientsManager redisManager) => throw null; public bool Remove(string key) => throw null; public void RemoveAll(System.Collections.Generic.IEnumerable keys) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveAllAsync(System.Collections.Generic.IEnumerable keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveAsync(string key, System.Threading.CancellationToken token) => throw null; public void RemoveByPattern(string pattern) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.IRemoveByPatternAsync.RemoveByPatternAsync(string pattern, System.Threading.CancellationToken token) => throw null; public void RemoveByRegex(string pattern) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.IRemoveByPatternAsync.RemoveByRegexAsync(string regex, System.Threading.CancellationToken token) => throw null; public void RemoveExpiredEntries() => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.RemoveExpiredEntriesAsync(System.Threading.CancellationToken token) => throw null; public bool Replace(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Replace(string key, T value, System.DateTime expiresAt) => throw null; public bool Replace(string key, T value) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.ReplaceAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; public bool Set(string key, T value, System.TimeSpan expiresIn) => throw null; public bool Set(string key, T value, System.DateTime expiresAt) => throw null; public bool Set(string key, T value) => throw null; public void SetAll(System.Collections.Generic.IDictionary values) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAllAsync(System.Collections.Generic.IDictionary values, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Caching.ICacheClientAsync.SetAsync(string key, T value, System.DateTime expiresAt, System.Threading.CancellationToken token) => throw null; } // Generated from `ServiceStack.Redis.RedisClientManagerConfig` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisClientManagerConfig { public bool AutoStart { get => throw null; set => throw null; } public System.Int64? DefaultDb { get => throw null; set => throw null; } public int MaxReadPoolSize { get => throw null; set => throw null; } public int MaxWritePoolSize { get => throw null; set => throw null; } public RedisClientManagerConfig() => throw null; } // Generated from `ServiceStack.Redis.RedisClientsManagerExtensions` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class RedisClientsManagerExtensions { public static ServiceStack.Redis.IRedisPubSubServer CreatePubSubServer(this ServiceStack.Redis.IRedisClientsManager redisManager, string channel, System.Action onMessage = default(System.Action), System.Action onError = default(System.Action), System.Action onInit = default(System.Action), System.Action onStart = default(System.Action), System.Action onStop = default(System.Action)) => throw null; public static void Exec(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Action lambda) => throw null; public static string Exec(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func lambda) => throw null; public static int Exec(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func lambda) => throw null; public static double Exec(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func lambda) => throw null; public static bool Exec(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func lambda) => throw null; public static System.Int64 Exec(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func lambda) => throw null; public static void ExecAs(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Action> lambda) => throw null; public static T ExecAs(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func, T> lambda) => throw null; public static System.Collections.Generic.List ExecAs(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func, System.Collections.Generic.List> lambda) => throw null; public static System.Collections.Generic.IList ExecAs(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func, System.Collections.Generic.IList> lambda) => throw null; public static System.Threading.Tasks.ValueTask ExecAsAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func, System.Threading.Tasks.ValueTask> lambda) => throw null; public static System.Threading.Tasks.ValueTask> ExecAsAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func, System.Threading.Tasks.ValueTask>> lambda) => throw null; public static System.Threading.Tasks.ValueTask> ExecAsAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func, System.Threading.Tasks.ValueTask>> lambda) => throw null; public static System.Threading.Tasks.ValueTask ExecAsAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func, System.Threading.Tasks.ValueTask> lambda) => throw null; public static System.Threading.Tasks.ValueTask ExecAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func> lambda) => throw null; public static System.Threading.Tasks.ValueTask ExecAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Func lambda) => throw null; public static void ExecTrans(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Action lambda) => throw null; public static System.Threading.Tasks.ValueTask GetCacheClientAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Threading.CancellationToken token = default(System.Threading.CancellationToken)) => throw null; public static System.Threading.Tasks.ValueTask GetClientAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Threading.CancellationToken token = default(System.Threading.CancellationToken)) => throw null; public static System.Threading.Tasks.ValueTask GetReadOnlyCacheClientAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Threading.CancellationToken token = default(System.Threading.CancellationToken)) => throw null; public static System.Threading.Tasks.ValueTask GetReadOnlyClientAsync(this ServiceStack.Redis.IRedisClientsManager redisManager, System.Threading.CancellationToken token = default(System.Threading.CancellationToken)) => throw null; } // Generated from `ServiceStack.Redis.RedisCommandQueue` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisCommandQueue : ServiceStack.Redis.RedisQueueCompletableOperation { public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Func> command, System.Action> onSuccessCallback) => throw null; public void QueueCommand(System.Func> command) => throw null; public void QueueCommand(System.Func> command, System.Action> onSuccessCallback) => throw null; public void QueueCommand(System.Func> command) => throw null; public void QueueCommand(System.Func> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func> command, System.Action> onSuccessCallback) => throw null; public void QueueCommand(System.Func> command) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func command) => throw null; public void QueueCommand(System.Action command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Action command) => throw null; public virtual void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Func> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Func> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Func command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public virtual void QueueCommand(System.Action command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; protected ServiceStack.Redis.RedisClient RedisClient; public RedisCommandQueue(ServiceStack.Redis.RedisClient redisClient) => throw null; } // Generated from `ServiceStack.Redis.RedisConfig` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisConfig { public static bool AssertAccessOnlyOnSameThread; public static int? AssumeServerVersion; public static int BackOffMultiplier; public static int BufferLength { get => throw null; } public static int BufferPoolMaxSize; public static System.Net.Security.LocalCertificateSelectionCallback CertificateSelectionCallback { get => throw null; set => throw null; } public static System.Net.Security.RemoteCertificateValidationCallback CertificateValidationCallback { get => throw null; set => throw null; } public static System.Func ClientFactory; public static System.TimeSpan DeactivatedClientsExpiry; public static int DefaultConnectTimeout; public const System.Int64 DefaultDb = default; public const string DefaultHost = default; public static int DefaultIdleTimeOutSecs; public static int? DefaultMaxPoolSize; public static int DefaultPoolSizeMultiplier; public const int DefaultPort = default; public const int DefaultPortSentinel = default; public const int DefaultPortSsl = default; public static int DefaultReceiveTimeout; public static int DefaultRetryTimeout; public static int DefaultSendTimeout; public static bool DisableVerboseLogging { get => throw null; set => throw null; } public static bool EnableVerboseLogging; public static int HostLookupTimeoutMs; public RedisConfig() => throw null; public static void Reset() => throw null; public static bool RetryReconnectOnFailedMasters; public static bool VerifyMasterConnections; } // Generated from `ServiceStack.Redis.RedisDataExtensions` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class RedisDataExtensions { public static string GetResult(this ServiceStack.Redis.RedisText from) => throw null; public static T GetResult(this ServiceStack.Redis.RedisText from) => throw null; public static System.Collections.Generic.List GetResults(this ServiceStack.Redis.RedisText from) => throw null; public static System.Collections.Generic.List GetResults(this ServiceStack.Redis.RedisText from) => throw null; public static double ToDouble(this ServiceStack.Redis.RedisData data) => throw null; public static System.Int64 ToInt64(this ServiceStack.Redis.RedisData data) => throw null; public static ServiceStack.Redis.RedisText ToRedisText(this ServiceStack.Redis.RedisData data) => throw null; } // Generated from `ServiceStack.Redis.RedisDataInfoExtensions` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class RedisDataInfoExtensions { public static string ToJsonInfo(this ServiceStack.Redis.RedisText redisText) => throw null; } // Generated from `ServiceStack.Redis.RedisEndpoint` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisEndpoint : ServiceStack.IO.IEndpoint { public string Client { get => throw null; set => throw null; } public int ConnectTimeout { get => throw null; set => throw null; } public System.Int64 Db { get => throw null; set => throw null; } public override bool Equals(object obj) => throw null; protected bool Equals(ServiceStack.Redis.RedisEndpoint other) => throw null; public override int GetHashCode() => throw null; public string Host { get => throw null; set => throw null; } public int IdleTimeOutSecs { get => throw null; set => throw null; } public string NamespacePrefix { get => throw null; set => throw null; } public string Password { get => throw null; set => throw null; } public int Port { get => throw null; set => throw null; } public int ReceiveTimeout { get => throw null; set => throw null; } public RedisEndpoint(string host, int port, string password = default(string), System.Int64 db = default(System.Int64)) => throw null; public RedisEndpoint() => throw null; public bool RequiresAuth { get => throw null; } public int RetryTimeout { get => throw null; set => throw null; } public int SendTimeout { get => throw null; set => throw null; } public bool Ssl { get => throw null; set => throw null; } public System.Security.Authentication.SslProtocols? SslProtocols { get => throw null; set => throw null; } public override string ToString() => throw null; } // Generated from `ServiceStack.Redis.RedisException` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisException : System.Exception { public RedisException(string message, System.Exception innerException) => throw null; public RedisException(string message) => throw null; } // Generated from `ServiceStack.Redis.RedisExtensions` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class RedisExtensions { public static System.Collections.Generic.List ToRedisEndPoints(this System.Collections.Generic.IEnumerable hosts) => throw null; public static ServiceStack.Redis.RedisEndpoint ToRedisEndpoint(this string connectionString, int? defaultPort = default(int?)) => throw null; } // Generated from `ServiceStack.Redis.RedisLock` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisLock : System.IDisposable, System.IAsyncDisposable { public void Dispose() => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; public RedisLock(ServiceStack.Redis.IRedisClient redisClient, string key, System.TimeSpan? timeOut) => throw null; } // Generated from `ServiceStack.Redis.RedisManagerPool` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisManagerPool : System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.IRedisFailover, ServiceStack.Redis.IRedisClientsManagerAsync, ServiceStack.Redis.IRedisClientsManager, ServiceStack.Redis.IRedisClientCacheManager, ServiceStack.Redis.IHasRedisResolver, ServiceStack.Redis.IHandleClientDispose { public bool AssertAccessOnlyOnSameThread { get => throw null; set => throw null; } public System.Func ClientFactory { get => throw null; set => throw null; } public System.Action ConnectionFilter { get => throw null; set => throw null; } public void Dispose() => throw null; protected void Dispose(ServiceStack.Redis.RedisClient redisClient) => throw null; protected virtual void Dispose(bool disposing) => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; public void DisposeClient(ServiceStack.Redis.RedisNativeClient client) => throw null; public void DisposeWriteClient(ServiceStack.Redis.RedisNativeClient client) => throw null; public void FailoverTo(params string[] readWriteHosts) => throw null; public void FailoverTo(System.Collections.Generic.IEnumerable readWriteHosts, System.Collections.Generic.IEnumerable readOnlyHosts) => throw null; public ServiceStack.Caching.ICacheClient GetCacheClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetCacheClientAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.IRedisClient GetClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetClientAsync(System.Threading.CancellationToken token) => throw null; public int[] GetClientPoolActiveStates() => throw null; public ServiceStack.Caching.ICacheClient GetReadOnlyCacheClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetReadOnlyCacheClientAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.IRedisClient GetReadOnlyClient() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisClientsManagerAsync.GetReadOnlyClientAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.Dictionary GetStats() => throw null; public int MaxPoolSize { get => throw null; set => throw null; } public System.Collections.Generic.List> OnFailover { get => throw null; set => throw null; } public int RecheckPoolAfterMs; protected int RedisClientCounter; public RedisManagerPool(string host, ServiceStack.Redis.RedisPoolConfig config) => throw null; public RedisManagerPool(string host) => throw null; public RedisManagerPool(System.Collections.Generic.IEnumerable hosts, ServiceStack.Redis.RedisPoolConfig config) => throw null; public RedisManagerPool(System.Collections.Generic.IEnumerable hosts) => throw null; public RedisManagerPool() => throw null; public ServiceStack.Redis.IRedisResolver RedisResolver { get => throw null; set => throw null; } protected int poolIndex; // ERR: Stub generator didn't handle member: ~RedisManagerPool } // Generated from `ServiceStack.Redis.RedisNativeClient` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisNativeClient : System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.IRedisNativeClientAsync, ServiceStack.Redis.IRedisNativeClient { public System.Int64 Append(string key, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.AppendAsync(string key, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public int AssertServerVersionNumber() => throw null; public System.Byte[][] BLPop(string[] listIds, int timeOutSecs) => throw null; public System.Byte[][] BLPop(string listId, int timeOutSecs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BLPopAsync(string[] listIds, int timeOutSecs, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BLPopAsync(string listId, int timeOutSecs, System.Threading.CancellationToken token) => throw null; public System.Byte[][] BLPopValue(string[] listIds, int timeOutSecs) => throw null; public System.Byte[] BLPopValue(string listId, int timeOutSecs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BLPopValueAsync(string[] listIds, int timeOutSecs, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BLPopValueAsync(string listId, int timeOutSecs, System.Threading.CancellationToken token) => throw null; public System.Byte[][] BRPop(string[] listIds, int timeOutSecs) => throw null; public System.Byte[][] BRPop(string listId, int timeOutSecs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BRPopAsync(string[] listIds, int timeOutSecs, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BRPopAsync(string listId, int timeOutSecs, System.Threading.CancellationToken token) => throw null; public System.Byte[] BRPopLPush(string fromListId, string toListId, int timeOutSecs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BRPopLPushAsync(string fromListId, string toListId, int timeOutSecs, System.Threading.CancellationToken token) => throw null; public System.Byte[][] BRPopValue(string[] listIds, int timeOutSecs) => throw null; public System.Byte[] BRPopValue(string listId, int timeOutSecs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BRPopValueAsync(string[] listIds, int timeOutSecs, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BRPopValueAsync(string listId, int timeOutSecs, System.Threading.CancellationToken token) => throw null; public void BgRewriteAof() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BgRewriteAofAsync(System.Threading.CancellationToken token) => throw null; public void BgSave() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BgSaveAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 BitCount(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.BitCountAsync(string key, System.Threading.CancellationToken token) => throw null; protected System.IO.BufferedStream Bstream; public string CalculateSha1(string luaBody) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.CalculateSha1Async(string luaBody, System.Threading.CancellationToken token) => throw null; public void ChangeDb(System.Int64 db) => throw null; public string Client { get => throw null; set => throw null; } public string ClientGetName() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ClientGetNameAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 ClientId { get => throw null; } public void ClientKill(string clientAddr) => throw null; public System.Int64 ClientKill(string addr = default(string), string id = default(string), string type = default(string), string skipMe = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ClientKillAsync(string addr, string id, string type, string skipMe, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ClientKillAsync(string clientAddr, System.Threading.CancellationToken token) => throw null; public System.Byte[] ClientList() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ClientListAsync(System.Threading.CancellationToken token) => throw null; public void ClientPause(int timeOutMs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ClientPauseAsync(int timeOutMs, System.Threading.CancellationToken token) => throw null; public void ClientSetName(string name) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ClientSetNameAsync(string name, System.Threading.CancellationToken token) => throw null; protected void CmdLog(System.Byte[][] args) => throw null; public System.Byte[][] ConfigGet(string pattern) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ConfigGetAsync(string pattern, System.Threading.CancellationToken token) => throw null; public void ConfigResetStat() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ConfigResetStatAsync(System.Threading.CancellationToken token) => throw null; public void ConfigRewrite() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ConfigRewriteAsync(System.Threading.CancellationToken token) => throw null; public void ConfigSet(string item, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ConfigSetAsync(string item, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public int ConnectTimeout { get => throw null; set => throw null; } public System.Action ConnectionFilter { get => throw null; set => throw null; } protected System.Byte[][] ConvertToBytes(string[] keys) => throw null; public ServiceStack.Redis.Pipeline.RedisPipelineCommand CreatePipelineCommand() => throw null; public virtual ServiceStack.Redis.IRedisSubscription CreateSubscription() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.CreateSubscriptionAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 Db { get => throw null; set => throw null; } public System.Int64 DbSize { get => throw null; } System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.DbSizeAsync(System.Threading.CancellationToken token) => throw null; public System.DateTime? DeactivatedAt { get => throw null; set => throw null; } public void DebugSegfault() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.DebugSegfaultAsync(System.Threading.CancellationToken token) => throw null; public void DebugSleep(double durationSecs) => throw null; public System.Int64 Decr(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.DecrAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Int64 DecrBy(string key, int count) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.DecrByAsync(string key, System.Int64 count, System.Threading.CancellationToken token) => throw null; public System.Int64 Del(string key) => throw null; public System.Int64 Del(params string[] keys) => throw null; public System.Int64 Del(System.Byte[] key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.DelAsync(string[] keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.DelAsync(string key, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.DelAsync(params string[] keys) => throw null; public virtual void Dispose() => throw null; protected virtual void Dispose(bool disposing) => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; public static void DisposeTimers() => throw null; public System.Byte[] Dump(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.DumpAsync(string key, System.Threading.CancellationToken token) => throw null; public string Echo(string text) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EchoAsync(string text, System.Threading.CancellationToken token) => throw null; public static string ErrorConnect; public System.Byte[][] Eval(string luaBody, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalAsync(string luaBody, int numberOfKeys, params System.Byte[][] keysAndArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalAsync(string luaBody, int numberOfKeys, System.Byte[][] keysAndArgs, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisData EvalCommand(string luaBody, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalCommandAsync(string luaBody, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalCommandAsync(string luaBody, int numberKeysInArgs, System.Byte[][] keys, System.Threading.CancellationToken token) => throw null; public System.Int64 EvalInt(string luaBody, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalIntAsync(string luaBody, int numberOfKeys, params System.Byte[][] keysAndArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalIntAsync(string luaBody, int numberOfKeys, System.Byte[][] keysAndArgs, System.Threading.CancellationToken token) => throw null; public System.Byte[][] EvalSha(string sha1, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalShaAsync(string sha1, int numberOfKeys, params System.Byte[][] keysAndArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalShaAsync(string sha1, int numberOfKeys, System.Byte[][] keysAndArgs, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisData EvalShaCommand(string sha1, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalShaCommandAsync(string sha1, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalShaCommandAsync(string sha1, int numberKeysInArgs, System.Byte[][] keys, System.Threading.CancellationToken token) => throw null; public System.Int64 EvalShaInt(string sha1, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalShaIntAsync(string sha1, int numberOfKeys, params System.Byte[][] keysAndArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalShaIntAsync(string sha1, int numberOfKeys, System.Byte[][] keysAndArgs, System.Threading.CancellationToken token) => throw null; public string EvalShaStr(string sha1, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalShaStrAsync(string sha1, int numberOfKeys, params System.Byte[][] keysAndArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalShaStrAsync(string sha1, int numberOfKeys, System.Byte[][] keysAndArgs, System.Threading.CancellationToken token) => throw null; public string EvalStr(string luaBody, int numberKeysInArgs, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalStrAsync(string luaBody, int numberOfKeys, params System.Byte[][] keysAndArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.EvalStrAsync(string luaBody, int numberOfKeys, System.Byte[][] keysAndArgs, System.Threading.CancellationToken token) => throw null; public System.Int64 Exists(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ExistsAsync(string key, System.Threading.CancellationToken token) => throw null; protected void ExpectSuccess() => throw null; protected System.Int64 ExpectSuccessFn() => throw null; public bool Expire(string key, int seconds) => throw null; public bool Expire(System.Byte[] key, int seconds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ExpireAsync(string key, int seconds, System.Threading.CancellationToken token) => throw null; public bool ExpireAt(string key, System.Int64 unixTime) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ExpireAtAsync(string key, System.Int64 unixTime, System.Threading.CancellationToken token) => throw null; public void FlushAll() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.FlushAllAsync(System.Threading.CancellationToken token) => throw null; public void FlushDb() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.FlushDbAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 GeoAdd(string key, params ServiceStack.Redis.RedisGeo[] geoPoints) => throw null; public System.Int64 GeoAdd(string key, double longitude, double latitude, string member) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GeoAddAsync(string key, params ServiceStack.Redis.RedisGeo[] geoPoints) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GeoAddAsync(string key, double longitude, double latitude, string member, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GeoAddAsync(string key, ServiceStack.Redis.RedisGeo[] geoPoints, System.Threading.CancellationToken token) => throw null; public double GeoDist(string key, string fromMember, string toMember, string unit = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GeoDistAsync(string key, string fromMember, string toMember, string unit, System.Threading.CancellationToken token) => throw null; public string[] GeoHash(string key, params string[] members) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GeoHashAsync(string key, string[] members, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GeoHashAsync(string key, params string[] members) => throw null; public System.Collections.Generic.List GeoPos(string key, params string[] members) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisNativeClientAsync.GeoPosAsync(string key, string[] members, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisNativeClientAsync.GeoPosAsync(string key, params string[] members) => throw null; public System.Collections.Generic.List GeoRadius(string key, double longitude, double latitude, double radius, string unit, bool withCoords = default(bool), bool withDist = default(bool), bool withHash = default(bool), int? count = default(int?), bool? asc = default(bool?)) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisNativeClientAsync.GeoRadiusAsync(string key, double longitude, double latitude, double radius, string unit, bool withCoords, bool withDist, bool withHash, int? count, bool? asc, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GeoRadiusByMember(string key, string member, double radius, string unit, bool withCoords = default(bool), bool withDist = default(bool), bool withHash = default(bool), int? count = default(int?), bool? asc = default(bool?)) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisNativeClientAsync.GeoRadiusByMemberAsync(string key, string member, double radius, string unit, bool withCoords, bool withDist, bool withHash, int? count, bool? asc, System.Threading.CancellationToken token) => throw null; public System.Byte[] Get(string key) => throw null; public System.Byte[] Get(System.Byte[] key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GetAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Int64 GetBit(string key, int offset) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GetBitAsync(string key, int offset, System.Threading.CancellationToken token) => throw null; public System.Byte[] GetBytes(string key) => throw null; public ServiceStack.Redis.RedisKeyType GetEntryType(string key) => throw null; public System.Byte[] GetRange(string key, int fromIndex, int toIndex) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GetRangeAsync(string key, int fromIndex, int toIndex, System.Threading.CancellationToken token) => throw null; public System.Byte[] GetSet(string key, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.GetSetAsync(string key, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 HDel(string hashId, System.Byte[][] keys) => throw null; public System.Int64 HDel(string hashId, System.Byte[] key) => throw null; public System.Int64 HDel(System.Byte[] hashId, System.Byte[] key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HDelAsync(string hashId, System.Byte[] key, System.Threading.CancellationToken token) => throw null; public System.Int64 HExists(string hashId, System.Byte[] key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HExistsAsync(string hashId, System.Byte[] key, System.Threading.CancellationToken token) => throw null; public System.Byte[] HGet(string hashId, System.Byte[] key) => throw null; public System.Byte[] HGet(System.Byte[] hashId, System.Byte[] key) => throw null; public System.Byte[][] HGetAll(string hashId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HGetAllAsync(string hashId, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HGetAsync(string hashId, System.Byte[] key, System.Threading.CancellationToken token) => throw null; public System.Int64 HIncrby(string hashId, System.Byte[] key, int incrementBy) => throw null; public System.Int64 HIncrby(string hashId, System.Byte[] key, System.Int64 incrementBy) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HIncrbyAsync(string hashId, System.Byte[] key, int incrementBy, System.Threading.CancellationToken token) => throw null; public double HIncrbyFloat(string hashId, System.Byte[] key, double incrementBy) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HIncrbyFloatAsync(string hashId, System.Byte[] key, double incrementBy, System.Threading.CancellationToken token) => throw null; public System.Byte[][] HKeys(string hashId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HKeysAsync(string hashId, System.Threading.CancellationToken token) => throw null; public System.Int64 HLen(string hashId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HLenAsync(string hashId, System.Threading.CancellationToken token) => throw null; public System.Byte[][] HMGet(string hashId, params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HMGetAsync(string hashId, params System.Byte[][] keysAndArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HMGetAsync(string hashId, System.Byte[][] keys, System.Threading.CancellationToken token) => throw null; public void HMSet(string hashId, System.Byte[][] keys, System.Byte[][] values) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HMSetAsync(string hashId, System.Byte[][] keys, System.Byte[][] values, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.ScanResult HScan(string hashId, System.UInt64 cursor, int count = default(int), string match = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HScanAsync(string hashId, System.UInt64 cursor, int count, string match, System.Threading.CancellationToken token) => throw null; public System.Int64 HSet(string hashId, System.Byte[] key, System.Byte[] value) => throw null; public System.Int64 HSet(System.Byte[] hashId, System.Byte[] key, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HSetAsync(string hashId, System.Byte[] key, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 HSetNX(string hashId, System.Byte[] key, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HSetNXAsync(string hashId, System.Byte[] key, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Byte[][] HVals(string hashId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.HValsAsync(string hashId, System.Threading.CancellationToken token) => throw null; public bool HadExceptions { get => throw null; } public bool HasConnected { get => throw null; } public string Host { get => throw null; set => throw null; } public System.Int64 Id { get => throw null; set => throw null; } public int IdleTimeOutSecs { get => throw null; set => throw null; } public System.Int64 Incr(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.IncrAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Int64 IncrBy(string key, int count) => throw null; public System.Int64 IncrBy(string key, System.Int64 count) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.IncrByAsync(string key, System.Int64 count, System.Threading.CancellationToken token) => throw null; public double IncrByFloat(string key, double incrBy) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.IncrByFloatAsync(string key, double incrBy, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.Dictionary Info { get => throw null; } System.Threading.Tasks.ValueTask> ServiceStack.Redis.IRedisNativeClientAsync.InfoAsync(System.Threading.CancellationToken token) => throw null; public bool IsManagedClient { get => throw null; } public bool IsSocketConnected() => throw null; public System.Byte[][] Keys(string pattern) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.KeysAsync(string pattern, System.Threading.CancellationToken token) => throw null; public System.Byte[] LIndex(string listId, int listIndex) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LIndexAsync(string listId, int listIndex, System.Threading.CancellationToken token) => throw null; public void LInsert(string listId, bool insertBefore, System.Byte[] pivot, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LInsertAsync(string listId, bool insertBefore, System.Byte[] pivot, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 LLen(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LLenAsync(string listId, System.Threading.CancellationToken token) => throw null; public System.Byte[] LPop(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LPopAsync(string listId, System.Threading.CancellationToken token) => throw null; public System.Int64 LPush(string listId, System.Byte[][] values) => throw null; public System.Int64 LPush(string listId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LPushAsync(string listId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 LPushX(string listId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LPushXAsync(string listId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Byte[][] LRange(string listId, int startingFrom, int endingAt) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LRangeAsync(string listId, int startingFrom, int endingAt, System.Threading.CancellationToken token) => throw null; public System.Int64 LRem(string listId, int removeNoOfMatches, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LRemAsync(string listId, int removeNoOfMatches, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public void LSet(string listId, int listIndex, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LSetAsync(string listId, int listIndex, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public void LTrim(string listId, int keepStartingFrom, int keepEndingAt) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LTrimAsync(string listId, int keepStartingFrom, int keepEndingAt, System.Threading.CancellationToken token) => throw null; public System.DateTime LastSave { get => throw null; } System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.LastSaveAsync(System.Threading.CancellationToken token) => throw null; protected void Log(string fmt, params object[] args) => throw null; public System.Byte[][] MGet(params string[] keys) => throw null; public System.Byte[][] MGet(params System.Byte[][] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MGetAsync(string[] keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MGetAsync(params string[] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MGetAsync(params System.Byte[][] keysAndArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MGetAsync(System.Byte[][] keys, System.Threading.CancellationToken token) => throw null; public void MSet(string[] keys, System.Byte[][] values) => throw null; public void MSet(System.Byte[][] keys, System.Byte[][] values) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MSetAsync(string[] keys, System.Byte[][] values, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MSetAsync(System.Byte[][] keys, System.Byte[][] values, System.Threading.CancellationToken token) => throw null; public bool MSetNx(string[] keys, System.Byte[][] values) => throw null; public bool MSetNx(System.Byte[][] keys, System.Byte[][] values) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MSetNxAsync(string[] keys, System.Byte[][] values, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MSetNxAsync(System.Byte[][] keys, System.Byte[][] values, System.Threading.CancellationToken token) => throw null; protected System.Byte[][] MergeAndConvertToBytes(string[] keys, string[] args) => throw null; public void Migrate(string host, int port, string key, int destinationDb, System.Int64 timeoutMs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MigrateAsync(string host, int port, string key, int destinationDb, System.Int64 timeoutMs, System.Threading.CancellationToken token) => throw null; public bool Move(string key, int db) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.MoveAsync(string key, int db, System.Threading.CancellationToken token) => throw null; public string NamespacePrefix { get => throw null; set => throw null; } public System.Int64 ObjectIdleTime(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ObjectIdleTimeAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Action OnBeforeFlush { get => throw null; set => throw null; } public virtual void OnConnected() => throw null; public bool PExpire(string key, System.Int64 ttlMs) => throw null; public bool PExpire(System.Byte[] key, System.Int64 ttlMs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PExpireAsync(string key, System.Int64 ttlMs, System.Threading.CancellationToken token) => throw null; public bool PExpireAt(string key, System.Int64 unixTimeMs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PExpireAtAsync(string key, System.Int64 unixTimeMs, System.Threading.CancellationToken token) => throw null; public void PSetEx(string key, System.Int64 expireInMs, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PSetExAsync(string key, System.Int64 expireInMs, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Byte[][] PSubscribe(params string[] toChannelsMatchingPatterns) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PSubscribeAsync(string[] toChannelsMatchingPatterns, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PSubscribeAsync(params string[] toChannelsMatchingPatterns) => throw null; public System.Int64 PTtl(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PTtlAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Byte[][] PUnSubscribe(params string[] fromChannelsMatchingPatterns) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PUnSubscribeAsync(string[] fromChannelsMatchingPatterns, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PUnSubscribeAsync(params string[] toChannelsMatchingPatterns) => throw null; public static double ParseDouble(System.Byte[] doubleBytes) => throw null; public string Password { get => throw null; set => throw null; } public bool Persist(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PersistAsync(string key, System.Threading.CancellationToken token) => throw null; public bool PfAdd(string key, params System.Byte[][] elements) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PfAddAsync(string key, params System.Byte[][] elements) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PfAddAsync(string key, System.Byte[][] elements, System.Threading.CancellationToken token) => throw null; public System.Int64 PfCount(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PfCountAsync(string key, System.Threading.CancellationToken token) => throw null; public void PfMerge(string toKeyId, params string[] fromKeys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PfMergeAsync(string toKeyId, string[] fromKeys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PfMergeAsync(string toKeyId, params string[] fromKeys) => throw null; public bool Ping() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PingAsync(System.Threading.CancellationToken token) => throw null; public int Port { get => throw null; set => throw null; } public System.Int64 Publish(string toChannel, System.Byte[] message) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.PublishAsync(string toChannel, System.Byte[] message, System.Threading.CancellationToken token) => throw null; public void Quit() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.QuitAsync(System.Threading.CancellationToken token) => throw null; public System.Byte[] RPop(string listId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RPopAsync(string listId, System.Threading.CancellationToken token) => throw null; public System.Byte[] RPopLPush(string fromListId, string toListId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RPopLPushAsync(string fromListId, string toListId, System.Threading.CancellationToken token) => throw null; public System.Int64 RPush(string listId, System.Byte[][] values) => throw null; public System.Int64 RPush(string listId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RPushAsync(string listId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 RPushX(string listId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RPushXAsync(string listId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public string RandomKey() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RandomKeyAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisData RawCommand(params object[] cmdWithArgs) => throw null; public ServiceStack.Redis.RedisData RawCommand(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected System.Threading.Tasks.ValueTask RawCommandAsync(System.Threading.CancellationToken token, params object[] cmdWithArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RawCommandAsync(params object[] cmdWithArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RawCommandAsync(params System.Byte[][] cmdWithBinaryArgs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RawCommandAsync(object[] cmdWithArgs, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RawCommandAsync(System.Byte[][] cmdWithBinaryArgs, System.Threading.CancellationToken token) => throw null; public double ReadDouble() => throw null; protected string ReadLine() => throw null; public System.Int64 ReadLong() => throw null; public System.Byte[][] ReceiveMessages() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ReceiveMessagesAsync(System.Threading.CancellationToken token) => throw null; public int ReceiveTimeout { get => throw null; set => throw null; } public RedisNativeClient(string host, int port, string password = default(string), System.Int64 db = default(System.Int64)) => throw null; public RedisNativeClient(string host, int port) => throw null; public RedisNativeClient(string connectionString) => throw null; public RedisNativeClient(ServiceStack.Redis.RedisEndpoint config) => throw null; public RedisNativeClient() => throw null; public void Rename(string oldKeyname, string newKeyname) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RenameAsync(string oldKeyName, string newKeyName, System.Threading.CancellationToken token) => throw null; public bool RenameNx(string oldKeyname, string newKeyname) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RenameNxAsync(string oldKeyName, string newKeyName, System.Threading.CancellationToken token) => throw null; public static int RequestsPerHour { get => throw null; } public void ResetSendBuffer() => throw null; public System.Byte[] Restore(string key, System.Int64 expireMs, System.Byte[] dumpValue) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RestoreAsync(string key, System.Int64 expireMs, System.Byte[] dumpValue, System.Threading.CancellationToken token) => throw null; public int RetryCount { get => throw null; set => throw null; } public int RetryTimeout { get => throw null; set => throw null; } public ServiceStack.Redis.RedisText Role() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.RoleAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 SAdd(string setId, System.Byte[][] values) => throw null; public System.Int64 SAdd(string setId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SAddAsync(string setId, System.Byte[][] values, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SAddAsync(string setId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 SCard(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SCardAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Byte[][] SDiff(string fromSetId, params string[] withSetIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SDiffAsync(string fromSetId, string[] withSetIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SDiffAsync(string fromSetId, params string[] withSetIds) => throw null; public void SDiffStore(string intoSetId, string fromSetId, params string[] withSetIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SDiffStoreAsync(string intoSetId, string fromSetId, string[] withSetIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SDiffStoreAsync(string intoSetId, string fromSetId, params string[] withSetIds) => throw null; public System.Byte[][] SInter(params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SInterAsync(string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SInterAsync(params string[] setIds) => throw null; public void SInterStore(string intoSetId, params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SInterStoreAsync(string intoSetId, string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SInterStoreAsync(string intoSetId, params string[] setIds) => throw null; public System.Int64 SIsMember(string setId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SIsMemberAsync(string setId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Byte[][] SMembers(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SMembersAsync(string setId, System.Threading.CancellationToken token) => throw null; public void SMove(string fromSetId, string toSetId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SMoveAsync(string fromSetId, string toSetId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Byte[][] SPop(string setId, int count) => throw null; public System.Byte[] SPop(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SPopAsync(string setId, int count, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SPopAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Byte[][] SRandMember(string setId, int count) => throw null; public System.Byte[] SRandMember(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SRandMemberAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Int64 SRem(string setId, System.Byte[][] values) => throw null; public System.Int64 SRem(string setId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SRemAsync(string setId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.ScanResult SScan(string setId, System.UInt64 cursor, int count = default(int), string match = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SScanAsync(string setId, System.UInt64 cursor, int count, string match, System.Threading.CancellationToken token) => throw null; public System.Byte[][] SUnion(params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SUnionAsync(string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SUnionAsync(params string[] setIds) => throw null; public void SUnionStore(string intoSetId, params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SUnionStoreAsync(string intoSetId, string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SUnionStoreAsync(string intoSetId, params string[] setIds) => throw null; public void Save() => throw null; public void SaveAsync() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SaveAsync(System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.ScanResult Scan(System.UInt64 cursor, int count = default(int), string match = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ScanAsync(System.UInt64 cursor, int count, string match, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ScriptExists(params System.Byte[][] sha1Refs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ScriptExistsAsync(params System.Byte[][] sha1Refs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ScriptExistsAsync(System.Byte[][] sha1Refs, System.Threading.CancellationToken token) => throw null; public void ScriptFlush() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ScriptFlushAsync(System.Threading.CancellationToken token) => throw null; public void ScriptKill() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ScriptKillAsync(System.Threading.CancellationToken token) => throw null; public System.Byte[] ScriptLoad(string luaBody) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ScriptLoadAsync(string body, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SelectAsync(System.Int64 db, System.Threading.CancellationToken token) => throw null; protected string SendExpectCode(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected ServiceStack.Redis.RedisData SendExpectComplexResponse(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected System.Threading.Tasks.ValueTask SendExpectComplexResponseAsync(System.Threading.CancellationToken token, params System.Byte[][] cmdWithBinaryArgs) => throw null; protected System.Byte[] SendExpectData(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected object[] SendExpectDeeplyNestedMultiData(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected double SendExpectDouble(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected System.Int64 SendExpectLong(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected System.Byte[][] SendExpectMultiData(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected string SendExpectString(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected System.Threading.Tasks.ValueTask SendExpectStringAsync(System.Threading.CancellationToken token, params System.Byte[][] cmdWithBinaryArgs) => throw null; protected System.Collections.Generic.List> SendExpectStringDictionaryList(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected void SendExpectSuccess(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected T SendReceive(System.Byte[][] cmdWithBinaryArgs, System.Func fn, System.Action> completePipelineFn = default(System.Action>), bool sendWithoutRead = default(bool)) => throw null; public int SendTimeout { get => throw null; set => throw null; } protected void SendUnmanagedExpectSuccess(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected void SendWithoutRead(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected System.Threading.Tasks.ValueTask SendWithoutReadAsync(System.Threading.CancellationToken token, params System.Byte[][] cmdWithBinaryArgs) => throw null; public void SentinelFailover(string masterName) => throw null; public System.Collections.Generic.List SentinelGetMasterAddrByName(string masterName) => throw null; public System.Collections.Generic.Dictionary SentinelMaster(string masterName) => throw null; public System.Collections.Generic.List> SentinelMasters() => throw null; public System.Collections.Generic.List> SentinelSentinels(string masterName) => throw null; public System.Collections.Generic.List> SentinelSlaves(string masterName) => throw null; public string ServerVersion { get => throw null; } public static int ServerVersionNumber { get => throw null; set => throw null; } public void Set(string key, System.Byte[] value, int expirySeconds, System.Int64 expiryMs = default(System.Int64)) => throw null; public void Set(string key, System.Byte[] value) => throw null; public void Set(System.Byte[] key, System.Byte[] value, int expirySeconds, System.Int64 expiryMs = default(System.Int64)) => throw null; public bool Set(string key, System.Byte[] value, bool exists, int expirySeconds = default(int), System.Int64 expiryMs = default(System.Int64)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SetAsync(string key, System.Byte[] value, bool exists, System.Int64 expirySeconds, System.Int64 expiryMilliseconds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SetAsync(string key, System.Byte[] value, System.Int64 expirySeconds, System.Int64 expiryMilliseconds, System.Threading.CancellationToken token) => throw null; public System.Int64 SetBit(string key, int offset, int value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SetBitAsync(string key, int offset, int value, System.Threading.CancellationToken token) => throw null; public void SetEx(string key, int expireInSeconds, System.Byte[] value) => throw null; public void SetEx(System.Byte[] key, int expireInSeconds, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SetExAsync(string key, int expireInSeconds, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 SetNX(string key, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SetNXAsync(string key, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 SetRange(string key, int offset, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SetRangeAsync(string key, int offset, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public void Shutdown() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ShutdownAsync(bool noSave, System.Threading.CancellationToken token) => throw null; public void ShutdownNoSave() => throw null; public void SlaveOf(string hostname, int port) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SlaveOfAsync(string hostname, int port, System.Threading.CancellationToken token) => throw null; public void SlaveOfNoOne() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SlaveOfNoOneAsync(System.Threading.CancellationToken token) => throw null; public object[] Slowlog(int? top) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SlowlogGetAsync(int? top, System.Threading.CancellationToken token) => throw null; public void SlowlogReset() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SlowlogResetAsync(System.Threading.CancellationToken token) => throw null; public System.Byte[][] Sort(string listOrSetId, ServiceStack.Redis.SortOptions sortOptions) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SortAsync(string listOrSetId, ServiceStack.Redis.SortOptions sortOptions, System.Threading.CancellationToken token) => throw null; public bool Ssl { get => throw null; set => throw null; } public System.Security.Authentication.SslProtocols? SslProtocols { get => throw null; set => throw null; } public System.Int64 StrLen(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.StrLenAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Byte[][] Subscribe(params string[] toChannels) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SubscribeAsync(string[] toChannels, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.SubscribeAsync(params string[] toChannels) => throw null; public System.Byte[][] Time() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.TimeAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 Ttl(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.TtlAsync(string key, System.Threading.CancellationToken token) => throw null; public string Type(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.TypeAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Byte[][] UnSubscribe(params string[] fromChannels) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.UnSubscribeAsync(string[] fromChannels, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.UnSubscribeAsync(params string[] toChannels) => throw null; public void UnWatch() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.UnWatchAsync(System.Threading.CancellationToken token) => throw null; public void Watch(params string[] keys) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.WatchAsync(string[] keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.WatchAsync(params string[] keys) => throw null; public void WriteAllToSendBuffer(params System.Byte[][] cmdWithBinaryArgs) => throw null; protected void WriteCommandToSendBuffer(params System.Byte[][] cmdWithBinaryArgs) => throw null; public void WriteToSendBuffer(System.Byte[] cmdBytes) => throw null; public System.Int64 ZAdd(string setId, double score, System.Byte[] value) => throw null; public System.Int64 ZAdd(string setId, System.Int64 score, System.Byte[] value) => throw null; public System.Int64 ZAdd(string setId, System.Collections.Generic.List> pairs) => throw null; public System.Int64 ZAdd(string setId, System.Collections.Generic.List> pairs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZAddAsync(string setId, double score, System.Byte[] value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZAddAsync(string setId, System.Int64 score, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 ZCard(string setId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZCardAsync(string setId, System.Threading.CancellationToken token) => throw null; public System.Int64 ZCount(string setId, double min, double max) => throw null; public System.Int64 ZCount(string setId, System.Int64 min, System.Int64 max) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZCountAsync(string setId, double min, double max, System.Threading.CancellationToken token) => throw null; public double ZIncrBy(string setId, double incrBy, System.Byte[] value) => throw null; public double ZIncrBy(string setId, System.Int64 incrBy, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZIncrByAsync(string setId, double incrBy, System.Byte[] value, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZIncrByAsync(string setId, System.Int64 incrBy, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 ZInterStore(string intoSetId, string[] setIds, string[] args) => throw null; public System.Int64 ZInterStore(string intoSetId, params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZInterStoreAsync(string intoSetId, string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZInterStoreAsync(string intoSetId, params string[] setIds) => throw null; public System.Int64 ZLexCount(string setId, string min, string max) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZLexCountAsync(string setId, string min, string max, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRange(string setId, int min, int max) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRangeAsync(string setId, int min, int max, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRangeByLex(string setId, string min, string max, int? skip = default(int?), int? take = default(int?)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRangeByLexAsync(string setId, string min, string max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRangeByScore(string setId, double min, double max, int? skip, int? take) => throw null; public System.Byte[][] ZRangeByScore(string setId, System.Int64 min, System.Int64 max, int? skip, int? take) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRangeByScoreAsync(string setId, double min, double max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRangeByScoreAsync(string setId, System.Int64 min, System.Int64 max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRangeByScoreWithScores(string setId, double min, double max, int? skip, int? take) => throw null; public System.Byte[][] ZRangeByScoreWithScores(string setId, System.Int64 min, System.Int64 max, int? skip, int? take) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRangeByScoreWithScoresAsync(string setId, double min, double max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRangeByScoreWithScoresAsync(string setId, System.Int64 min, System.Int64 max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRangeWithScores(string setId, int min, int max) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRangeWithScoresAsync(string setId, int min, int max, System.Threading.CancellationToken token) => throw null; public System.Int64 ZRank(string setId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRankAsync(string setId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 ZRem(string setId, System.Byte[][] values) => throw null; public System.Int64 ZRem(string setId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRemAsync(string setId, System.Byte[][] values, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRemAsync(string setId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 ZRemRangeByLex(string setId, string min, string max) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRemRangeByLexAsync(string setId, string min, string max, System.Threading.CancellationToken token) => throw null; public System.Int64 ZRemRangeByRank(string setId, int min, int max) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRemRangeByRankAsync(string setId, int min, int max, System.Threading.CancellationToken token) => throw null; public System.Int64 ZRemRangeByScore(string setId, double fromScore, double toScore) => throw null; public System.Int64 ZRemRangeByScore(string setId, System.Int64 fromScore, System.Int64 toScore) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRemRangeByScoreAsync(string setId, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRemRangeByScoreAsync(string setId, System.Int64 fromScore, System.Int64 toScore, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRevRange(string setId, int min, int max) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRevRangeAsync(string setId, int min, int max, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRevRangeByScore(string setId, double min, double max, int? skip, int? take) => throw null; public System.Byte[][] ZRevRangeByScore(string setId, System.Int64 min, System.Int64 max, int? skip, int? take) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRevRangeByScoreAsync(string setId, double min, double max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRevRangeByScoreAsync(string setId, System.Int64 min, System.Int64 max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRevRangeByScoreWithScores(string setId, double min, double max, int? skip, int? take) => throw null; public System.Byte[][] ZRevRangeByScoreWithScores(string setId, System.Int64 min, System.Int64 max, int? skip, int? take) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRevRangeByScoreWithScoresAsync(string setId, double min, double max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRevRangeByScoreWithScoresAsync(string setId, System.Int64 min, System.Int64 max, int? skip, int? take, System.Threading.CancellationToken token) => throw null; public System.Byte[][] ZRevRangeWithScores(string setId, int min, int max) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRevRangeWithScoresAsync(string setId, int min, int max, System.Threading.CancellationToken token) => throw null; public System.Int64 ZRevRank(string setId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZRevRankAsync(string setId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.ScanResult ZScan(string setId, System.UInt64 cursor, int count = default(int), string match = default(string)) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZScanAsync(string setId, System.UInt64 cursor, int count, string match, System.Threading.CancellationToken token) => throw null; public double ZScore(string setId, System.Byte[] value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZScoreAsync(string setId, System.Byte[] value, System.Threading.CancellationToken token) => throw null; public System.Int64 ZUnionStore(string intoSetId, string[] setIds, string[] args) => throw null; public System.Int64 ZUnionStore(string intoSetId, params string[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZUnionStoreAsync(string intoSetId, string[] setIds, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisNativeClientAsync.ZUnionStoreAsync(string intoSetId, params string[] setIds) => throw null; protected System.Net.Sockets.Socket socket; protected System.Net.Security.SslStream sslStream; // ERR: Stub generator didn't handle member: ~RedisNativeClient } // Generated from `ServiceStack.Redis.RedisPoolConfig` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisPoolConfig { public static int DefaultMaxPoolSize; public int MaxPoolSize { get => throw null; set => throw null; } public RedisPoolConfig() => throw null; } // Generated from `ServiceStack.Redis.RedisPubSubServer` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisPubSubServer : System.IDisposable, ServiceStack.Redis.IRedisPubSubServer { public const string AllChannelsWildCard = default; public bool AutoRestart { get => throw null; set => throw null; } public System.Int64 BgThreadCount { get => throw null; } public string[] Channels { get => throw null; set => throw null; } public string[] ChannelsMatching { get => throw null; set => throw null; } public ServiceStack.Redis.IRedisClientsManager ClientsManager { get => throw null; set => throw null; } // Generated from `ServiceStack.Redis.RedisPubSubServer+ControlCommand` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class ControlCommand { public const string Control = default; public const string Pulse = default; } public System.DateTime CurrentServerTime { get => throw null; } public virtual void Dispose() => throw null; public string GetStatsDescription() => throw null; public string GetStatus() => throw null; public System.TimeSpan? HeartbeatInterval; public System.TimeSpan HeartbeatTimeout; public bool IsSentinelSubscription { get => throw null; set => throw null; } public System.Action OnControlCommand { get => throw null; set => throw null; } public System.Action OnDispose { get => throw null; set => throw null; } public System.Action OnError { get => throw null; set => throw null; } public System.Action OnFailover { get => throw null; set => throw null; } public System.Action OnHeartbeatReceived { get => throw null; set => throw null; } public System.Action OnHeartbeatSent { get => throw null; set => throw null; } public System.Action OnInit { get => throw null; set => throw null; } public System.Action OnMessage { get => throw null; set => throw null; } public System.Action OnMessageBytes { get => throw null; set => throw null; } public System.Action OnStart { get => throw null; set => throw null; } public System.Action OnStop { get => throw null; set => throw null; } public System.Action OnUnSubscribe { get => throw null; set => throw null; } // Generated from `ServiceStack.Redis.RedisPubSubServer+Operation` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class Operation { public static string GetName(int op) => throw null; public const int NoOp = default; public const int Reset = default; public const int Restart = default; public const int Stop = default; } public RedisPubSubServer(ServiceStack.Redis.IRedisClientsManager clientsManager, params string[] channels) => throw null; public void Restart() => throw null; public ServiceStack.Redis.IRedisPubSubServer Start() => throw null; public void Stop() => throw null; public System.TimeSpan? WaitBeforeNextRestart { get => throw null; set => throw null; } } // Generated from `ServiceStack.Redis.RedisQueueCompletableOperation` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisQueueCompletableOperation { protected virtual void AddCurrentQueuedOperation() => throw null; public virtual void CompleteBytesQueuedCommand(System.Func bytesReadCommand) => throw null; public virtual void CompleteDoubleQueuedCommand(System.Func doubleReadCommand) => throw null; public virtual void CompleteIntQueuedCommand(System.Func intReadCommand) => throw null; public virtual void CompleteLongQueuedCommand(System.Func longReadCommand) => throw null; public virtual void CompleteMultiBytesQueuedCommand(System.Func multiBytesReadCommand) => throw null; public virtual void CompleteMultiStringQueuedCommand(System.Func> multiStringReadCommand) => throw null; public virtual void CompleteRedisDataQueuedCommand(System.Func redisDataReadCommand) => throw null; public virtual void CompleteStringQueuedCommand(System.Func stringReadCommand) => throw null; public virtual void CompleteVoidQueuedCommand(System.Action voidReadCommand) => throw null; public RedisQueueCompletableOperation() => throw null; } // Generated from `ServiceStack.Redis.RedisResolver` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisResolver : ServiceStack.Redis.IRedisResolverExtended, ServiceStack.Redis.IRedisResolver { public System.Func ClientFactory { get => throw null; set => throw null; } public ServiceStack.Redis.RedisClient CreateMasterClient(int desiredIndex) => throw null; public virtual ServiceStack.Redis.RedisClient CreateRedisClient(ServiceStack.Redis.RedisEndpoint config, bool master) => throw null; public ServiceStack.Redis.RedisClient CreateSlaveClient(int desiredIndex) => throw null; public ServiceStack.Redis.RedisEndpoint GetReadOnlyHost(int desiredIndex) => throw null; public ServiceStack.Redis.RedisEndpoint GetReadWriteHost(int desiredIndex) => throw null; protected ServiceStack.Redis.RedisClient GetValidMaster(ServiceStack.Redis.RedisClient client, ServiceStack.Redis.RedisEndpoint config) => throw null; public ServiceStack.Redis.RedisEndpoint[] Masters { get => throw null; } public int ReadOnlyHostsCount { get => throw null; set => throw null; } public int ReadWriteHostsCount { get => throw null; set => throw null; } public RedisResolver(System.Collections.Generic.IEnumerable masters, System.Collections.Generic.IEnumerable replicas) => throw null; public RedisResolver(System.Collections.Generic.IEnumerable masters, System.Collections.Generic.IEnumerable replicas) => throw null; public RedisResolver() => throw null; public virtual void ResetMasters(System.Collections.Generic.List newMasters) => throw null; public virtual void ResetMasters(System.Collections.Generic.IEnumerable hosts) => throw null; public virtual void ResetSlaves(System.Collections.Generic.List newReplicas) => throw null; public virtual void ResetSlaves(System.Collections.Generic.IEnumerable hosts) => throw null; public ServiceStack.Redis.RedisEndpoint[] Slaves { get => throw null; } } // Generated from `ServiceStack.Redis.RedisResolverExtensions` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class RedisResolverExtensions { public static ServiceStack.Redis.RedisClient CreateRedisClient(this ServiceStack.Redis.IRedisResolver resolver, ServiceStack.Redis.RedisEndpoint config, bool master) => throw null; public static ServiceStack.Redis.RedisEndpoint GetReadOnlyHost(this ServiceStack.Redis.IRedisResolver resolver, int desiredIndex) => throw null; public static ServiceStack.Redis.RedisEndpoint GetReadWriteHost(this ServiceStack.Redis.IRedisResolver resolver, int desiredIndex) => throw null; } // Generated from `ServiceStack.Redis.RedisResponseException` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisResponseException : ServiceStack.Redis.RedisException { public string Code { get => throw null; set => throw null; } public RedisResponseException(string message, string code) : base(default(string)) => throw null; public RedisResponseException(string message) : base(default(string)) => throw null; } // Generated from `ServiceStack.Redis.RedisRetryableException` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisRetryableException : ServiceStack.Redis.RedisException { public string Code { get => throw null; set => throw null; } public RedisRetryableException(string message, string code) : base(default(string)) => throw null; public RedisRetryableException(string message) : base(default(string)) => throw null; } // Generated from `ServiceStack.Redis.RedisScripts` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisScripts : ServiceStack.Script.ScriptMethods { public ServiceStack.Redis.IRedisClientsManager RedisManager { get => throw null; set => throw null; } public RedisScripts() => throw null; public object redisCall(ServiceStack.Script.ScriptScopeContext scope, object redisCommand, object options) => throw null; public object redisCall(ServiceStack.Script.ScriptScopeContext scope, object redisCommand) => throw null; public string redisChangeConnection(ServiceStack.Script.ScriptScopeContext scope, object newConnection, object options) => throw null; public string redisChangeConnection(ServiceStack.Script.ScriptScopeContext scope, object newConnection) => throw null; public System.Collections.Generic.Dictionary redisConnection(ServiceStack.Script.ScriptScopeContext scope) => throw null; public string redisConnectionString(ServiceStack.Script.ScriptScopeContext scope) => throw null; public System.Collections.Generic.Dictionary redisInfo(ServiceStack.Script.ScriptScopeContext scope, object options) => throw null; public System.Collections.Generic.Dictionary redisInfo(ServiceStack.Script.ScriptScopeContext scope) => throw null; public System.Collections.Generic.List redisSearchKeys(ServiceStack.Script.ScriptScopeContext scope, string query, object options) => throw null; public System.Collections.Generic.List redisSearchKeys(ServiceStack.Script.ScriptScopeContext scope, string query) => throw null; public string redisSearchKeysAsJson(ServiceStack.Script.ScriptScopeContext scope, string query, object options) => throw null; public string redisToConnectionString(ServiceStack.Script.ScriptScopeContext scope, object connectionInfo, object options) => throw null; public string redisToConnectionString(ServiceStack.Script.ScriptScopeContext scope, object connectionInfo) => throw null; public ServiceStack.Script.IgnoreResult useRedis(ServiceStack.Script.ScriptScopeContext scope, string redisConnection) => throw null; } // Generated from `ServiceStack.Redis.RedisSearchCursorResult` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisSearchCursorResult { public int Cursor { get => throw null; set => throw null; } public RedisSearchCursorResult() => throw null; public System.Collections.Generic.List Results { get => throw null; set => throw null; } } // Generated from `ServiceStack.Redis.RedisSearchResult` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisSearchResult { public string Id { get => throw null; set => throw null; } public RedisSearchResult() => throw null; public System.Int64 Size { get => throw null; set => throw null; } public System.Int64 Ttl { get => throw null; set => throw null; } public string Type { get => throw null; set => throw null; } } // Generated from `ServiceStack.Redis.RedisSentinel` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisSentinel : System.IDisposable, ServiceStack.Redis.IRedisSentinel { public static string DefaultAddress; public static string DefaultMasterName; public void Dispose() => throw null; public void ForceMasterFailover() => throw null; public System.Collections.Generic.List GetActiveSentinelHosts(System.Collections.Generic.IEnumerable sentinelHosts) => throw null; public ServiceStack.Redis.RedisEndpoint GetMaster() => throw null; public ServiceStack.Redis.IRedisClientsManager GetRedisManager() => throw null; public SentinelInfo GetSentinelInfo() => throw null; public System.Collections.Generic.List GetSlaves() => throw null; public System.Func HostFilter { get => throw null; set => throw null; } public System.Collections.Generic.Dictionary IpAddressMap { get => throw null; set => throw null; } protected static ServiceStack.Logging.ILog Log; public string MasterName { get => throw null; } public System.TimeSpan MaxWaitBetweenFailedHosts { get => throw null; set => throw null; } public System.Action OnFailover { get => throw null; set => throw null; } public System.Action OnSentinelMessageReceived { get => throw null; set => throw null; } public System.Action OnWorkerError { get => throw null; set => throw null; } public ServiceStack.Redis.IRedisClientsManager RedisManager { get => throw null; set => throw null; } public System.Func RedisManagerFactory { get => throw null; set => throw null; } public RedisSentinel(string sentinelHost = default(string), string masterName = default(string)) => throw null; public RedisSentinel(System.Collections.Generic.IEnumerable sentinelHosts, string masterName = default(string)) => throw null; public void RefreshActiveSentinels() => throw null; public System.TimeSpan RefreshSentinelHostsAfter { get => throw null; set => throw null; } public SentinelInfo ResetClients() => throw null; public bool ResetWhenObjectivelyDown { get => throw null; set => throw null; } public bool ResetWhenSubjectivelyDown { get => throw null; set => throw null; } public bool ScanForOtherSentinels { get => throw null; set => throw null; } public System.Func SentinelHostFilter { get => throw null; set => throw null; } public System.Collections.Generic.List SentinelHosts { get => throw null; set => throw null; } public int SentinelWorkerConnectTimeoutMs { get => throw null; set => throw null; } public int SentinelWorkerReceiveTimeoutMs { get => throw null; set => throw null; } public int SentinelWorkerSendTimeoutMs { get => throw null; set => throw null; } public ServiceStack.Redis.IRedisClientsManager Start() => throw null; public System.TimeSpan WaitBeforeForcingMasterFailover { get => throw null; set => throw null; } public System.TimeSpan WaitBetweenFailedHosts { get => throw null; set => throw null; } } // Generated from `ServiceStack.Redis.RedisSentinelResolver` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisSentinelResolver : ServiceStack.Redis.IRedisResolverExtended, ServiceStack.Redis.IRedisResolver { public System.Func ClientFactory { get => throw null; set => throw null; } public ServiceStack.Redis.RedisClient CreateMasterClient(int desiredIndex) => throw null; public virtual ServiceStack.Redis.RedisClient CreateRedisClient(ServiceStack.Redis.RedisEndpoint config, bool master) => throw null; public ServiceStack.Redis.RedisClient CreateSlaveClient(int desiredIndex) => throw null; public ServiceStack.Redis.RedisEndpoint GetReadOnlyHost(int desiredIndex) => throw null; public ServiceStack.Redis.RedisEndpoint GetReadWriteHost(int desiredIndex) => throw null; public ServiceStack.Redis.RedisEndpoint[] Masters { get => throw null; } public int ReadOnlyHostsCount { get => throw null; set => throw null; } public int ReadWriteHostsCount { get => throw null; set => throw null; } public RedisSentinelResolver(ServiceStack.Redis.RedisSentinel sentinel, System.Collections.Generic.IEnumerable masters, System.Collections.Generic.IEnumerable replicas) => throw null; public RedisSentinelResolver(ServiceStack.Redis.RedisSentinel sentinel, System.Collections.Generic.IEnumerable masters, System.Collections.Generic.IEnumerable replicas) => throw null; public RedisSentinelResolver(ServiceStack.Redis.RedisSentinel sentinel) => throw null; public virtual void ResetMasters(System.Collections.Generic.List newMasters) => throw null; public virtual void ResetMasters(System.Collections.Generic.IEnumerable hosts) => throw null; public virtual void ResetSlaves(System.Collections.Generic.List newReplicas) => throw null; public virtual void ResetSlaves(System.Collections.Generic.IEnumerable hosts) => throw null; public ServiceStack.Redis.RedisEndpoint[] Slaves { get => throw null; } } // Generated from `ServiceStack.Redis.RedisStats` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class RedisStats { public static void Reset() => throw null; public static System.Collections.Generic.Dictionary ToDictionary() => throw null; public static System.Int64 TotalClientsCreated { get => throw null; } public static System.Int64 TotalClientsCreatedOutsidePool { get => throw null; } public static System.Int64 TotalCommandsSent { get => throw null; } public static System.Int64 TotalDeactivatedClients { get => throw null; } public static System.Int64 TotalFailedSentinelWorkers { get => throw null; } public static System.Int64 TotalFailovers { get => throw null; } public static System.Int64 TotalForcedMasterFailovers { get => throw null; } public static System.Int64 TotalInvalidMasters { get => throw null; } public static System.Int64 TotalNoMastersFound { get => throw null; } public static System.Int64 TotalObjectiveServersDown { get => throw null; } public static System.Int64 TotalPendingDeactivatedClients { get => throw null; } public static System.Int64 TotalRetryCount { get => throw null; } public static System.Int64 TotalRetrySuccess { get => throw null; } public static System.Int64 TotalRetryTimedout { get => throw null; } public static System.Int64 TotalSubjectiveServersDown { get => throw null; } } // Generated from `ServiceStack.Redis.RedisSubscription` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisSubscription : System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.IRedisSubscriptionAsync, ServiceStack.Redis.IRedisSubscription { public void Dispose() => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; public bool IsPSubscription { get => throw null; set => throw null; } public System.Action OnMessage { get => throw null; set => throw null; } event System.Func ServiceStack.Redis.IRedisSubscriptionAsync.OnMessageAsync { add => throw null; remove => throw null; } public System.Action OnMessageBytes { get => throw null; set => throw null; } event System.Func ServiceStack.Redis.IRedisSubscriptionAsync.OnMessageBytesAsync { add => throw null; remove => throw null; } public System.Action OnSubscribe { get => throw null; set => throw null; } event System.Func ServiceStack.Redis.IRedisSubscriptionAsync.OnSubscribeAsync { add => throw null; remove => throw null; } public System.Action OnUnSubscribe { get => throw null; set => throw null; } event System.Func ServiceStack.Redis.IRedisSubscriptionAsync.OnUnSubscribeAsync { add => throw null; remove => throw null; } public RedisSubscription(ServiceStack.Redis.IRedisNativeClient redisClient) => throw null; public void SubscribeToChannels(params string[] channels) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.SubscribeToChannelsAsync(string[] channels, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.SubscribeToChannelsAsync(params string[] channels) => throw null; public void SubscribeToChannelsMatching(params string[] patterns) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.SubscribeToChannelsMatchingAsync(string[] patterns, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.SubscribeToChannelsMatchingAsync(params string[] patterns) => throw null; public System.Int64 SubscriptionCount { get => throw null; set => throw null; } public void UnSubscribeFromAllChannels() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.UnSubscribeFromAllChannelsAsync(System.Threading.CancellationToken token) => throw null; public void UnSubscribeFromAllChannelsMatchingAnyPatterns() => throw null; public void UnSubscribeFromChannels(params string[] channels) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.UnSubscribeFromChannelsAsync(string[] channels, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.UnSubscribeFromChannelsAsync(params string[] channels) => throw null; public void UnSubscribeFromChannelsMatching(params string[] patterns) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.UnSubscribeFromChannelsMatchingAsync(string[] patterns, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisSubscriptionAsync.UnSubscribeFromChannelsMatchingAsync(params string[] patterns) => throw null; } // Generated from `ServiceStack.Redis.RedisTransaction` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisTransaction : ServiceStack.Redis.RedisAllPurposePipeline, System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.Pipeline.IRedisQueueableOperationAsync, ServiceStack.Redis.Pipeline.IRedisQueueableOperation, ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync, ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperation, ServiceStack.Redis.Pipeline.IRedisPipelineSharedAsync, ServiceStack.Redis.Pipeline.IRedisPipelineShared, ServiceStack.Redis.IRedisTransactionBaseAsync, ServiceStack.Redis.IRedisTransactionBase, ServiceStack.Redis.IRedisTransactionAsync, ServiceStack.Redis.IRedisTransaction { protected override void AddCurrentQueuedOperation() => throw null; public bool Commit() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisTransactionAsync.CommitAsync(System.Threading.CancellationToken token) => throw null; public override void Dispose() => throw null; protected override void Init() => throw null; public RedisTransaction(ServiceStack.Redis.RedisClient redisClient) : base(default(ServiceStack.Redis.RedisClient)) => throw null; internal RedisTransaction(ServiceStack.Redis.RedisClient redisClient, bool isAsync) : base(default(ServiceStack.Redis.RedisClient)) => throw null; public override bool Replay() => throw null; public void Rollback() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.IRedisTransactionAsync.RollbackAsync(System.Threading.CancellationToken token) => throw null; } // Generated from `ServiceStack.Redis.RedisTransactionFailedException` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisTransactionFailedException : System.Exception { public RedisTransactionFailedException() => throw null; } // Generated from `ServiceStack.Redis.RedisTypedPipeline<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisTypedPipeline : ServiceStack.Redis.Generic.RedisTypedCommandQueue, System.IDisposable, System.IAsyncDisposable, ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync, ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperation, ServiceStack.Redis.Pipeline.IRedisPipelineSharedAsync, ServiceStack.Redis.Pipeline.IRedisPipelineShared, ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync, ServiceStack.Redis.Generic.IRedisTypedQueueableOperation, ServiceStack.Redis.Generic.IRedisTypedPipelineAsync, ServiceStack.Redis.Generic.IRedisTypedPipeline { protected void ClosePipeline() => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteBytesQueuedCommandAsync(System.Func> bytesReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteDoubleQueuedCommandAsync(System.Func> doubleReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteIntQueuedCommandAsync(System.Func> intReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteLongQueuedCommandAsync(System.Func> longReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteMultiBytesQueuedCommandAsync(System.Func> multiBytesReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteMultiStringQueuedCommandAsync(System.Func>> multiStringReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteRedisDataQueuedCommandAsync(System.Func> redisDataReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteStringQueuedCommandAsync(System.Func> stringReadCommand) => throw null; void ServiceStack.Redis.Pipeline.IRedisQueueCompletableOperationAsync.CompleteVoidQueuedCommandAsync(System.Func voidReadCommand) => throw null; public virtual void Dispose() => throw null; System.Threading.Tasks.ValueTask System.IAsyncDisposable.DisposeAsync() => throw null; protected void Execute() => throw null; public void Flush() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Pipeline.IRedisPipelineSharedAsync.FlushAsync(System.Threading.CancellationToken token) => throw null; protected virtual void Init() => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask>> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask>> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask>> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; void ServiceStack.Redis.Generic.IRedisTypedQueueableOperationAsync.QueueCommand(System.Func, System.Threading.Tasks.ValueTask> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; internal RedisTypedPipeline(ServiceStack.Redis.Generic.RedisTypedClient redisClient) : base(default(ServiceStack.Redis.Generic.RedisTypedClient)) => throw null; public virtual bool Replay() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Pipeline.IRedisPipelineSharedAsync.ReplayAsync(System.Threading.CancellationToken token) => throw null; } // Generated from `ServiceStack.Redis.ScanResultExtensions` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class ScanResultExtensions { public static System.Collections.Generic.Dictionary AsItemsWithScores(this ServiceStack.Redis.ScanResult result) => throw null; public static System.Collections.Generic.Dictionary AsKeyValues(this ServiceStack.Redis.ScanResult result) => throw null; public static System.Collections.Generic.List AsStrings(this ServiceStack.Redis.ScanResult result) => throw null; } // Generated from `ServiceStack.Redis.ShardedConnectionPool` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class ShardedConnectionPool : ServiceStack.Redis.PooledRedisClientManager { public override int GetHashCode() => throw null; public ShardedConnectionPool(string name, int weight, params string[] readWriteHosts) => throw null; public string name; public int weight; } // Generated from `ServiceStack.Redis.ShardedRedisClientManager` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class ShardedRedisClientManager { public ServiceStack.Redis.ShardedConnectionPool GetConnectionPool(string key) => throw null; public ShardedRedisClientManager(params ServiceStack.Redis.ShardedConnectionPool[] connectionPools) => throw null; } // Generated from `ServiceStack.Redis.TemplateRedisFilters` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class TemplateRedisFilters : ServiceStack.Redis.RedisScripts { public TemplateRedisFilters() => throw null; } namespace Generic { // Generated from `ServiceStack.Redis.Generic.ManagedList<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class ManagedList : System.Collections.IEnumerable, System.Collections.Generic.IList, System.Collections.Generic.IEnumerable, System.Collections.Generic.ICollection { public void Add(T item) => throw null; public void Clear() => throw null; public bool Contains(T item) => throw null; public void CopyTo(T[] array, int arrayIndex) => throw null; public int Count { get => throw null; } public System.Collections.Generic.IEnumerator GetEnumerator() => throw null; System.Collections.IEnumerator System.Collections.IEnumerable.GetEnumerator() => throw null; public int IndexOf(T item) => throw null; public void Insert(int index, T item) => throw null; public bool IsReadOnly { get => throw null; } public T this[int index] { get => throw null; set => throw null; } public ManagedList(ServiceStack.Redis.IRedisClientsManager manager, string key) => throw null; public bool Remove(T item) => throw null; public void RemoveAt(int index) => throw null; } // Generated from `ServiceStack.Redis.Generic.RedisClientsManagerExtensionsGeneric` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public static class RedisClientsManagerExtensionsGeneric { public static ServiceStack.Redis.Generic.ManagedList GetManagedList(this ServiceStack.Redis.IRedisClientsManager manager, string key) => throw null; } // Generated from `ServiceStack.Redis.Generic.RedisTypedClient<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisTypedClient : ServiceStack.Redis.Generic.IRedisTypedClientAsync, ServiceStack.Redis.Generic.IRedisTypedClient, ServiceStack.Data.IEntityStoreAsync, ServiceStack.Data.IEntityStore { public System.IDisposable AcquireLock(System.TimeSpan timeOut) => throw null; public System.IDisposable AcquireLock() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.AcquireLockAsync(System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public void AddItemToList(ServiceStack.Redis.Generic.IRedisList fromList, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.AddItemToListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, T value, System.Threading.CancellationToken token) => throw null; public void AddItemToSet(ServiceStack.Redis.Generic.IRedisSet toSet, T item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.AddItemToSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync toSet, T item, System.Threading.CancellationToken token) => throw null; public void AddItemToSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet toSet, T value, double score) => throw null; public void AddItemToSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet toSet, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.AddItemToSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync toSet, T value, double score, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.AddItemToSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync toSet, T value, System.Threading.CancellationToken token) => throw null; public void AddRangeToList(ServiceStack.Redis.Generic.IRedisList fromList, System.Collections.Generic.IEnumerable values) => throw null; public void AddToRecentsList(T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.AddToRecentsListAsync(T value, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.Generic.IRedisTypedClientAsync AsAsync() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.BackgroundSaveAsync(System.Threading.CancellationToken token) => throw null; public T BlockingDequeueItemFromList(ServiceStack.Redis.Generic.IRedisList fromList, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.BlockingDequeueItemFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public T BlockingPopAndPushItemBetweenLists(ServiceStack.Redis.Generic.IRedisList fromList, ServiceStack.Redis.Generic.IRedisList toList, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.BlockingPopAndPushItemBetweenListsAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, ServiceStack.Redis.Generic.IRedisListAsync toList, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public T BlockingPopItemFromList(ServiceStack.Redis.Generic.IRedisList fromList, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.BlockingPopItemFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public T BlockingRemoveStartFromList(ServiceStack.Redis.Generic.IRedisList fromList, System.TimeSpan? timeOut) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.BlockingRemoveStartFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.TimeSpan? timeOut, System.Threading.CancellationToken token) => throw null; public bool ContainsKey(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.ContainsKeyAsync(string key, System.Threading.CancellationToken token) => throw null; public static System.Collections.Generic.Dictionary ConvertEachTo(System.Collections.Generic.IDictionary map) => throw null; public ServiceStack.Redis.Generic.IRedisTypedPipeline CreatePipeline() => throw null; ServiceStack.Redis.Generic.IRedisTypedPipelineAsync ServiceStack.Redis.Generic.IRedisTypedClientAsync.CreatePipeline() => throw null; public ServiceStack.Redis.Generic.IRedisTypedTransaction CreateTransaction() => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.CreateTransactionAsync(System.Threading.CancellationToken token) => throw null; public System.Int64 Db { get => throw null; set => throw null; } System.Int64 ServiceStack.Redis.Generic.IRedisTypedClientAsync.Db { get => throw null; } public System.Int64 DecrementValue(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.DecrementValueAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Int64 DecrementValueBy(string key, int count) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.DecrementValueByAsync(string key, int count, System.Threading.CancellationToken token) => throw null; public void Delete(T entity) => throw null; public void DeleteAll() => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.DeleteAllAsync(System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.DeleteAsync(T entity, System.Threading.CancellationToken token) => throw null; public void DeleteById(object id) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.DeleteByIdAsync(object id, System.Threading.CancellationToken token) => throw null; public void DeleteByIds(System.Collections.IEnumerable ids) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.DeleteByIdsAsync(System.Collections.IEnumerable ids, System.Threading.CancellationToken token) => throw null; public void DeleteRelatedEntities(object parentId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.DeleteRelatedEntitiesAsync(object parentId, System.Threading.CancellationToken token) => throw null; public void DeleteRelatedEntity(object parentId, object childId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.DeleteRelatedEntityAsync(object parentId, object childId, System.Threading.CancellationToken token) => throw null; public T DequeueItemFromList(ServiceStack.Redis.Generic.IRedisList fromList) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.DequeueItemFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.Threading.CancellationToken token) => throw null; public static T DeserializeFromString(string serializedObj) => throw null; public T DeserializeValue(System.Byte[] value) => throw null; public void Discard() => throw null; public void EnqueueItemOnList(ServiceStack.Redis.Generic.IRedisList fromList, T item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.EnqueueItemOnListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, T item, System.Threading.CancellationToken token) => throw null; public void Exec() => throw null; public bool ExpireAt(object id, System.DateTime expireAt) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.ExpireAtAsync(object id, System.DateTime expireAt, System.Threading.CancellationToken token) => throw null; public bool ExpireEntryAt(string key, System.DateTime expireAt) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.ExpireEntryAtAsync(string key, System.DateTime expireAt, System.Threading.CancellationToken token) => throw null; public bool ExpireEntryIn(string key, System.TimeSpan expireIn) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.ExpireEntryInAsync(string key, System.TimeSpan expireIn, System.Threading.CancellationToken token) => throw null; public bool ExpireIn(object id, System.TimeSpan expireIn) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.ExpireInAsync(object id, System.TimeSpan expiresIn, System.Threading.CancellationToken token) => throw null; public void FlushAll() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.FlushAllAsync(System.Threading.CancellationToken token) => throw null; public void FlushDb() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.FlushDbAsync(System.Threading.CancellationToken token) => throw null; public void FlushSendBuffer() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.ForegroundSaveAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IList GetAll() => throw null; System.Threading.Tasks.Task> ServiceStack.Data.IEntityStoreAsync.GetAllAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.Dictionary GetAllEntriesFromHash(ServiceStack.Redis.Generic.IRedisHash hash) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetAllEntriesFromHashAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetAllItemsFromList(ServiceStack.Redis.Generic.IRedisList fromList) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetAllItemsFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.HashSet GetAllItemsFromSet(ServiceStack.Redis.Generic.IRedisSet fromSet) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetAllItemsFromSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync fromSet, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetAllItemsFromSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet set) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetAllItemsFromSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetAllItemsFromSortedSetDesc(ServiceStack.Redis.Generic.IRedisSortedSet set) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetAllItemsFromSortedSetDescAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetAllKeys() => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetAllKeysAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetAllWithScoresFromSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet set) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetAllWithScoresFromSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, System.Threading.CancellationToken token) => throw null; public T GetAndSetValue(string key, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetAndSetValueAsync(string key, T value, System.Threading.CancellationToken token) => throw null; public T GetById(object id) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.GetByIdAsync(object id, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IList GetByIds(System.Collections.IEnumerable ids) => throw null; System.Threading.Tasks.Task> ServiceStack.Data.IEntityStoreAsync.GetByIdsAsync(System.Collections.IEnumerable ids, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.HashSet GetDifferencesFromSet(ServiceStack.Redis.Generic.IRedisSet fromSet, params ServiceStack.Redis.Generic.IRedisSet[] withSets) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetDifferencesFromSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync fromSet, params ServiceStack.Redis.Generic.IRedisSetAsync[] withSets) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetDifferencesFromSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync fromSet, ServiceStack.Redis.Generic.IRedisSetAsync[] withSets, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetEarliestFromRecentsList(int skip, int take) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetEarliestFromRecentsListAsync(int skip, int take, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.RedisKeyType GetEntryType(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetEntryTypeAsync(string key, System.Threading.CancellationToken token) => throw null; public T GetFromHash(object id) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetFromHashAsync(object id, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.Generic.IRedisHash GetHash(string hashId) => throw null; ServiceStack.Redis.Generic.IRedisHashAsync ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetHash(string hashId) => throw null; public System.Int64 GetHashCount(ServiceStack.Redis.Generic.IRedisHash hash) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetHashCountAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetHashKeys(ServiceStack.Redis.Generic.IRedisHash hash) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetHashKeysAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetHashValues(ServiceStack.Redis.Generic.IRedisHash hash) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetHashValuesAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.HashSet GetIntersectFromSets(params ServiceStack.Redis.Generic.IRedisSet[] sets) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetIntersectFromSetsAsync(params ServiceStack.Redis.Generic.IRedisSetAsync[] sets) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetIntersectFromSetsAsync(ServiceStack.Redis.Generic.IRedisSetAsync[] sets, System.Threading.CancellationToken token) => throw null; public T GetItemFromList(ServiceStack.Redis.Generic.IRedisList fromList, int listIndex) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetItemFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, int listIndex, System.Threading.CancellationToken token) => throw null; public System.Int64 GetItemIndexInSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet set, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetItemIndexInSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, T value, System.Threading.CancellationToken token) => throw null; public System.Int64 GetItemIndexInSortedSetDesc(ServiceStack.Redis.Generic.IRedisSortedSet set, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetItemIndexInSortedSetDescAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, T value, System.Threading.CancellationToken token) => throw null; public double GetItemScoreInSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet set, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetItemScoreInSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, T value, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetLatestFromRecentsList(int skip, int take) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetLatestFromRecentsListAsync(int skip, int take, System.Threading.CancellationToken token) => throw null; public System.Int64 GetListCount(ServiceStack.Redis.Generic.IRedisList fromList) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetListCountAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.Threading.CancellationToken token) => throw null; public System.Int64 GetNextSequence(int incrBy) => throw null; public System.Int64 GetNextSequence() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetNextSequenceAsync(int incrBy, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetNextSequenceAsync(System.Threading.CancellationToken token) => throw null; public T GetRandomItemFromSet(ServiceStack.Redis.Generic.IRedisSet fromSet) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRandomItemFromSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync fromSet, System.Threading.CancellationToken token) => throw null; public string GetRandomKey() => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRandomKeyAsync(System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromList(ServiceStack.Redis.Generic.IRedisList fromList, int startingFrom, int endingAt) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, int startingFrom, int endingAt, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet set, int fromRank, int toRank) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, int fromRank, int toRank, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, string fromStringScore, string toStringScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, string fromStringScore, string toStringScore) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByHighestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetByHighestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, string fromStringScore, string toStringScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetByHighestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetByHighestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetByHighestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, string fromStringScore, string toStringScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, string fromStringScore, string toStringScore) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore, int? skip, int? take) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetByLowestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetByLowestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, string fromStringScore, string toStringScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetByLowestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetByLowestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetByLowestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRangeFromSortedSetDesc(ServiceStack.Redis.Generic.IRedisSortedSet set, int fromRank, int toRank) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeFromSortedSetDescAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, int fromRank, int toRank, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet set, int fromRank, int toRank) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, int fromRank, int toRank, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, string fromStringScore, string toStringScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, string fromStringScore, string toStringScore) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByHighestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, string fromStringScore, string toStringScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetByHighestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, string fromStringScore, string toStringScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, string fromStringScore, string toStringScore) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore, int? skip, int? take) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetByLowestScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, string fromStringScore, string toStringScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, string fromStringScore, string toStringScore, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, int? skip, int? take, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetByLowestScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.IDictionary GetRangeWithScoresFromSortedSetDesc(ServiceStack.Redis.Generic.IRedisSortedSet set, int fromRank, int toRank) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRangeWithScoresFromSortedSetDescAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, int fromRank, int toRank, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetRelatedEntities(object parentId) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRelatedEntitiesAsync(object parentId, System.Threading.CancellationToken token) => throw null; public System.Int64 GetRelatedEntitiesCount(object parentId) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetRelatedEntitiesCountAsync(object parentId, System.Threading.CancellationToken token) => throw null; public System.Int64 GetSetCount(ServiceStack.Redis.Generic.IRedisSet set) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetSetCountAsync(ServiceStack.Redis.Generic.IRedisSetAsync set, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetSortedEntryValues(ServiceStack.Redis.Generic.IRedisSet fromSet, int startingFrom, int endingAt) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetSortedEntryValuesAsync(ServiceStack.Redis.Generic.IRedisSetAsync fromSet, int startingFrom, int endingAt, System.Threading.CancellationToken token) => throw null; public System.Int64 GetSortedSetCount(ServiceStack.Redis.Generic.IRedisSortedSet set) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetSortedSetCountAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, System.Threading.CancellationToken token) => throw null; public System.TimeSpan GetTimeToLive(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetTimeToLiveAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.HashSet GetUnionFromSets(params ServiceStack.Redis.Generic.IRedisSet[] sets) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetUnionFromSetsAsync(params ServiceStack.Redis.Generic.IRedisSetAsync[] sets) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetUnionFromSetsAsync(ServiceStack.Redis.Generic.IRedisSetAsync[] sets, System.Threading.CancellationToken token) => throw null; public T GetValue(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetValueAsync(string key, System.Threading.CancellationToken token) => throw null; public T GetValueFromHash(ServiceStack.Redis.Generic.IRedisHash hash, TKey key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetValueFromHashAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, TKey key, System.Threading.CancellationToken token) => throw null; public System.Collections.Generic.List GetValues(System.Collections.Generic.List keys) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.GetValuesAsync(System.Collections.Generic.List keys, System.Threading.CancellationToken token) => throw null; public bool HashContainsEntry(ServiceStack.Redis.Generic.IRedisHash hash, TKey key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.HashContainsEntryAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, TKey key, System.Threading.CancellationToken token) => throw null; public double IncrementItemInSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet set, T value, double incrementBy) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.IncrementItemInSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, T value, double incrementBy, System.Threading.CancellationToken token) => throw null; public System.Int64 IncrementValue(string key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.IncrementValueAsync(string key, System.Threading.CancellationToken token) => throw null; public System.Int64 IncrementValueBy(string key, int count) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.IncrementValueByAsync(string key, int count, System.Threading.CancellationToken token) => throw null; public void InsertAfterItemInList(ServiceStack.Redis.Generic.IRedisList toList, T pivot, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.InsertAfterItemInListAsync(ServiceStack.Redis.Generic.IRedisListAsync toList, T pivot, T value, System.Threading.CancellationToken token) => throw null; public void InsertBeforeItemInList(ServiceStack.Redis.Generic.IRedisList toList, T pivot, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.InsertBeforeItemInListAsync(ServiceStack.Redis.Generic.IRedisListAsync toList, T pivot, T value, System.Threading.CancellationToken token) => throw null; public T this[string key] { get => throw null; set => throw null; } public ServiceStack.Model.IHasNamed> Lists { get => throw null; set => throw null; } ServiceStack.Model.IHasNamed> ServiceStack.Redis.Generic.IRedisTypedClientAsync.Lists { get => throw null; } public void MoveBetweenSets(ServiceStack.Redis.Generic.IRedisSet fromSet, ServiceStack.Redis.Generic.IRedisSet toSet, T item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.MoveBetweenSetsAsync(ServiceStack.Redis.Generic.IRedisSetAsync fromSet, ServiceStack.Redis.Generic.IRedisSetAsync toSet, T item, System.Threading.CancellationToken token) => throw null; public void Multi() => throw null; public ServiceStack.Redis.IRedisNativeClient NativeClient { get => throw null; } public ServiceStack.Redis.Pipeline.IRedisPipelineShared Pipeline { get => throw null; set => throw null; } public T PopAndPushItemBetweenLists(ServiceStack.Redis.Generic.IRedisList fromList, ServiceStack.Redis.Generic.IRedisList toList) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.PopAndPushItemBetweenListsAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, ServiceStack.Redis.Generic.IRedisListAsync toList, System.Threading.CancellationToken token) => throw null; public T PopItemFromList(ServiceStack.Redis.Generic.IRedisList fromList) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.PopItemFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.Threading.CancellationToken token) => throw null; public T PopItemFromSet(ServiceStack.Redis.Generic.IRedisSet fromSet) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.PopItemFromSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync fromSet, System.Threading.CancellationToken token) => throw null; public T PopItemWithHighestScoreFromSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet fromSet) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.PopItemWithHighestScoreFromSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync fromSet, System.Threading.CancellationToken token) => throw null; public T PopItemWithLowestScoreFromSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet fromSet) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.PopItemWithLowestScoreFromSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync fromSet, System.Threading.CancellationToken token) => throw null; public void PrependItemToList(ServiceStack.Redis.Generic.IRedisList fromList, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.PrependItemToListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, T value, System.Threading.CancellationToken token) => throw null; public void PushItemToList(ServiceStack.Redis.Generic.IRedisList fromList, T item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.PushItemToListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, T item, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.IRedisClient RedisClient { get => throw null; } ServiceStack.Redis.IRedisClientAsync ServiceStack.Redis.Generic.IRedisTypedClientAsync.RedisClient { get => throw null; } public RedisTypedClient(ServiceStack.Redis.RedisClient client) => throw null; public void RemoveAllFromList(ServiceStack.Redis.Generic.IRedisList fromList) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveAllFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.Threading.CancellationToken token) => throw null; public T RemoveEndFromList(ServiceStack.Redis.Generic.IRedisList fromList) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveEndFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.Threading.CancellationToken token) => throw null; public bool RemoveEntry(string key) => throw null; public bool RemoveEntry(params string[] keys) => throw null; public bool RemoveEntry(params ServiceStack.Model.IHasStringId[] entities) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveEntryAsync(string[] keys, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveEntryAsync(string key, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveEntryAsync(params string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveEntryAsync(params ServiceStack.Model.IHasStringId[] entities) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveEntryAsync(ServiceStack.Model.IHasStringId[] entities, System.Threading.CancellationToken token) => throw null; public bool RemoveEntryFromHash(ServiceStack.Redis.Generic.IRedisHash hash, TKey key) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveEntryFromHashAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, TKey key, System.Threading.CancellationToken token) => throw null; public System.Int64 RemoveItemFromList(ServiceStack.Redis.Generic.IRedisList fromList, T value, int noOfMatches) => throw null; public System.Int64 RemoveItemFromList(ServiceStack.Redis.Generic.IRedisList fromList, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveItemFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, T value, int noOfMatches, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveItemFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, T value, System.Threading.CancellationToken token) => throw null; public void RemoveItemFromSet(ServiceStack.Redis.Generic.IRedisSet fromSet, T item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveItemFromSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync fromSet, T item, System.Threading.CancellationToken token) => throw null; public bool RemoveItemFromSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet fromSet, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveItemFromSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync fromSet, T value, System.Threading.CancellationToken token) => throw null; public System.Int64 RemoveRangeFromSortedSet(ServiceStack.Redis.Generic.IRedisSortedSet set, int minRank, int maxRank) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveRangeFromSortedSetAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, int minRank, int maxRank, System.Threading.CancellationToken token) => throw null; public System.Int64 RemoveRangeFromSortedSetByScore(ServiceStack.Redis.Generic.IRedisSortedSet set, double fromScore, double toScore) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveRangeFromSortedSetByScoreAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, double fromScore, double toScore, System.Threading.CancellationToken token) => throw null; public T RemoveStartFromList(ServiceStack.Redis.Generic.IRedisList fromList) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.RemoveStartFromListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, System.Threading.CancellationToken token) => throw null; public void ResetSendBuffer() => throw null; public void Save() => throw null; public void SaveAsync() => throw null; public T[] SearchKeys(string pattern) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SearchKeysAsync(string pattern, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SelectAsync(System.Int64 db, System.Threading.CancellationToken token) => throw null; public string SequenceKey { get => throw null; set => throw null; } public System.Byte[] SerializeValue(T value) => throw null; public bool SetContainsItem(ServiceStack.Redis.Generic.IRedisSet set, T item) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetContainsItemAsync(ServiceStack.Redis.Generic.IRedisSetAsync set, T item, System.Threading.CancellationToken token) => throw null; public bool SetEntryInHash(ServiceStack.Redis.Generic.IRedisHash hash, TKey key, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetEntryInHashAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, TKey key, T value, System.Threading.CancellationToken token) => throw null; public bool SetEntryInHashIfNotExists(ServiceStack.Redis.Generic.IRedisHash hash, TKey key, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetEntryInHashIfNotExistsAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, TKey key, T value, System.Threading.CancellationToken token) => throw null; public void SetItemInList(ServiceStack.Redis.Generic.IRedisList toList, int listIndex, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetItemInListAsync(ServiceStack.Redis.Generic.IRedisListAsync toList, int listIndex, T value, System.Threading.CancellationToken token) => throw null; public void SetRangeInHash(ServiceStack.Redis.Generic.IRedisHash hash, System.Collections.Generic.IEnumerable> keyValuePairs) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetRangeInHashAsync(ServiceStack.Redis.Generic.IRedisHashAsync hash, System.Collections.Generic.IEnumerable> keyValuePairs, System.Threading.CancellationToken token) => throw null; public void SetSequence(int value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetSequenceAsync(int value, System.Threading.CancellationToken token) => throw null; public void SetValue(string key, T entity, System.TimeSpan expireIn) => throw null; public void SetValue(string key, T entity) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetValueAsync(string key, T entity, System.TimeSpan expireIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetValueAsync(string key, T entity, System.Threading.CancellationToken token) => throw null; public bool SetValueIfExists(string key, T entity) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetValueIfExistsAsync(string key, T entity, System.Threading.CancellationToken token) => throw null; public bool SetValueIfNotExists(string key, T entity) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SetValueIfNotExistsAsync(string key, T entity, System.Threading.CancellationToken token) => throw null; public ServiceStack.Model.IHasNamed> Sets { get => throw null; set => throw null; } ServiceStack.Model.IHasNamed> ServiceStack.Redis.Generic.IRedisTypedClientAsync.Sets { get => throw null; } public System.Collections.Generic.List SortList(ServiceStack.Redis.Generic.IRedisList fromList, int startingFrom, int endingAt) => throw null; System.Threading.Tasks.ValueTask> ServiceStack.Redis.Generic.IRedisTypedClientAsync.SortListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, int startingFrom, int endingAt, System.Threading.CancellationToken token) => throw null; public bool SortedSetContainsItem(ServiceStack.Redis.Generic.IRedisSortedSet set, T value) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.SortedSetContainsItemAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync set, T value, System.Threading.CancellationToken token) => throw null; public ServiceStack.Model.IHasNamed> SortedSets { get => throw null; set => throw null; } ServiceStack.Model.IHasNamed> ServiceStack.Redis.Generic.IRedisTypedClientAsync.SortedSets { get => throw null; } public T Store(T entity, System.TimeSpan expireIn) => throw null; public T Store(T entity) => throw null; public void StoreAll(System.Collections.Generic.IEnumerable entities) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.StoreAllAsync(System.Collections.Generic.IEnumerable entities, System.Threading.CancellationToken token) => throw null; public void StoreAsHash(T entity) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreAsHashAsync(T entity, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreAsync(T entity, System.TimeSpan expireIn, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.Task ServiceStack.Data.IEntityStoreAsync.StoreAsync(T entity, System.Threading.CancellationToken token) => throw null; public void StoreDifferencesFromSet(ServiceStack.Redis.Generic.IRedisSet intoSet, ServiceStack.Redis.Generic.IRedisSet fromSet, params ServiceStack.Redis.Generic.IRedisSet[] withSets) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreDifferencesFromSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync intoSet, ServiceStack.Redis.Generic.IRedisSetAsync fromSet, params ServiceStack.Redis.Generic.IRedisSetAsync[] withSets) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreDifferencesFromSetAsync(ServiceStack.Redis.Generic.IRedisSetAsync intoSet, ServiceStack.Redis.Generic.IRedisSetAsync fromSet, ServiceStack.Redis.Generic.IRedisSetAsync[] withSets, System.Threading.CancellationToken token) => throw null; public void StoreIntersectFromSets(ServiceStack.Redis.Generic.IRedisSet intoSet, params ServiceStack.Redis.Generic.IRedisSet[] sets) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreIntersectFromSetsAsync(ServiceStack.Redis.Generic.IRedisSetAsync intoSet, params ServiceStack.Redis.Generic.IRedisSetAsync[] sets) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreIntersectFromSetsAsync(ServiceStack.Redis.Generic.IRedisSetAsync intoSet, ServiceStack.Redis.Generic.IRedisSetAsync[] sets, System.Threading.CancellationToken token) => throw null; public System.Int64 StoreIntersectFromSortedSets(ServiceStack.Redis.Generic.IRedisSortedSet intoSetId, params ServiceStack.Redis.Generic.IRedisSortedSet[] setIds) => throw null; public System.Int64 StoreIntersectFromSortedSets(ServiceStack.Redis.Generic.IRedisSortedSet intoSetId, ServiceStack.Redis.Generic.IRedisSortedSet[] setIds, string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreIntersectFromSortedSetsAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync intoSetId, params ServiceStack.Redis.Generic.IRedisSortedSetAsync[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreIntersectFromSortedSetsAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync intoSetId, ServiceStack.Redis.Generic.IRedisSortedSetAsync[] setIds, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreIntersectFromSortedSetsAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync intoSetId, ServiceStack.Redis.Generic.IRedisSortedSetAsync[] setIds, System.Threading.CancellationToken token) => throw null; public void StoreRelatedEntities(object parentId, params TChild[] children) => throw null; public void StoreRelatedEntities(object parentId, System.Collections.Generic.List children) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreRelatedEntitiesAsync(object parentId, params TChild[] children) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreRelatedEntitiesAsync(object parentId, TChild[] children, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreRelatedEntitiesAsync(object parentId, System.Collections.Generic.List children, System.Threading.CancellationToken token) => throw null; public void StoreUnionFromSets(ServiceStack.Redis.Generic.IRedisSet intoSet, params ServiceStack.Redis.Generic.IRedisSet[] sets) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreUnionFromSetsAsync(ServiceStack.Redis.Generic.IRedisSetAsync intoSet, params ServiceStack.Redis.Generic.IRedisSetAsync[] sets) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreUnionFromSetsAsync(ServiceStack.Redis.Generic.IRedisSetAsync intoSet, ServiceStack.Redis.Generic.IRedisSetAsync[] sets, System.Threading.CancellationToken token) => throw null; public System.Int64 StoreUnionFromSortedSets(ServiceStack.Redis.Generic.IRedisSortedSet intoSetId, params ServiceStack.Redis.Generic.IRedisSortedSet[] setIds) => throw null; public System.Int64 StoreUnionFromSortedSets(ServiceStack.Redis.Generic.IRedisSortedSet intoSetId, ServiceStack.Redis.Generic.IRedisSortedSet[] setIds, string[] args) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreUnionFromSortedSetsAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync intoSetId, params ServiceStack.Redis.Generic.IRedisSortedSetAsync[] setIds) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreUnionFromSortedSetsAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync intoSetId, ServiceStack.Redis.Generic.IRedisSortedSetAsync[] setIds, string[] args, System.Threading.CancellationToken token) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.StoreUnionFromSortedSetsAsync(ServiceStack.Redis.Generic.IRedisSortedSetAsync intoSetId, ServiceStack.Redis.Generic.IRedisSortedSetAsync[] setIds, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.IRedisTransactionBase Transaction { get => throw null; set => throw null; } public void TrimList(ServiceStack.Redis.Generic.IRedisList fromList, int keepStartingFrom, int keepEndingAt) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Generic.IRedisTypedClientAsync.TrimListAsync(ServiceStack.Redis.Generic.IRedisListAsync fromList, int keepStartingFrom, int keepEndingAt, System.Threading.CancellationToken token) => throw null; public ServiceStack.Redis.IRedisSet TypeIdsSet { get => throw null; } ServiceStack.Redis.IRedisSetAsync ServiceStack.Redis.Generic.IRedisTypedClientAsync.TypeIdsSet { get => throw null; } public string TypeIdsSetKey { get => throw null; set => throw null; } public string TypeLockKey { get => throw null; set => throw null; } public void UnWatch() => throw null; public string UrnKey(T entity) => throw null; public void Watch(params string[] keys) => throw null; } // Generated from `ServiceStack.Redis.Generic.RedisTypedCommandQueue<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisTypedCommandQueue : ServiceStack.Redis.RedisQueueCompletableOperation { public void QueueCommand(System.Func, string> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, string> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func, string> command) => throw null; public void QueueCommand(System.Func, int> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, int> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func, int> command) => throw null; public void QueueCommand(System.Func, double> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, double> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func, double> command) => throw null; public void QueueCommand(System.Func, bool> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, bool> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func, bool> command) => throw null; public void QueueCommand(System.Func, T> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, T> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func, T> command) => throw null; public void QueueCommand(System.Func, System.Int64> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, System.Int64> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func, System.Int64> command) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.List> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.List> command, System.Action> onSuccessCallback) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.List> command) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.List> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.List> command, System.Action> onSuccessCallback) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.List> command) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.HashSet> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.HashSet> command, System.Action> onSuccessCallback) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.HashSet> command) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.HashSet> command, System.Action> onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.HashSet> command, System.Action> onSuccessCallback) => throw null; public void QueueCommand(System.Func, System.Collections.Generic.HashSet> command) => throw null; public void QueueCommand(System.Func, System.Byte[][]> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, System.Byte[][]> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func, System.Byte[][]> command) => throw null; public void QueueCommand(System.Func, System.Byte[]> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Func, System.Byte[]> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Func, System.Byte[]> command) => throw null; public void QueueCommand(System.Action> command, System.Action onSuccessCallback, System.Action onErrorCallback) => throw null; public void QueueCommand(System.Action> command, System.Action onSuccessCallback) => throw null; public void QueueCommand(System.Action> command) => throw null; internal RedisTypedCommandQueue(ServiceStack.Redis.Generic.RedisTypedClient redisClient) => throw null; } } namespace Pipeline { // Generated from `ServiceStack.Redis.Pipeline.RedisPipelineCommand` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisPipelineCommand { public void Flush() => throw null; public System.Collections.Generic.List ReadAllAsInts() => throw null; public bool ReadAllAsIntsHaveSuccess() => throw null; public RedisPipelineCommand(ServiceStack.Redis.RedisNativeClient client) => throw null; public void WriteCommand(params System.Byte[][] cmdWithBinaryArgs) => throw null; } } namespace Support { // Generated from `ServiceStack.Redis.Support.ConsistentHash<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class ConsistentHash { public void AddTarget(T node, int weight) => throw null; public ConsistentHash(System.Collections.Generic.IEnumerable> nodes, System.Func hashFunction) => throw null; public ConsistentHash(System.Collections.Generic.IEnumerable> nodes) => throw null; public ConsistentHash() => throw null; public T GetTarget(string key) => throw null; public static System.UInt64 Md5Hash(string key) => throw null; public static System.UInt64 ModifiedBinarySearch(System.UInt64[] sortedArray, System.UInt64 val) => throw null; } // Generated from `ServiceStack.Redis.Support.IOrderedDictionary<,>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IOrderedDictionary : System.Collections.Specialized.IOrderedDictionary, System.Collections.IEnumerable, System.Collections.IDictionary, System.Collections.ICollection, System.Collections.Generic.IEnumerable>, System.Collections.Generic.IDictionary, System.Collections.Generic.ICollection> { int Add(TKey key, TValue value); void Insert(int index, TKey key, TValue value); TValue this[int index] { get; set; } } // Generated from `ServiceStack.Redis.Support.ISerializer` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface ISerializer { object Deserialize(System.Byte[] someBytes); System.Byte[] Serialize(object value); } // Generated from `ServiceStack.Redis.Support.ObjectSerializer` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class ObjectSerializer : ServiceStack.Redis.Support.ISerializer { public virtual object Deserialize(System.Byte[] someBytes) => throw null; public ObjectSerializer() => throw null; public virtual System.Byte[] Serialize(object value) => throw null; protected System.Runtime.Serialization.Formatters.Binary.BinaryFormatter bf; } // Generated from `ServiceStack.Redis.Support.OptimizedObjectSerializer` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class OptimizedObjectSerializer : ServiceStack.Redis.Support.ObjectSerializer { public override object Deserialize(System.Byte[] someBytes) => throw null; public OptimizedObjectSerializer() => throw null; public override System.Byte[] Serialize(object value) => throw null; } // Generated from `ServiceStack.Redis.Support.OrderedDictionary<,>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class OrderedDictionary : System.Collections.Specialized.IOrderedDictionary, System.Collections.IEnumerable, System.Collections.IDictionary, System.Collections.ICollection, System.Collections.Generic.IEnumerable>, System.Collections.Generic.IDictionary, System.Collections.Generic.ICollection>, ServiceStack.Redis.Support.IOrderedDictionary { void System.Collections.IDictionary.Add(object key, object value) => throw null; void System.Collections.Generic.IDictionary.Add(TKey key, TValue value) => throw null; void System.Collections.Generic.ICollection>.Add(System.Collections.Generic.KeyValuePair item) => throw null; public int Add(TKey key, TValue value) => throw null; public void Clear() => throw null; bool System.Collections.IDictionary.Contains(object key) => throw null; bool System.Collections.Generic.ICollection>.Contains(System.Collections.Generic.KeyValuePair item) => throw null; public bool ContainsKey(TKey key) => throw null; void System.Collections.ICollection.CopyTo(System.Array array, int index) => throw null; void System.Collections.Generic.ICollection>.CopyTo(System.Collections.Generic.KeyValuePair[] array, int arrayIndex) => throw null; public int Count { get => throw null; } System.Collections.IEnumerator System.Collections.IEnumerable.GetEnumerator() => throw null; System.Collections.IDictionaryEnumerator System.Collections.Specialized.IOrderedDictionary.GetEnumerator() => throw null; System.Collections.IDictionaryEnumerator System.Collections.IDictionary.GetEnumerator() => throw null; System.Collections.Generic.IEnumerator> System.Collections.Generic.IEnumerable>.GetEnumerator() => throw null; public int IndexOfKey(TKey key) => throw null; void System.Collections.Specialized.IOrderedDictionary.Insert(int index, object key, object value) => throw null; public void Insert(int index, TKey key, TValue value) => throw null; bool System.Collections.IDictionary.IsFixedSize { get => throw null; } public bool IsReadOnly { get => throw null; } bool System.Collections.ICollection.IsSynchronized { get => throw null; } public TValue this[int index] { get => throw null; set => throw null; } public TValue this[TKey key] { get => throw null; set => throw null; } object System.Collections.Specialized.IOrderedDictionary.this[int index] { get => throw null; set => throw null; } object System.Collections.IDictionary.this[object key] { get => throw null; set => throw null; } public System.Collections.Generic.ICollection Keys { get => throw null; } System.Collections.ICollection System.Collections.IDictionary.Keys { get => throw null; } public OrderedDictionary(int capacity, System.Collections.Generic.IEqualityComparer comparer) => throw null; public OrderedDictionary(int capacity) => throw null; public OrderedDictionary(System.Collections.Generic.IEqualityComparer comparer) => throw null; public OrderedDictionary() => throw null; void System.Collections.IDictionary.Remove(object key) => throw null; public bool Remove(TKey key) => throw null; bool System.Collections.Generic.ICollection>.Remove(System.Collections.Generic.KeyValuePair item) => throw null; public void RemoveAt(int index) => throw null; object System.Collections.ICollection.SyncRoot { get => throw null; } public bool TryGetValue(TKey key, out TValue value) => throw null; public System.Collections.Generic.ICollection Values { get => throw null; } System.Collections.ICollection System.Collections.IDictionary.Values { get => throw null; } } // Generated from `ServiceStack.Redis.Support.RedisNamespace` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisNamespace { public System.Int64 GetGeneration() => throw null; public string GetGenerationKey() => throw null; public string GetGlobalKeysKey() => throw null; public string GlobalCacheKey(object key) => throw null; public string GlobalKey(object key, int numUniquePrefixes) => throw null; public string GlobalLockKey(object key) => throw null; public const string KeyTag = default; public ServiceStack.Redis.Support.Locking.ILockingStrategy LockingStrategy { get => throw null; set => throw null; } public const string NamespaceTag = default; public const string NamespacesGarbageKey = default; public const int NumTagsForKey = default; public const int NumTagsForLockKey = default; public RedisNamespace(string name) => throw null; public void SetGeneration(System.Int64 generation) => throw null; } // Generated from `ServiceStack.Redis.Support.SerializedObjectWrapper` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public struct SerializedObjectWrapper { public System.ArraySegment Data { get => throw null; set => throw null; } public System.UInt16 Flags { get => throw null; set => throw null; } public SerializedObjectWrapper(System.UInt16 flags, System.ArraySegment data) => throw null; // Stub generator skipped constructor } namespace Diagnostic { // Generated from `ServiceStack.Redis.Support.Diagnostic.InvokeEventArgs` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class InvokeEventArgs : System.EventArgs { public InvokeEventArgs(System.Reflection.MethodInfo methodInfo) => throw null; public System.Reflection.MethodInfo MethodInfo { get => throw null; set => throw null; } } // Generated from `ServiceStack.Redis.Support.Diagnostic.TrackingFrame` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class TrackingFrame : System.IEquatable { public override bool Equals(object obj) => throw null; public bool Equals(ServiceStack.Redis.Support.Diagnostic.TrackingFrame other) => throw null; public override int GetHashCode() => throw null; public System.Guid Id { get => throw null; set => throw null; } public System.DateTime Initialised { get => throw null; set => throw null; } public System.Type ProvidedToInstanceOfType { get => throw null; set => throw null; } public TrackingFrame() => throw null; } } namespace Locking { // Generated from `ServiceStack.Redis.Support.Locking.DisposableDistributedLock` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class DisposableDistributedLock : System.IDisposable { public DisposableDistributedLock(ServiceStack.Redis.IRedisClient client, string globalLockKey, int acquisitionTimeout, int lockTimeout) => throw null; public void Dispose() => throw null; public System.Int64 LockExpire { get => throw null; } public System.Int64 LockState { get => throw null; } } // Generated from `ServiceStack.Redis.Support.Locking.DistributedLock` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class DistributedLock : ServiceStack.Redis.Support.Locking.IDistributedLockAsync, ServiceStack.Redis.Support.Locking.IDistributedLock { public ServiceStack.Redis.Support.Locking.IDistributedLockAsync AsAsync() => throw null; public DistributedLock() => throw null; public const int LOCK_ACQUIRED = default; public const int LOCK_NOT_ACQUIRED = default; public const int LOCK_RECOVERED = default; public virtual System.Int64 Lock(string key, int acquisitionTimeout, int lockTimeout, out System.Int64 lockExpire, ServiceStack.Redis.IRedisClient client) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Support.Locking.IDistributedLockAsync.LockAsync(string key, int acquisitionTimeout, int lockTimeout, ServiceStack.Redis.IRedisClientAsync client, System.Threading.CancellationToken token) => throw null; public virtual bool Unlock(string key, System.Int64 lockExpire, ServiceStack.Redis.IRedisClient client) => throw null; System.Threading.Tasks.ValueTask ServiceStack.Redis.Support.Locking.IDistributedLockAsync.UnlockAsync(string key, System.Int64 lockExpire, ServiceStack.Redis.IRedisClientAsync client, System.Threading.CancellationToken token) => throw null; } // Generated from `ServiceStack.Redis.Support.Locking.IDistributedLock` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IDistributedLock { System.Int64 Lock(string key, int acquisitionTimeout, int lockTimeout, out System.Int64 lockExpire, ServiceStack.Redis.IRedisClient client); bool Unlock(string key, System.Int64 lockExpire, ServiceStack.Redis.IRedisClient client); } // Generated from `ServiceStack.Redis.Support.Locking.IDistributedLockAsync` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IDistributedLockAsync { System.Threading.Tasks.ValueTask LockAsync(string key, int acquisitionTimeout, int lockTimeout, ServiceStack.Redis.IRedisClientAsync client, System.Threading.CancellationToken token = default(System.Threading.CancellationToken)); System.Threading.Tasks.ValueTask UnlockAsync(string key, System.Int64 lockExpire, ServiceStack.Redis.IRedisClientAsync client, System.Threading.CancellationToken token = default(System.Threading.CancellationToken)); } // Generated from `ServiceStack.Redis.Support.Locking.ILockingStrategy` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface ILockingStrategy { System.IDisposable ReadLock(); System.IDisposable WriteLock(); } // Generated from `ServiceStack.Redis.Support.Locking.LockState` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public struct LockState { public void Deconstruct(out System.Int64 result, out System.Int64 expiration) => throw null; public override bool Equals(object obj) => throw null; public System.Int64 Expiration { get => throw null; } public override int GetHashCode() => throw null; public LockState(System.Int64 result, System.Int64 expiration) => throw null; // Stub generator skipped constructor public System.Int64 Result { get => throw null; } public override string ToString() => throw null; } // Generated from `ServiceStack.Redis.Support.Locking.NoLockingStrategy` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class NoLockingStrategy : ServiceStack.Redis.Support.Locking.ILockingStrategy { public NoLockingStrategy() => throw null; public System.IDisposable ReadLock() => throw null; public System.IDisposable WriteLock() => throw null; } // Generated from `ServiceStack.Redis.Support.Locking.ReadLock` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class ReadLock : System.IDisposable { public void Dispose() => throw null; public ReadLock(System.Threading.ReaderWriterLockSlim lockObject) => throw null; } // Generated from `ServiceStack.Redis.Support.Locking.ReaderWriterLockingStrategy` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class ReaderWriterLockingStrategy : ServiceStack.Redis.Support.Locking.ILockingStrategy { public System.IDisposable ReadLock() => throw null; public ReaderWriterLockingStrategy() => throw null; public System.IDisposable WriteLock() => throw null; } // Generated from `ServiceStack.Redis.Support.Locking.WriteLock` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class WriteLock : System.IDisposable { public void Dispose() => throw null; public WriteLock(System.Threading.ReaderWriterLockSlim lockObject) => throw null; } } namespace Queue { // Generated from `ServiceStack.Redis.Support.Queue.IChronologicalWorkQueue<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface IChronologicalWorkQueue : System.IDisposable where T : class { System.Collections.Generic.IList> Dequeue(double minTime, double maxTime, int maxBatchSize); void Enqueue(string workItemId, T workItem, double time); } // Generated from `ServiceStack.Redis.Support.Queue.ISequentialData<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface ISequentialData { string DequeueId { get; } System.Collections.Generic.IList DequeueItems { get; } void DoneProcessedWorkItem(); void PopAndUnlock(); void UpdateNextUnprocessed(T newWorkItem); } // Generated from `ServiceStack.Redis.Support.Queue.ISequentialWorkQueue<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface ISequentialWorkQueue : System.IDisposable where T : class { ServiceStack.Redis.Support.Queue.ISequentialData Dequeue(int maxBatchSize); void Enqueue(string workItemId, T workItem); bool HarvestZombies(); bool PrepareNextWorkItem(); void Update(string workItemId, int index, T newWorkItem); } // Generated from `ServiceStack.Redis.Support.Queue.ISimpleWorkQueue<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public interface ISimpleWorkQueue : System.IDisposable where T : class { System.Collections.Generic.IList Dequeue(int maxBatchSize); void Enqueue(T workItem); } namespace Implementation { // Generated from `ServiceStack.Redis.Support.Queue.Implementation.RedisChronologicalWorkQueue<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisChronologicalWorkQueue : ServiceStack.Redis.Support.Queue.Implementation.RedisWorkQueue, System.IDisposable, ServiceStack.Redis.Support.Queue.IChronologicalWorkQueue where T : class { public System.Collections.Generic.IList> Dequeue(double minTime, double maxTime, int maxBatchSize) => throw null; public void Enqueue(string workItemId, T workItem, double time) => throw null; public RedisChronologicalWorkQueue(int maxReadPoolSize, int maxWritePoolSize, string host, int port, string queueName) : base(default(int), default(int), default(string), default(int)) => throw null; public RedisChronologicalWorkQueue(int maxReadPoolSize, int maxWritePoolSize, string host, int port) : base(default(int), default(int), default(string), default(int)) => throw null; } // Generated from `ServiceStack.Redis.Support.Queue.Implementation.RedisSequentialWorkQueue<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisSequentialWorkQueue : ServiceStack.Redis.Support.Queue.Implementation.RedisWorkQueue, System.IDisposable, ServiceStack.Redis.Support.Queue.ISequentialWorkQueue where T : class { protected const double CONVENIENTLY_SIZED_FLOAT = default; public ServiceStack.Redis.Support.Queue.ISequentialData Dequeue(int maxBatchSize) => throw null; // Generated from `ServiceStack.Redis.Support.Queue.Implementation.RedisSequentialWorkQueue<>+DequeueManager` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class DequeueManager { public DequeueManager(ServiceStack.Redis.PooledRedisClientManager clientManager, ServiceStack.Redis.Support.Queue.Implementation.RedisSequentialWorkQueue workQueue, string workItemId, string dequeueLockKey, int numberOfDequeuedItems, int dequeueLockTimeout) => throw null; public void DoneProcessedWorkItem() => throw null; public System.Int64 Lock(int acquisitionTimeout, ServiceStack.Redis.IRedisClient client) => throw null; public bool PopAndUnlock(int numProcessed, ServiceStack.Redis.IRedisClient client) => throw null; public bool PopAndUnlock(int numProcessed) => throw null; public bool Unlock(ServiceStack.Redis.IRedisClient client) => throw null; public void UpdateNextUnprocessed(T newWorkItem) => throw null; protected ServiceStack.Redis.PooledRedisClientManager clientManager; protected int numberOfDequeuedItems; protected int numberOfProcessedItems; protected string workItemId; protected ServiceStack.Redis.Support.Queue.Implementation.RedisSequentialWorkQueue workQueue; } public void Enqueue(string workItemId, T workItem) => throw null; public bool HarvestZombies() => throw null; public bool PrepareNextWorkItem() => throw null; public RedisSequentialWorkQueue(int maxReadPoolSize, int maxWritePoolSize, string host, int port, string queueName, int dequeueLockTimeout) : base(default(int), default(int), default(string), default(int)) => throw null; public RedisSequentialWorkQueue(int maxReadPoolSize, int maxWritePoolSize, string host, int port, int dequeueLockTimeout) : base(default(int), default(int), default(string), default(int)) => throw null; public bool TryForceReleaseLock(ServiceStack.Redis.Support.Queue.Implementation.SerializingRedisClient client, string workItemId) => throw null; public void Update(string workItemId, int index, T newWorkItem) => throw null; } // Generated from `ServiceStack.Redis.Support.Queue.Implementation.RedisSimpleWorkQueue<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisSimpleWorkQueue : ServiceStack.Redis.Support.Queue.Implementation.RedisWorkQueue, System.IDisposable, ServiceStack.Redis.Support.Queue.ISimpleWorkQueue where T : class { public System.Collections.Generic.IList Dequeue(int maxBatchSize) => throw null; public void Enqueue(T msg) => throw null; public RedisSimpleWorkQueue(int maxReadPoolSize, int maxWritePoolSize, string host, int port, string queueName) : base(default(int), default(int), default(string), default(int)) => throw null; public RedisSimpleWorkQueue(int maxReadPoolSize, int maxWritePoolSize, string host, int port) : base(default(int), default(int), default(string), default(int)) => throw null; } // Generated from `ServiceStack.Redis.Support.Queue.Implementation.RedisWorkQueue<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class RedisWorkQueue { public void Dispose() => throw null; public RedisWorkQueue(int maxReadPoolSize, int maxWritePoolSize, string host, int port, string queueName) => throw null; public RedisWorkQueue(int maxReadPoolSize, int maxWritePoolSize, string host, int port) => throw null; protected ServiceStack.Redis.PooledRedisClientManager clientManager; protected string pendingWorkItemIdQueue; protected ServiceStack.Redis.Support.RedisNamespace queueNamespace; protected string workQueue; } // Generated from `ServiceStack.Redis.Support.Queue.Implementation.SequentialData<>` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class SequentialData : ServiceStack.Redis.Support.Queue.ISequentialData where T : class { public string DequeueId { get => throw null; } public System.Collections.Generic.IList DequeueItems { get => throw null; } public void DoneProcessedWorkItem() => throw null; public void PopAndUnlock() => throw null; public SequentialData(string dequeueId, System.Collections.Generic.IList _dequeueItems, ServiceStack.Redis.Support.Queue.Implementation.RedisSequentialWorkQueue.DequeueManager _dequeueManager) => throw null; public void UpdateNextUnprocessed(T newWorkItem) => throw null; } // Generated from `ServiceStack.Redis.Support.Queue.Implementation.SerializingRedisClient` in `ServiceStack.Redis, Version=5.0.0.0, Culture=neutral, PublicKeyToken=null` public class SerializingRedisClient : ServiceStack.Redis.RedisClient { public object Deserialize(System.Byte[] someBytes) => throw null; public System.Collections.IList Deserialize(System.Byte[][] byteArray) => throw null; public System.Collections.Generic.List Serialize(object[] values) => throw null; public System.Byte[] Serialize(object value) => throw null; public ServiceStack.Redis.Support.ISerializer Serializer { set => throw null; } public SerializingRedisClient(string host, int port) => throw null; public SerializingRedisClient(string host) => throw null; public SerializingRedisClient(ServiceStack.Redis.RedisEndpoint config) => throw null; } } } } } }