consul - ActiveState ActiveGo 1.8
...

Package consul

import "github.com/hashicorp/consul/consul"
Overview
Index
Subdirectories

Overview ▾

The snapshot endpoint is a special non-RPC endpoint that supports streaming for taking and restoring snapshots for disaster recovery. This gets wired directly into Consul's stream handler, and a new TCP connection is made for each request.

This also includes a SnapshotRPC() function, which acts as a lightweight client that knows the details of the stream protocol.

Index ▾

Constants
Variables
func CanServersUnderstandProtocol(members []serf.Member, version uint8) (bool, error)
func FilterDirEnt(acl acl.ACL, ent structs.DirEntries) structs.DirEntries
func FilterEntries(f Filter) int
func FilterKeys(acl acl.ACL, keys []string) []string
func FilterTxnResults(acl acl.ACL, results structs.TxnResults) structs.TxnResults
func GetPrivateIP() (net.IP, error)
func GetPublicIPv6() (net.IP, error)
func NewFSM(gc *state.TombstoneGC, logOutput io.Writer) (*consulFSM, error)
func ServerMinRaftProtocol(members []serf.Member) (int, error)
func ServersMeetMinimumVersion(members []serf.Member, minVersion *version.Version) bool
func SnapshotRPC(pool *ConnPool, dc string, addr net.Addr, useTLS bool, args *structs.SnapshotRequest, in io.Reader, reply *structs.SnapshotResponse) (io.ReadCloser, error)
type ACL
    func (a *ACL) Apply(args *structs.ACLRequest, reply *string) error
    func (a *ACL) Get(args *structs.ACLSpecificRequest, reply *structs.IndexedACLs) error
    func (a *ACL) GetPolicy(args *structs.ACLPolicyRequest, reply *structs.ACLPolicy) error
    func (a *ACL) List(args *structs.DCSpecificRequest, reply *structs.IndexedACLs) error
    func (a *ACL) ReplicationStatus(args *structs.DCSpecificRequest, reply *structs.ACLReplicationStatus) error
type AutopilotPolicy
type BasicAutopilot
    func (b *BasicAutopilot) PromoteNonVoters(autopilotConfig *structs.AutopilotConfig) error
type Catalog
    func (c *Catalog) Deregister(args *structs.DeregisterRequest, reply *struct{}) error
    func (c *Catalog) ListDatacenters(args *struct{}, reply *[]string) error
    func (c *Catalog) ListNodes(args *structs.DCSpecificRequest, reply *structs.IndexedNodes) error
    func (c *Catalog) ListServices(args *structs.DCSpecificRequest, reply *structs.IndexedServices) error
    func (c *Catalog) NodeServices(args *structs.NodeSpecificRequest, reply *structs.IndexedNodeServices) error
    func (c *Catalog) Register(args *structs.RegisterRequest, reply *struct{}) error
    func (c *Catalog) ServiceNodes(args *structs.ServiceSpecificRequest, reply *structs.IndexedServiceNodes) error
type Client
    func NewClient(config *Config) (*Client, error)
    func NewClientLogger(config *Config, logger *log.Logger) (*Client, error)
    func (c *Client) Encrypted() bool
    func (c *Client) GetLANCoordinate() (*coordinate.Coordinate, error)
    func (c *Client) JoinLAN(addrs []string) (int, error)
    func (c *Client) KeyManagerLAN() *serf.KeyManager
    func (c *Client) LANMembers() []serf.Member
    func (c *Client) Leave() error
    func (c *Client) LocalMember() serf.Member
    func (c *Client) RPC(method string, args interface{}, reply interface{}) error
    func (c *Client) RemoveFailedNode(node string) error
    func (c *Client) Shutdown() error
    func (c *Client) SnapshotRPC(args *structs.SnapshotRequest, in io.Reader, out io.Writer, replyFn SnapshotReplyFn) error
    func (c *Client) Stats() map[string]map[string]string
type Config
    func DefaultConfig() *Config
    func (c *Config) CheckACL() error
    func (c *Config) CheckProtocolVersion() error
    func (c *Config) GetTokenForAgent() string
    func (c *Config) ScaleRaft(raftMultRaw uint)
type Conn
    func (c *Conn) Close() error
type ConnPool
    func NewPool(src *net.TCPAddr, logOutput io.Writer, maxTime time.Duration, maxStreams int, tlsWrap tlsutil.DCWrapper, forceTLS bool) *ConnPool
    func (p *ConnPool) DialTimeout(dc string, addr net.Addr, timeout time.Duration, useTLS bool) (net.Conn, HalfCloser, error)
    func (p *ConnPool) PingConsulServer(s *agent.Server) (bool, error)
    func (p *ConnPool) RPC(dc string, addr net.Addr, version int, method string, useTLS bool, args interface{}, reply interface{}) error
    func (p *ConnPool) Shutdown() error
type Coordinate
    func NewCoordinate(srv *Server) *Coordinate
    func (c *Coordinate) ListDatacenters(args *struct{}, reply *[]structs.DatacenterMap) error
    func (c *Coordinate) ListNodes(args *structs.DCSpecificRequest, reply *structs.IndexedCoordinates) error
    func (c *Coordinate) Update(args *structs.CoordinateUpdateRequest, reply *struct{}) (err error)
type Filter
type HalfCloser
type Health
    func (h *Health) ChecksInState(args *structs.ChecksInStateRequest, reply *structs.IndexedHealthChecks) error
    func (h *Health) NodeChecks(args *structs.NodeSpecificRequest, reply *structs.IndexedHealthChecks) error
    func (h *Health) ServiceChecks(args *structs.ServiceSpecificRequest, reply *structs.IndexedHealthChecks) error
    func (h *Health) ServiceNodes(args *structs.ServiceSpecificRequest, reply *structs.IndexedCheckServiceNodes) error
type Interface
type Internal
    func (m *Internal) EventFire(args *structs.EventFireRequest, reply *structs.EventFireResponse) error
    func (m *Internal) KeyringOperation(args *structs.KeyringRequest, reply *structs.KeyringResponses) error
    func (m *Internal) NodeDump(args *structs.DCSpecificRequest, reply *structs.IndexedNodeDump) error
    func (m *Internal) NodeInfo(args *structs.NodeSpecificRequest, reply *structs.IndexedNodeDump) error
