github.com/cockroachdb/cockroach@v20.2.0-alpha.1+incompatible/pkg/kv/kvserver/doc.go (about)

     1  // Copyright 2014 The Cockroach Authors.
     2  //
     3  // Use of this software is governed by the Business Source License
     4  // included in the file licenses/BSL.txt.
     5  //
     6  // As of the Change Date specified in that file, in accordance with
     7  // the Business Source License, use of this software will be governed
     8  // by the Apache License, Version 2.0, included in the file
     9  // licenses/APL.txt.
    10  
    11  /*
    12  Package kvserver provides access to the Store and Range
    13  abstractions. Each Cockroach node handles one or more stores, each of
    14  which multiplexes to one or more ranges, identified by [start, end)
    15  keys. Ranges are contiguous regions of the keyspace. Each range
    16  implements an instance of the Raft consensus algorithm to synchronize
    17  participating range replicas.
    18  
    19  Each store is represented by a single engine.Engine instance. The
    20  ranges hosted by a store all have access to the same engine, but write
    21  to only a range-limited keyspace within it. Ranges access the
    22  underlying engine via the MVCC interface, which provides historical
    23  versioned values.
    24  */
    25  package kvserver