Show / Hide Table of Contents

Class RaftCluster.NodeConfiguration

Represents transport-agnostic configuration of cluster member.

Inheritance
Object
RaftCluster.NodeConfiguration
RaftCluster.TcpConfiguration
RaftCluster.UdpConfiguration
Implements
IClusterMemberConfiguration
Inherited Members
Object.Equals(Object)
Object.Equals(Object, Object)
Object.GetHashCode()
Object.GetType()
Object.MemberwiseClone()
Object.ReferenceEquals(Object, Object)
Object.ToString()
Namespace: DotNext.Net.Cluster.Consensus.Raft
Assembly: DotNext.Net.Cluster.dll
Syntax
public abstract class NodeConfiguration : IClusterMemberConfiguration

Properties

| Improve this Doc View Source

HeartbeatThreshold

Gets or sets threshold of the heartbeat timeout.

Declaration
public double HeartbeatThreshold { get; set; }
Property Value
Type Description
Double
Remarks

The threshold should be in range (0, 1). The heartbeat timeout is computed as node election timeout X threshold. The default is 0.5.

Exceptions
Type Condition
ArgumentOutOfRangeException

Attempts to set invalid value.

| Improve this Doc View Source

HostEndPoint

Gets the address used for hosting of local member.

Declaration
public IPEndPoint HostEndPoint { get; }
Property Value
Type Description
IPEndPoint
| Improve this Doc View Source

LoggerFactory

Gets or sets logger factory using for internal logging.

Declaration
[CLSCompliant(false)]
public ILoggerFactory LoggerFactory { get; set; }
Property Value
Type Description
ILoggerFactory
| Improve this Doc View Source

LowerElectionTimeout

Gets lower possible value of leader election timeout, in milliseconds.

Declaration
public int LowerElectionTimeout { get; set; }
Property Value
Type Description
Int32
| Improve this Doc View Source

Members

Gets collection of cluster members.

Declaration
public ICollection<IPEndPoint> Members { get; }
Property Value
Type Description
ICollection<IPEndPoint>

The collection of cluster members.

| Improve this Doc View Source

MemoryAllocator

Gets or sets memory allocator to be used for network I/O.

Declaration
public MemoryAllocator<byte> MemoryAllocator { get; set; }
Property Value
Type Description
MemoryAllocator<Byte>
| Improve this Doc View Source

Metadata

Gets metadata associated with local cluster member.

Declaration
public IDictionary<string, string> Metadata { get; }
Property Value
Type Description
IDictionary<String, String>
| Improve this Doc View Source

Metrics

Gets or sets metrics collector.

Declaration
public MetricsCollector Metrics { get; set; }
Property Value
Type Description
MetricsCollector
| Improve this Doc View Source

Partitioning

Indicates that each part of cluster in partitioned network allow to elect its own leader.

Declaration
public bool Partitioning { get; set; }
Property Value
Type Description
Boolean
Remarks

false value allows to build CA distributed cluster while true value allows to build CP/AP distributed cluster.

| Improve this Doc View Source

PipeConfig

Gets or sets configuration of the Pipe used for internal pipelined I/O.

Declaration
public PipeOptions PipeConfig { get; set; }
Property Value
Type Description
PipeOptions
| Improve this Doc View Source

PublicEndPoint

Gets the address of the local member visible to other members.

Declaration
public IPEndPoint PublicEndPoint { get; set; }
Property Value
Type Description
IPEndPoint
Remarks

This property is useful when local member hosted in a container (Windows, LXC or Docker) because HostEndPoint may return Any or IPv6Any.

| Improve this Doc View Source

RequestTimeout

Gets or sets request processing timeout.

Declaration
public TimeSpan RequestTimeout { get; set; }
Property Value
Type Description
TimeSpan
| Improve this Doc View Source

ServerBacklog

Gets or sets the maximum number of parallel requests that can be handled simultaneously.

Declaration
public int ServerBacklog { get; set; }
Property Value
Type Description
Int32
Remarks

By default, the value based on the number of cluster members.

Exceptions
Type Condition
ArgumentOutOfRangeException

Supplied value is equal to or less than zero.

| Improve this Doc View Source

TimeToLive

Gets or sets a value that specifies the Time To Live (TTL) value of Internet Protocol (IP) packets.

Declaration
public byte TimeToLive { get; set; }
Property Value
Type Description
Byte
| Improve this Doc View Source

UpperElectionTimeout

Gets upper possible value of leader election timeout, in milliseconds.

Declaration
public int UpperElectionTimeout { get; set; }
Property Value
Type Description
Int32

Explicit Interface Implementations

| Improve this Doc View Source

IClusterMemberConfiguration.ElectionTimeout

Declaration
ElectionTimeout IClusterMemberConfiguration.ElectionTimeout { get; }
Returns
Type Description
ElectionTimeout

Implements

IClusterMemberConfiguration

Extension Methods

AsyncLockAcquisition.AcquireLockAsync<T>(T, TimeSpan)
AsyncLockAcquisition.AcquireLockAsync<T>(T, CancellationToken)
AsyncLockAcquisition.AcquireReadLockAsync<T>(T, TimeSpan)
AsyncLockAcquisition.AcquireReadLockAsync<T>(T, CancellationToken)
AsyncLockAcquisition.AcquireWriteLockAsync<T>(T, TimeSpan)
AsyncLockAcquisition.AcquireWriteLockAsync<T>(T, CancellationToken)
AsyncLockAcquisition.AcquireUpgradeableReadLockAsync<T>(T, TimeSpan)
AsyncLockAcquisition.AcquireUpgradeableReadLockAsync<T>(T, CancellationToken)
ObjectExtensions.GetUserData<T>(T)
ObjectExtensions.IsOneOf<T>(T, IEnumerable<T>)
ObjectExtensions.IsOneOf<T>(T, T[])
ObjectExtensions.Decompose<T, TResult1, TResult2>(T, Func<T, TResult1>, Func<T, TResult2>, out TResult1, out TResult2)
ObjectExtensions.Decompose<T, TResult1, TResult2>(T, ValueFunc<T, TResult1>, ValueFunc<T, TResult2>, out TResult1, out TResult2)
ObjectExtensions.Decompose<T, TResult1, TResult2>(T, Func<T, TResult1>, Func<T, TResult2>)
ObjectExtensions.Decompose<T, TResult1, TResult2>(T, ValueFunc<T, TResult1>, ValueFunc<T, TResult2>)
ObjectExtensions.As<T>(T)
LockAcquisition.AcquireReadLock<T>(T)
LockAcquisition.AcquireReadLock<T>(T, TimeSpan)
LockAcquisition.AcquireWriteLock<T>(T)
LockAcquisition.AcquireWriteLock<T>(T, TimeSpan)
LockAcquisition.AcquireUpgradeableReadLock<T>(T)
LockAcquisition.AcquireUpgradeableReadLock<T>(T, TimeSpan)
ExpressionBuilder.Const<T>(T)
  • Improve this Doc
  • View Source
In This Article
Back to top Generated by DocFX