type KVS
    func (k *KVS) Apply(args *structs.KVSRequest, reply *bool) error
    func (k *KVS) Get(args *structs.KeyRequest, reply *structs.IndexedDirEntries) error
    func (k *KVS) List(args *structs.KeyRequest, reply *structs.IndexedDirEntries) error
    func (k *KVS) ListKeys(args *structs.KeyListRequest, reply *structs.IndexedKeyList) error
type Operator
    func (op *Operator) AutopilotGetConfiguration(args *structs.DCSpecificRequest, reply *structs.AutopilotConfig) error
    func (op *Operator) AutopilotSetConfiguration(args *structs.AutopilotSetConfigRequest, reply *bool) error
    func (op *Operator) RaftGetConfiguration(args *structs.DCSpecificRequest, reply *structs.RaftConfigurationResponse) error
    func (op *Operator) RaftRemovePeerByAddress(args *structs.RaftRemovePeerRequest, reply *struct{}) error
    func (op *Operator) RaftRemovePeerByID(args *structs.RaftRemovePeerRequest, reply *struct{}) error
    func (op *Operator) ServerHealth(args *structs.DCSpecificRequest, reply *structs.OperatorHealthReply) error
type PreparedQuery
    func (p *PreparedQuery) Apply(args *structs.PreparedQueryRequest, reply *string) (err error)
    func (p *PreparedQuery) Execute(args *structs.PreparedQueryExecuteRequest, reply *structs.PreparedQueryExecuteResponse) error
    func (p *PreparedQuery) ExecuteRemote(args *structs.PreparedQueryExecuteRemoteRequest, reply *structs.PreparedQueryExecuteResponse) error
    func (p *PreparedQuery) Explain(args *structs.PreparedQueryExecuteRequest, reply *structs.PreparedQueryExplainResponse) error
    func (p *PreparedQuery) Get(args *structs.PreparedQuerySpecificRequest, reply *structs.IndexedPreparedQueries) error
    func (p *PreparedQuery) List(args *structs.DCSpecificRequest, reply *structs.IndexedPreparedQueries) error
type RPCType
type RaftLayer
    func NewRaftLayer(src, addr net.Addr, tlsWrap tlsutil.Wrapper, tlsFunc func(raft.ServerAddress) bool) *RaftLayer
    func (l *RaftLayer) Accept() (net.Conn, error)
    func (l *RaftLayer) Addr() net.Addr
    func (l *RaftLayer) Close() error
    func (l *RaftLayer) Dial(address raft.ServerAddress, timeout time.Duration) (net.Conn, error)
    func (l *RaftLayer) Handoff(c net.Conn) error
type Server
    func NewServer(config *Config) (*Server, error)
    func NewServerLogger(config *Config, logger *log.Logger) (*Server, error)
    func (s *Server) Encrypted() bool
    func (s *Server) Flood(portFn servers.FloodPortFn, global *serf.Serf)
    func (s *Server) FloodNotify()
    func (s *Server) GetLANCoordinate() (*coordinate.Coordinate, error)
    func (s *Server) GetWANCoordinate() (*coordinate.Coordinate, error)
    func (s *Server) InjectEndpoint(endpoint interface{}) error
    func (s *Server) IsACLReplicationEnabled() bool
    func (s *Server) IsLeader() bool
    func (s *Server) JoinLAN(addrs []string) (int, error)
    func (s *Server) JoinWAN(addrs []string) (int, error)
    func (s *Server) KeyManagerLAN() *serf.KeyManager
    func (s *Server) KeyManagerWAN() *serf.KeyManager
    func (s *Server) LANMembers() []serf.Member
    func (s *Server) Leave() error
    func (s *Server) LocalMember() serf.Member
    func (s *Server) RPC(method string, args interface{}, reply interface{}) error
    func (s *Server) RemoveFailedNode(node string) error
    func (s *Server) Shutdown() error
    func (s *Server) SnapshotRPC(args *structs.SnapshotRequest, in io.Reader, out io.Writer, replyFn SnapshotReplyFn) error
    func (s *Server) Stats() map[string]map[string]string
    func (s *Server) WANMembers() []serf.Member
type Session
    func (s *Session) Apply(args *structs.SessionRequest, reply *string) error
    func (s *Session) Get(args *structs.SessionSpecificRequest, reply *structs.IndexedSessions) error
    func (s *Session) List(args *structs.DCSpecificRequest, reply *structs.IndexedSessions) error
    func (s *Session) NodeSessions(args *structs.NodeSpecificRequest, reply *structs.IndexedSessions) error
    func (s *Session) Renew(args *structs.SessionSpecificRequest, reply *structs.IndexedSessions) error
type SnapshotReplyFn
type StatsFetcher
    func NewStatsFetcher(logger *log.Logger, pool *ConnPool, datacenter string) *StatsFetcher
    func (f *StatsFetcher) Fetch(ctx context.Context, servers []*agent.Server) map[string]*structs.ServerStats
type Status
    func (s *Status) Leader(args struct{}, reply *string) error
    func (s *Status) Peers(args struct{}, reply *[]string) error
    func (s *Status) Ping(args struct{}, reply *struct{}) error
    func (s *Status) RaftStats(args struct{}, reply *structs.ServerStats) error
type StreamClient
    func (sc *StreamClient) Close()
type Txn
    func (t *Txn) Apply(args *structs.TxnRequest, reply *structs.TxnResponse) error
    func (t *Txn) Read(args *structs.TxnReadRequest, reply *structs.TxnReadResponse) error

Package files

acl.go acl_endpoint.go acl_replication.go autopilot.go catalog_endpoint.go client.go config.go coordinate_endpoint.go filter.go flood.go fsm.go health_endpoint.go internal_endpoint.go kvs_endpoint.go leader.go merge.go operator_autopilot_endpoint.go operator_endpoint.go operator_raft_endpoint.go pool.go prepared_query_endpoint.go raft_rpc.go rpc.go rtt.go serf.go server.go session_endpoint.go session_ttl.go snapshot_endpoint.go stats_fetcher.go status_endpoint.go txn_endpoint.go util.go

Constants

const (
    DefaultDC          = "dc1"
    DefaultRPCPort     = 8300
    DefaultLANSerfPort = 8301
    DefaultWANSerfPort = 8302

    // DefaultRaftMultiplier is used as a baseline Raft configuration that
    // will be reliable on a very basic server. See docs/guides/performance.html
    // for information on how this value was obtained.
    DefaultRaftMultiplier uint = 5

    // MaxRaftMultiplier is a fairly arbitrary upper bound that limits the
    // amount of performance detuning that's possible.
    MaxRaftMultiplier uint = 10
)
const (
    SerfCheckID           types.CheckID = "serfHealth"
    SerfCheckName                       = "Serf Health Status"
    SerfCheckAliveOutput                = "Agent alive and reachable"
    SerfCheckFailedOutput               = "Agent not live or unreachable"
    ConsulServiceID                     = "consul"
    ConsulServiceName                   = "consul"
)

These are the protocol versions that Consul can _understand_. These are Consul-level protocol versions, that are used to configure the Serf protocol versions.

const (
    ProtocolVersionMin uint8 = 2

    // Version 3 added support for network coordinates but we kept the
    // default protocol version at 2 to ease the transition to this new
    // feature. A Consul agent speaking version 2 of the protocol will
    // attempt to send its coordinates to a server who understands version
    // 3 or greater.
    ProtocolVersion2Compatible = 2

    ProtocolVersionMax = 3
)
const (
    // StatusReap is used to update the status of a node if we
    // are handling a EventMemberReap
    StatusReap = serf.MemberStatus(-1)
)

Variables

var (
    DefaultRPCAddr = &net.TCPAddr{IP: net.ParseIP("0.0.0.0"), Port: DefaultRPCPort}
)
var (
    // ErrQueryNotFound is returned if the query lookup failed.
    ErrQueryNotFound = errors.New("Query not found")
)

func CanServersUnderstandProtocol

func CanServersUnderstandProtocol(members []serf.Member, version uint8) (bool, error)

CanServersUnderstandProtocol checks to see if all the servers in the given list understand the given protocol version. If there are no servers in the list then this will return false.

func FilterDirEnt

func FilterDirEnt(acl acl.ACL, ent structs.DirEntries) structs.DirEntries

FilterDirEnt is used to filter a list of directory entries by applying an ACL policy

func FilterEntries

func FilterEntries(f Filter) int

FilterEntries is used to do an inplace filter of a slice. This has cost proportional to the list length.

func FilterKeys

func FilterKeys(acl acl.ACL, keys []string) []string

FilterKeys is used to filter a list of keys by applying an ACL policy

func FilterTxnResults

func FilterTxnResults(acl acl.ACL, results structs.TxnResults) structs.TxnResults

FilterTxnResults is used to filter a list of transaction results by applying an ACL policy.

func GetPrivateIP

func GetPrivateIP() (net.IP, error)

GetPrivateIP is used to return the first private IP address associated with an interface on the machine

func GetPublicIPv6

func GetPublicIPv6() (net.IP, error)

GetPublicIPv6 is used to return the first public IP address associated with an interface on the machine

func NewFSM

func NewFSM(gc *state.TombstoneGC, logOutput io.Writer) (*consulFSM, error)

NewFSM is used to construct a new FSM with a blank state

func ServerMinRaftProtocol

func ServerMinRaftProtocol(members []serf.Member) (int, error)

ServerMinRaftProtocol returns the lowest supported Raft protocol among alive servers

func ServersMeetMinimumVersion

func ServersMeetMinimumVersion(members []serf.Member, minVersion *version.Version) bool

ServersMeetMinimumVersion returns whether the given alive servers are at least on the given Consul version

func SnapshotRPC

func SnapshotRPC(pool *ConnPool, dc string, addr net.Addr, useTLS bool,
    args *structs.SnapshotRequest, in io.Reader, reply *structs.SnapshotResponse) (io.ReadCloser, error)

SnapshotRPC is a streaming client function for performing a snapshot RPC request to a remote server. It will create a fresh connection for each request, send the request header, and then stream in any data from the reader (for a restore). It will then parse the received response header, and if there's no error will return an io.ReadCloser (that you must close) with the streaming output (for a snapshot). If the reply contains an error, this will always return an error as well, so you don't need to check the error inside the filled-in reply.

type ACL

ACL endpoint is used to manipulate ACLs

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

func (*ACL) Apply

func (a *ACL) Apply(args *structs.ACLRequest, reply *string) error

Apply is used to apply a modifying request to the data store. This should only be used for operations that modify the data

func (*ACL) Get

func (a *ACL) Get(args *structs.ACLSpecificRequest,
    reply *structs.IndexedACLs) error

Get is used to retrieve a single ACL

func (*ACL) GetPolicy

func (a *ACL) GetPolicy(args *structs.ACLPolicyRequest, reply *structs.ACLPolicy) error

GetPolicy is used to retrieve a compiled policy object with a TTL. Does not support a blocking query.

func (*ACL) List

func (a *ACL) List(args *structs.DCSpecificRequest,
    reply *structs.IndexedACLs) error

List is used to list all the ACLs

func (*ACL) ReplicationStatus

func (a *ACL) ReplicationStatus(args *structs.DCSpecificRequest,
    reply *structs.ACLReplicationStatus) error

ReplicationStatus is used to retrieve the current ACL replication status.

type AutopilotPolicy

AutopilotPolicy is the interface for the Autopilot mechanism

type AutopilotPolicy interface {
    // PromoteNonVoters defines the handling of non-voting servers
    PromoteNonVoters(*structs.AutopilotConfig) error
}

type BasicAutopilot

BasicAutopilot defines a policy for promoting non-voting servers in a way that maintains an odd-numbered voter count.

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

func (*BasicAutopilot) PromoteNonVoters

func (b *BasicAutopilot) PromoteNonVoters(autopilotConfig *structs.AutopilotConfig) error

PromoteNonVoters promotes eligible non-voting servers to voters.

type Catalog

Catalog endpoint is used to manipulate the service catalog

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

func (*Catalog) Deregister

func (c *Catalog) Deregister(args *structs.DeregisterRequest, reply *struct{}) error

Deregister is used to remove a service registration for a given node.

func (*Catalog) ListDatacenters

func (c *Catalog) ListDatacenters(args *struct{}, reply *[]string) error

ListDatacenters is used to query for the list of known datacenters

func (*Catalog) ListNodes

func (c *Catalog) ListNodes(args *structs.DCSpecificRequest, reply *structs.IndexedNodes) error

ListNodes is used to query the nodes in a DC

func (*Catalog) ListServices

func (c *Catalog) ListServices(args *structs.DCSpecificRequest, reply *structs.IndexedServices) error

ListServices is used to query the services in a DC

func (*Catalog) NodeServices

func (c *Catalog) NodeServices(args *structs.NodeSpecificRequest, reply *structs.IndexedNodeServices) error

NodeServices returns all the services registered as part of a node

func (*Catalog) Register

func (c *Catalog) Register(args *structs.RegisterRequest, reply *struct{}) error

Register is used register that a node is providing a given service.

func (*Catalog) ServiceNodes

func (c *Catalog) ServiceNodes(args *structs.ServiceSpecificRequest, reply *structs.IndexedServiceNodes) error

ServiceNodes returns all the nodes registered as part of a service

type Client

Client is Consul client which uses RPC to communicate with the services for service discovery, health checking, and DC forwarding.

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

func NewClient

func NewClient(config *Config) (*Client, error)

NewClient is used to construct a new Consul client from the configuration, potentially returning an error

func NewClientLogger

func NewClientLogger(config *Config, logger *log.Logger) (*Client, error)

func (*Client) Encrypted

func (c *Client) Encrypted() bool

Encrypted determines if gossip is encrypted

func (*Client) GetLANCoordinate

func (c *Client) GetLANCoordinate() (*coordinate.Coordinate, error)

GetLANCoordinate returns the network coordinate of the current node, as maintained by Serf.

func (*Client) JoinLAN

func (c *Client) JoinLAN(addrs []string) (int, error)

JoinLAN is used to have Consul client join the inner-DC pool The target address should be another node inside the DC listening on the Serf LAN address

func (*Client) KeyManagerLAN

func (c *Client) KeyManagerLAN() *serf.KeyManager

KeyManagerLAN returns the LAN Serf keyring manager

func (*Client) LANMembers

func (c *Client) LANMembers() []serf.Member

LANMembers is used to return the members of the LAN cluster

func (*Client) Leave

func (c *Client) Leave() error

Leave is used to prepare for a graceful shutdown

func (*Client) LocalMember

func (c *Client) LocalMember() serf.Member

LocalMember is used to return the local node

func (*Client) RPC

func (c *Client) RPC(method string, args interface{}, reply interface{}) error

RPC is used to forward an RPC call to a consul server, or fail if no servers

func (*Client) RemoveFailedNode

func (c *Client) RemoveFailedNode(node string) error

RemoveFailedNode is used to remove a failed node from the cluster

func (*Client) Shutdown

func (c *Client) Shutdown() error

Shutdown is used to shutdown the client

func (*Client) SnapshotRPC

func (c *Client) SnapshotRPC(args *structs.SnapshotRequest, in io.Reader, out io.Writer,
    replyFn SnapshotReplyFn) error

SnapshotRPC sends the snapshot request to one of the servers, reading from the streaming input and writing to the streaming output depending on the operation.

func (*Client) Stats

func (c *Client) Stats() map[string]map[string]string

Stats is used to return statistics for debugging and insight for various sub-systems

type Config

Config is used to configure the server

type Config struct {
    // Bootstrap mode is used to bring up the first Consul server.
    // It is required so that it can elect a leader without any
    // other nodes being present
    Bootstrap bool

    // BootstrapExpect mode is used to automatically bring up a collection of
    // Consul servers. This can be used to automatically bring up a collection
    // of nodes.
    BootstrapExpect int

    // Datacenter is the datacenter this Consul server represents
    Datacenter string

    // DataDir is the directory to store our state in
    DataDir string

    // DevMode is used to enable a development server mode.
    DevMode bool

    // NodeID is a unique identifier for this node across space and time.
    NodeID types.NodeID

    // Node name is the name we use to advertise. Defaults to hostname.
    NodeName string

    // Domain is the DNS domain for the records. Defaults to "consul."
    Domain string

    // RaftConfig is the configuration used for Raft in the local DC
    RaftConfig *raft.Config

    // (Enterprise-only) NonVoter is used to prevent this server from being added
    // as a voting member of the Raft cluster.
    NonVoter bool

    // RPCAddr is the RPC address used by Consul. This should be reachable
    // by the WAN and LAN
    RPCAddr *net.TCPAddr

    // RPCAdvertise is the address that is advertised to other nodes for
    // the RPC endpoint. This can differ from the RPC address, if for example
    // the RPCAddr is unspecified "0.0.0.0:8300", but this address must be
    // reachable
    RPCAdvertise *net.TCPAddr

    // RPCSrcAddr is the source address for outgoing RPC connections.
    RPCSrcAddr *net.TCPAddr

    // SerfLANConfig is the configuration for the intra-dc serf
    SerfLANConfig *serf.Config

    // SerfWANConfig is the configuration for the cross-dc serf
    SerfWANConfig *serf.Config

    // SerfFloodInterval controls how often we attempt to flood local Serf
    // Consul servers into the global areas (WAN and user-defined areas in
    // Consul Enterprise).
    SerfFloodInterval time.Duration

    // ReconcileInterval controls how often we reconcile the strongly
    // consistent store with the Serf info. This is used to handle nodes
    // that are force removed, as well as intermittent unavailability during
    // leader election.
    ReconcileInterval time.Duration

    // LogOutput is the location to write logs to. If this is not set,
    // logs will go to stderr.
    LogOutput io.Writer

    // ProtocolVersion is the protocol version to speak. This must be between
    // ProtocolVersionMin and ProtocolVersionMax.
    ProtocolVersion uint8

    // VerifyIncoming is used to verify the authenticity of incoming connections.
    // This means that TCP requests are forbidden, only allowing for TLS. TLS connections
    // must match a provided certificate authority. This can be used to force client auth.
    VerifyIncoming bool

    // VerifyOutgoing is used to force verification of the authenticity of outgoing connections.
    // This means that TLS requests are used, and TCP requests are not made. TLS connections
    // must match a provided certificate authority.
    VerifyOutgoing bool

    // UseTLS is used to enable TLS for outgoing connections to other TLS-capable Consul
    // servers. This doesn't imply any verification, it only enables TLS if possible.
    UseTLS bool

    // VerifyServerHostname is used to enable hostname verification of servers. This
    // ensures that the certificate presented is valid for server.<datacenter>.<domain>.
    // This prevents a compromised client from being restarted as a server, and then
    // intercepting request traffic as well as being added as a raft peer. This should be
    // enabled by default with VerifyOutgoing, but for legacy reasons we cannot break
    // existing clients.
    VerifyServerHostname bool

    // CAFile is a path to a certificate authority file. This is used with VerifyIncoming
    // or VerifyOutgoing to verify the TLS connection.
    CAFile string

    // CAPath is a path to a directory of certificate authority files. This is used with
    // VerifyIncoming or VerifyOutgoing to verify the TLS connection.
    CAPath string

    // CertFile is used to provide a TLS certificate that is used for serving TLS connections.
    // Must be provided to serve TLS connections.
    CertFile string

    // KeyFile is used to provide a TLS key that is used for serving TLS connections.
    // Must be provided to serve TLS connections.
    KeyFile string

    // ServerName is used with the TLS certificate to ensure the name we
    // provide matches the certificate
    ServerName string

    // TLSMinVersion is used to set the minimum TLS version used for TLS connections.
    TLSMinVersion string

    // TLSCipherSuites is used to specify the list of supported ciphersuites.
    TLSCipherSuites []uint16

    // TLSPreferServerCipherSuites specifies whether to prefer the server's ciphersuite
    // over the client ciphersuites.
    TLSPreferServerCipherSuites bool

    // RejoinAfterLeave controls our interaction with Serf.
    // When set to false (default), a leave causes a Consul to not rejoin
    // the cluster until an explicit join is received. If this is set to
    // true, we ignore the leave, and rejoin the cluster on start.
    RejoinAfterLeave bool

    // Build is a string that is gossiped around, and can be used to help
    // operators track which versions are actively deployed
    Build string

    // ACLToken is the default token to use when making a request.
    // If not provided, the anonymous token is used. This enables
    // backwards compatibility as well.
    ACLToken string

    // ACLAgentToken is the default token used to make requests for the agent
    // itself, such as for registering itself with the catalog. If not
    // configured, the ACLToken will be used.
    ACLAgentToken string

    // ACLMasterToken is used to bootstrap the ACL system. It should be specified
    // on the servers in the ACLDatacenter. When the leader comes online, it ensures
    // that the Master token is available. This provides the initial token.
    ACLMasterToken string

    // ACLDatacenter provides the authoritative datacenter for ACL
    // tokens. If not provided, ACL verification is disabled.
    ACLDatacenter string

    // ACLTTL controls the time-to-live of cached ACL policies.
    // It can be set to zero to disable caching, but this adds
    // a substantial cost.
    ACLTTL time.Duration

    // ACLDefaultPolicy is used to control the ACL interaction when
    // there is no defined policy. This can be "allow" which means
    // ACLs are used to black-list, or "deny" which means ACLs are
    // white-lists.
    ACLDefaultPolicy string

    // ACLDownPolicy controls the behavior of ACLs if the ACLDatacenter
    // cannot be contacted. It can be either "deny" to deny all requests,
    // or "extend-cache" which ignores the ACLCacheInterval and uses
    // cached policies. If a policy is not in the cache, it acts like deny.
    // "allow" can be used to allow all requests. This is not recommended.
    ACLDownPolicy string

    // ACLReplicationToken is used to fetch ACLs from the ACLDatacenter in
    // order to replicate them locally. Setting this to a non-empty value
    // also enables replication. Replication is only available in datacenters
    // other than the ACLDatacenter.
    ACLReplicationToken string

    // ACLReplicationInterval is the interval at which replication passes
    // will occur. Queries to the ACLDatacenter may block, so replication
    // can happen less often than this, but the interval forms the upper
    // limit to how fast we will go if there was constant ACL churn on the
    // remote end.
    ACLReplicationInterval time.Duration

    // ACLReplicationApplyLimit is the max number of replication-related
    // apply operations that we allow during a one second period. This is
    // used to limit the amount of Raft bandwidth used for replication.
    ACLReplicationApplyLimit int

    // ACLEnforceVersion8 is used to gate a set of ACL policy features that
    // are opt-in prior to Consul 0.8 and opt-out in Consul 0.8 and later.
    ACLEnforceVersion8 bool

    // TombstoneTTL is used to control how long KV tombstones are retained.
    // This provides a window of time where the X-Consul-Index is monotonic.
    // Outside this window, the index may not be monotonic. This is a result
    // of a few trade offs:
    // 1) The index is defined by the data view and not globally. This is a
    // performance optimization that prevents any write from incrementing the
    // index for all data views.
    // 2) Tombstones are not kept indefinitely, since otherwise storage required
    // is also monotonic. This prevents deletes from reducing the disk space
    // used.
    // In theory, neither of these are intrinsic limitations, however for the
    // purposes of building a practical system, they are reasonable trade offs.
    //
    // It is also possible to set this to an incredibly long time, thereby
    // simulating infinite retention. This is not recommended however.
    //
    TombstoneTTL time.Duration

    // TombstoneTTLGranularity is used to control how granular the timers are
    // for the Tombstone GC. This is used to batch the GC of many keys together
    // to reduce overhead. It is unlikely a user would ever need to tune this.
    TombstoneTTLGranularity time.Duration

    // Minimum Session TTL
    SessionTTLMin time.Duration

    // ServerUp callback can be used to trigger a notification that
    // a Consul server is now up and known about.
    ServerUp func()

    // UserEventHandler callback can be used to handle incoming
    // user events. This function should not block.
    UserEventHandler func(serf.UserEvent)

    // CoordinateUpdatePeriod controls how long a server batches coordinate
    // updates before applying them in a Raft transaction. A larger period
    // leads to fewer Raft transactions, but also the stored coordinates
    // being more stale.
    CoordinateUpdatePeriod time.Duration

    // CoordinateUpdateBatchSize controls the maximum number of updates a
    // server batches before applying them in a Raft transaction.
    CoordinateUpdateBatchSize int

    // CoordinateUpdateMaxBatches controls the maximum number of batches we
    // are willing to apply in one period. After this limit we will issue a
    // warning and discard the remaining updates.
    CoordinateUpdateMaxBatches int

    // RPCHoldTimeout is how long an RPC can be "held" before it is errored.
    // This is used to paper over a loss of leadership by instead holding RPCs,
    // so that the caller experiences a slow response rather than an error.
    // This period is meant to be long enough for a leader election to take
    // place, and a small jitter is applied to avoid a thundering herd.
    RPCHoldTimeout time.Duration

    // AutopilotConfig is used to apply the initial autopilot config when
    // bootstrapping.
    AutopilotConfig *structs.AutopilotConfig

    // ServerHealthInterval is the frequency with which the health of the
    // servers in the cluster will be updated.
    ServerHealthInterval time.Duration

    // AutopilotInterval is the frequency with which the leader will perform
    // autopilot tasks, such as promoting eligible non-voters and removing
    // dead servers.
    AutopilotInterval time.Duration
}

func DefaultConfig

func DefaultConfig() *Config

DefaultConfig returns a sane default configuration.

func (*Config) CheckACL

func (c *Config) CheckACL() error

CheckACL validates the ACL configuration.

func (*Config) CheckProtocolVersion

func (c *Config) CheckProtocolVersion() error

CheckProtocolVersion validates the protocol version.

func (*Config) GetTokenForAgent

func (c *Config) GetTokenForAgent() string

GetTokenForAgent returns the token the agent should use for its own internal operations, such as registering itself with the catalog.

func (*Config) ScaleRaft

func (c *Config) ScaleRaft(raftMultRaw uint)

ScaleRaft sets the config to have Raft timing parameters scaled by the given performance multiplier. This is done in an idempotent way so it's not tricky to call this when composing configurations and potentially calling this multiple times on the same structure.

type Conn

Conn is a pooled connection to a Consul server

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

func (*Conn) Close

func (c *Conn) Close() error

type ConnPool

ConnPool is used to maintain a connection pool to other Consul servers. This is used to reduce the latency of RPC requests between servers. It is only used to pool connections in the rpcConsul mode. Raft connections are pooled separately.

type ConnPool struct {
    sync.Mutex
    // contains filtered or unexported fields
}

func NewPool

func NewPool(src *net.TCPAddr, logOutput io.Writer, maxTime time.Duration, maxStreams int, tlsWrap tlsutil.DCWrapper, forceTLS bool) *ConnPool

NewPool is used to make a new connection pool Maintain at most one connection per host, for up to maxTime. Set maxTime to 0 to disable reaping. maxStreams is used to control the number of idle streams allowed. If TLS settings are provided outgoing connections use TLS.

func (*ConnPool) DialTimeout

func (p *ConnPool) DialTimeout(dc string, addr net.Addr, timeout time.Duration, useTLS bool) (net.Conn, HalfCloser, error)

DialTimeout is used to establish a raw connection to the given server, with a given connection timeout.

func (*ConnPool) PingConsulServer

func (p *ConnPool) PingConsulServer(s *agent.Server) (bool, error)

PingConsulServer sends a Status.Ping message to the specified server and returns true if healthy, false if an error occurred

func (*ConnPool) RPC

func (p *ConnPool) RPC(dc string, addr net.Addr, version int, method string, useTLS bool, args interface{}, reply interface{}) error

RPC is used to make an RPC call to a remote host

func (*ConnPool) Shutdown

func (p *ConnPool) Shutdown() error

Shutdown is used to close the connection pool

type Coordinate

Coordinate manages queries and updates for network coordinates.

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

func NewCoordinate

func NewCoordinate(srv *Server) *Coordinate

NewCoordinate returns a new Coordinate endpoint.

func (*Coordinate) ListDatacenters

func (c *Coordinate) ListDatacenters(args *struct{}, reply *[]structs.DatacenterMap) error

ListDatacenters returns the list of datacenters and their respective nodes and the raw coordinates of those nodes (if no coordinates are available for any of the nodes, the node list may be empty).

func (*Coordinate) ListNodes

func (c *Coordinate) ListNodes(args *structs.DCSpecificRequest, reply *structs.IndexedCoordinates) error

ListNodes returns the list of nodes with their raw network coordinates (if no coordinates are available for a node it won't appear in this list).

func (*Coordinate) Update

func (c *Coordinate) Update(args *structs.CoordinateUpdateRequest, reply *struct{}) (err error)

Update inserts or updates the LAN coordinate of a node.

type Filter

Filter interface is used with FilterEntries to do an in-place filter of a slice.

type Filter interface {
    Len() int
    Filter(int) bool
    Move(dst, src, span int)
}

type HalfCloser

HalfCloser is an interface that exposes a TCP half-close. We need this because we want to expose the raw TCP connection underlying a TLS one in a way that's hard to screw up and use for anything else. There's a change brewing that will allow us to use the TLS connection for this instead - https://go-review.googlesource.com/#/c/25159/.

type HalfCloser interface {
    CloseWrite() error
}

type Health

Health endpoint is used to query the health information

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

func (*Health) ChecksInState

func (h *Health) ChecksInState(args *structs.ChecksInStateRequest,
    reply *structs.IndexedHealthChecks) error

ChecksInState is used to get all the checks in a given state

func (*Health) NodeChecks

func (h *Health) NodeChecks(args *structs.NodeSpecificRequest,
    reply *structs.IndexedHealthChecks) error

NodeChecks is used to get all the checks for a node

func (*Health) ServiceChecks

func (h *Health) ServiceChecks(args *structs.ServiceSpecificRequest,
    reply *structs.IndexedHealthChecks) error

ServiceChecks is used to get all the checks for a service

func (*Health) ServiceNodes

func (h *Health) ServiceNodes(args *structs.ServiceSpecificRequest, reply *structs.IndexedCheckServiceNodes) error

ServiceNodes returns all the nodes registered as part of a service including health info

type Interface

Interface is used to provide either a Client or Server, both of which can be used to perform certain common Consul methods

type Interface interface {
    RPC(method string, args interface{}, reply interface{}) error
    LANMembers() []serf.Member
    LocalMember() serf.Member
}

type Internal

Internal endpoint is used to query the miscellaneous info that does not necessarily fit into the other systems. It is also used to hold undocumented APIs that users should not rely on.

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

func (*Internal) EventFire

func (m *Internal) EventFire(args *structs.EventFireRequest,
    reply *structs.EventFireResponse) error

EventFire is a bit of an odd endpoint, but it allows for a cross-DC RPC call to fire an event. The primary use case is to enable user events being triggered in a remote DC.

func (*Internal) KeyringOperation

func (m *Internal) KeyringOperation(
    args *structs.KeyringRequest,
    reply *structs.KeyringResponses) error

KeyringOperation will query the WAN and LAN gossip keyrings of all nodes.

func (*Internal) NodeDump

func (m *Internal) NodeDump(args *structs.DCSpecificRequest,
    reply *structs.IndexedNodeDump) error

NodeDump is used to generate information about all of the nodes.

func (*Internal) NodeInfo

func (m *Internal) NodeInfo(args *structs.NodeSpecificRequest,
    reply *structs.IndexedNodeDump) error

NodeInfo is used to retrieve information about a specific node.

type KVS

KVS endpoint is used to manipulate the Key-Value store

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

func (*KVS) Apply

func (k *KVS) Apply(args *structs.KVSRequest, reply *bool) error

Apply is used to apply a KVS update request to the data store.

func (*KVS) Get

func (k *KVS) Get(args *structs.KeyRequest, reply *structs.IndexedDirEntries) error

Get is used to lookup a single key.

func (*KVS) List

func (k *KVS) List(args *structs.KeyRequest, reply *structs.IndexedDirEntries) error

List is used to list all keys with a given prefix.

func (*KVS) ListKeys

func (k *KVS) ListKeys(args *structs.KeyListRequest, reply *structs.IndexedKeyList) error

ListKeys is used to list all keys with a given prefix to a separator.

type Operator

Operator endpoint is used to perform low-level operator tasks for Consul.

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

func (*Operator) AutopilotGetConfiguration

func (op *Operator) AutopilotGetConfiguration(args *structs.DCSpecificRequest, reply *structs.AutopilotConfig) error

AutopilotGetConfiguration is used to retrieve the current Autopilot configuration.

func (*Operator) AutopilotSetConfiguration

func (op *Operator) AutopilotSetConfiguration(args *structs.AutopilotSetConfigRequest, reply *bool) error

AutopilotSetConfiguration is used to set the current Autopilot configuration.

func (*Operator) RaftGetConfiguration

func (op *Operator) RaftGetConfiguration(args *structs.DCSpecificRequest, reply *structs.RaftConfigurationResponse) error

RaftGetConfiguration is used to retrieve the current Raft configuration.

func (*Operator) RaftRemovePeerByAddress

func (op *Operator) RaftRemovePeerByAddress(args *structs.RaftRemovePeerRequest, reply *struct{}) error

RaftRemovePeerByAddress is used to kick a stale peer (one that it in the Raft quorum but no longer known to Serf or the catalog) by address in the form of "IP:port". The reply argument is not used, but it required to fulfill the RPC interface.

func (*Operator) RaftRemovePeerByID

func (op *Operator) RaftRemovePeerByID(args *structs.RaftRemovePeerRequest, reply *struct{}) error

RaftRemovePeerByID is used to kick a stale peer (one that is in the Raft quorum but no longer known to Serf or the catalog) by address in the form of "IP:port". The reply argument is not used, but is required to fulfill the RPC interface.

func (*Operator) ServerHealth

func (op *Operator) ServerHealth(args *structs.DCSpecificRequest, reply *structs.OperatorHealthReply) error

ServerHealth is used to get the current health of the servers.

type PreparedQuery

PreparedQuery manages the prepared query endpoint.

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

func (*PreparedQuery) Apply

func (p *PreparedQuery) Apply(args *structs.PreparedQueryRequest, reply *string) (err error)

Apply is used to apply a modifying request to the data store. This should only be used for operations that modify the data. The ID of the session is returned in the reply.

func (*PreparedQuery) Execute

func (p *PreparedQuery) Execute(args *structs.PreparedQueryExecuteRequest,
    reply *structs.PreparedQueryExecuteResponse) error

Execute runs a prepared query and returns the results. This will perform the failover logic if no local results are available. This is typically called as part of a DNS lookup, or when executing prepared queries from the HTTP API.

func (*PreparedQuery) ExecuteRemote

func (p *PreparedQuery) ExecuteRemote(args *structs.PreparedQueryExecuteRemoteRequest,
    reply *structs.PreparedQueryExecuteResponse) error

ExecuteRemote is used when a local node doesn't have any instances of a service available and needs to probe remote DCs. This sends the full query over since the remote side won't have it in its state store, and this doesn't do the failover logic since that's already being run on the originating DC. We don't want things to fan out further than one level.

func (*PreparedQuery) Explain

func (p *PreparedQuery) Explain(args *structs.PreparedQueryExecuteRequest,
    reply *structs.PreparedQueryExplainResponse) error

Explain resolves a prepared query and returns the (possibly rendered template) to the caller. This is useful for letting operators figure out which query is picking up a given name. We can also add additional info about how the query will be executed here.

func (*PreparedQuery) Get

func (p *PreparedQuery) Get(args *structs.PreparedQuerySpecificRequest,
    reply *structs.IndexedPreparedQueries) error

Get returns a single prepared query by ID.

func (*PreparedQuery) List

func (p *PreparedQuery) List(args *structs.DCSpecificRequest, reply *structs.IndexedPreparedQueries) error

List returns all the prepared queries.

type RPCType

type RPCType byte

type RaftLayer

RaftLayer implements the raft.StreamLayer interface, so that we can use a single RPC layer for Raft and Consul

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

func NewRaftLayer

func NewRaftLayer(src, addr net.Addr, tlsWrap tlsutil.Wrapper, tlsFunc func(raft.ServerAddress) bool) *RaftLayer

NewRaftLayer is used to initialize a new RaftLayer which can be used as a StreamLayer for Raft. If a tlsConfig is provided, then the connection will use TLS.

func (*RaftLayer) Accept

func (l *RaftLayer) Accept() (net.Conn, error)

Accept is used to return connection which are dialed to be used with the Raft layer

func (*RaftLayer) Addr

func (l *RaftLayer) Addr() net.Addr

Addr is used to return the address of the listener

func (*RaftLayer) Close

func (l *RaftLayer) Close() error

Close is used to stop listening for Raft connections

func (*RaftLayer) Dial

func (l *RaftLayer) Dial(address raft.ServerAddress, timeout time.Duration) (net.Conn, error)

Dial is used to create a new outgoing connection

func (*RaftLayer) Handoff

func (l *RaftLayer) Handoff(c net.Conn) error

Handoff is used to hand off a connection to the RaftLayer. This allows it to be Accept()'ed

type Server

Server is Consul server which manages the service discovery, health checking, DC forwarding, Raft, and multiple Serf pools.

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

func NewServer

func NewServer(config *Config) (*Server, error)

func NewServerLogger

func NewServerLogger(config *Config, logger *log.Logger) (*Server, error)

NewServer is used to construct a new Consul server from the configuration, potentially returning an error

func (*Server) Encrypted

func (s *Server) Encrypted() bool

Encrypted determines if gossip is encrypted

func (*Server) Flood

func (s *Server) Flood(portFn servers.FloodPortFn, global *serf.Serf)

Flood is a long-running goroutine that floods servers from the LAN to the given global Serf instance, such as the WAN. This will exit once either of the Serf instances are shut down.

func (*Server) FloodNotify

func (s *Server) FloodNotify()

FloodNotify lets all the waiting Flood goroutines know that some change may have affected them.

func (*Server) GetLANCoordinate

func (s *Server) GetLANCoordinate() (*coordinate.Coordinate, error)

GetLANCoordinate returns the coordinate of the server in the LAN gossip pool.

func (*Server) GetWANCoordinate

func (s *Server) GetWANCoordinate() (*coordinate.Coordinate, error)

GetWANCoordinate returns the coordinate of the server in the WAN gossip pool.

func (*Server) InjectEndpoint

func (s *Server) InjectEndpoint(endpoint interface{}) error

InjectEndpoint is used to substitute an endpoint for testing.

func (*Server) IsACLReplicationEnabled

func (s *Server) IsACLReplicationEnabled() bool

IsACLReplicationEnabled returns true if ACL replication is enabled.

func (*Server) IsLeader

func (s *Server) IsLeader() bool

IsLeader checks if this server is the cluster leader

func (*Server) JoinLAN

func (s *Server) JoinLAN(addrs []string) (int, error)

JoinLAN is used to have Consul join the inner-DC pool The target address should be another node inside the DC listening on the Serf LAN address

func (*Server) JoinWAN

func (s *Server) JoinWAN(addrs []string) (int, error)

JoinWAN is used to have Consul join the cross-WAN Consul ring The target address should be another node listening on the Serf WAN address

func (*Server) KeyManagerLAN

func (s *Server) KeyManagerLAN() *serf.KeyManager

KeyManagerLAN returns the LAN Serf keyring manager

func (*Server) KeyManagerWAN

func (s *Server) KeyManagerWAN() *serf.KeyManager

KeyManagerWAN returns the WAN Serf keyring manager

func (*Server) LANMembers

func (s *Server) LANMembers() []serf.Member

LANMembers is used to return the members of the LAN cluster

func (*Server) Leave

func (s *Server) Leave() error

Leave is used to prepare for a graceful shutdown of the server

func (*Server) LocalMember

func (s *Server) LocalMember() serf.Member

LocalMember is used to return the local node

func (*Server) RPC

func (s *Server) RPC(method string, args interface{}, reply interface{}) error

RPC is used to make a local RPC call

func (*Server) RemoveFailedNode

func (s *Server) RemoveFailedNode(node string) error

RemoveFailedNode is used to remove a failed node from the cluster

func (*Server) Shutdown

func (s *Server) Shutdown() error

Shutdown is used to shutdown the server

func (*Server) SnapshotRPC

func (s *Server) SnapshotRPC(args *structs.SnapshotRequest, in io.Reader, out io.Writer,
    replyFn SnapshotReplyFn) error

SnapshotRPC dispatches the given snapshot request, reading from the streaming input and writing to the streaming output depending on the operation.

func (*Server) Stats

func (s *Server) Stats() map[string]map[string]string

Stats is used to return statistics for debugging and insight for various sub-systems

func (*Server) WANMembers

func (s *Server) WANMembers() []serf.Member

WANMembers is used to return the members of the LAN cluster

type Session

Session endpoint is used to manipulate sessions for KV

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

func (*Session) Apply

func (s *Session) Apply(args *structs.SessionRequest, reply *string) error

Apply is used to apply a modifying request to the data store. This should only be used for operations that modify the data

func (*Session) Get

func (s *Session) Get(args *structs.SessionSpecificRequest,
    reply *structs.IndexedSessions) error

Get is used to retrieve a single session

func (*Session) List

func (s *Session) List(args *structs.DCSpecificRequest,
    reply *structs.IndexedSessions) error

List is used to list all the active sessions

func (*Session) NodeSessions

func (s *Session) NodeSessions(args *structs.NodeSpecificRequest,
    reply *structs.IndexedSessions) error

NodeSessions is used to get all the sessions for a particular node

func (*Session) Renew

func (s *Session) Renew(args *structs.SessionSpecificRequest,
    reply *structs.IndexedSessions) error

Renew is used to renew the TTL on a single session

type SnapshotReplyFn

SnapshotReplyFn gets a peek at the reply before the snapshot streams, which is useful for setting headers.

type SnapshotReplyFn func(reply *structs.SnapshotResponse) error

type StatsFetcher

StatsFetcher has two functions for autopilot. First, lets us fetch all the stats in parallel so we are taking a sample as close to the same time as possible, since we are comparing time-sensitive info for the health check. Second, it bounds the time so that one slow RPC can't hold up the health check loop; as a side effect of how it implements this, it also limits to a single in-flight RPC to any given server, so goroutines don't accumulate as we run the health check fairly frequently.

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

func NewStatsFetcher

func NewStatsFetcher(logger *log.Logger, pool *ConnPool, datacenter string) *StatsFetcher

NewStatsFetcher returns a stats fetcher.

func (*StatsFetcher) Fetch

func (f *StatsFetcher) Fetch(ctx context.Context, servers []*agent.Server) map[string]*structs.ServerStats

Fetch will attempt to query all the servers in parallel.

type Status

Status endpoint is used to check on server status

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

func (*Status) Leader

func (s *Status) Leader(args struct{}, reply *string) error

Leader is used to get the address of the leader

func (*Status) Peers

func (s *Status) Peers(args struct{}, reply *[]string) error

Peers is used to get all the Raft peers

func (*Status) Ping

func (s *Status) Ping(args struct{}, reply *struct{}) error

Ping is used to just check for connectivity

func (*Status) RaftStats

func (s *Status) RaftStats(args struct{}, reply *structs.ServerStats) error

Used by Autopilot to query the raft stats of the local server.

type StreamClient

streamClient is used to wrap a stream with an RPC client

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

func (*StreamClient) Close

func (sc *StreamClient) Close()

type Txn

Txn endpoint is used to perform multi-object atomic transactions.

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

func (*Txn) Apply

func (t *Txn) Apply(args *structs.TxnRequest, reply *structs.TxnResponse) error

Apply is used to apply multiple operations in a single, atomic transaction.

func (*Txn) Read

func (t *Txn) Read(args *structs.TxnReadRequest, reply *structs.TxnReadResponse) error

Read is used to perform a read-only transaction that doesn't modify the state store. This is much more scaleable since it doesn't go through Raft and supports staleness, so this should be preferred if you're just performing reads.

Subdirectories

Name Synopsis
..
agent Package agent provides a logical endpoint for Consul agents in the network.
prepared_query
servers Package servers provides a Manager interface for Manager managed agent.Server objects.
state
structs