Versions in this module Expand all Collapse all v1 v1.1.1 Dec 10, 2014 v1.1.0 Nov 28, 2014 Changes in this version type Client + DefaultPolicy *BasePolicy + DefaultQueryPolicy *QueryPolicy + DefaultScanPolicy *ScanPolicy + DefaultWritePolicy *WritePolicy v1.0.3 Nov 24, 2014 v1.0.2 Nov 2, 2014 Changes in this version type LargeList + func (ll *LargeList) Update(values ...interface{}) error type LargeMap + func (lm *LargeMap) Remove(name interface{}) (map[interface{}]interface{}, error) + type MultiPolicy struct + MaxConcurrentNodes int + RecordQueueSize int + WaitUntilMigrationsAreOver bool + func NewMultiPolicy() *MultiPolicy v1.0.1 Sep 7, 2014 Changes in this version + func RequestInfo(conn *Connection, names ...string) (map[string]string, error) + func RequestNodeInfo(node *Node, name ...string) (map[string]string, error) + func RequestNodeStats(node *Node) (map[string]string, error) + func SetCommandBufferPool(poolSize, initBufSize, maxBufferSize int) + type AerospikeBlob interface + EncodeBlob func() ([]byte, error) + type BasePolicy struct + MaxRetries int + Priority Priority + SleepBetweenRetries time.Duration + Timeout time.Duration + func NewPolicy() *BasePolicy + func (p *BasePolicy) GetBasePolicy() *BasePolicy + type BaseTask struct + func NewTask(cluster *Cluster, done bool) *BaseTask + type Bin struct + Name string + Value Value + func NewBin(name string, value interface{}) *Bin + func (bn *Bin) String() string + type BinMap map[string]interface + type BytesValue struct + func NewBlobValue(object AerospikeBlob) *BytesValue + func NewBytesValue(bytes []byte) *BytesValue + func (vl *BytesValue) GetObject() interface{} + func (vl *BytesValue) GetType() int + func (vl *BytesValue) String() string + type Client struct + func NewClient(hostname string, port int) (*Client, error) + func NewClientWithPolicy(policy *ClientPolicy, hostname string, port int) (*Client, error) + func NewClientWithPolicyAndHost(policy *ClientPolicy, hosts ...*Host) (*Client, error) + func (clnt *Client) Add(policy *WritePolicy, key *Key, bins BinMap) error + func (clnt *Client) AddBins(policy *WritePolicy, key *Key, bins ...*Bin) error + func (clnt *Client) Append(policy *WritePolicy, key *Key, bins BinMap) error + func (clnt *Client) AppendBins(policy *WritePolicy, key *Key, bins ...*Bin) error + func (clnt *Client) BatchExists(policy *BasePolicy, keys []*Key) ([]bool, error) + func (clnt *Client) BatchGet(policy *BasePolicy, keys []*Key, binNames ...string) ([]*Record, error) + func (clnt *Client) BatchGetHeader(policy *BasePolicy, keys []*Key) ([]*Record, error) + func (clnt *Client) Close() + func (clnt *Client) CreateIndex(policy *WritePolicy, namespace string, setName string, indexName string, ...) (*IndexTask, error) + func (clnt *Client) Delete(policy *WritePolicy, key *Key) (bool, error) + func (clnt *Client) DropIndex(policy *WritePolicy, namespace string, setName string, indexName string) error + func (clnt *Client) Execute(policy *WritePolicy, key *Key, packageName string, functionName string, ...) (interface{}, error) + func (clnt *Client) ExecuteUDF(policy *QueryPolicy, statement *Statement, packageName string, ...) (*ExecuteTask, error) + func (clnt *Client) Exists(policy *BasePolicy, key *Key) (bool, error) + func (clnt *Client) Get(policy *BasePolicy, key *Key, binNames ...string) (*Record, error) + func (clnt *Client) GetHeader(policy *BasePolicy, key *Key) (*Record, error) + func (clnt *Client) GetLargeList(policy *WritePolicy, key *Key, binName string, userModule string) *LargeList + func (clnt *Client) GetLargeMap(policy *WritePolicy, key *Key, binName string, userModule string) *LargeMap + func (clnt *Client) GetLargeSet(policy *WritePolicy, key *Key, binName string, userModule string) *LargeSet + func (clnt *Client) GetLargeStack(policy *WritePolicy, key *Key, binName string, userModule string) *LargeStack + func (clnt *Client) GetNodeNames() []string + func (clnt *Client) GetNodes() []*Node + func (clnt *Client) IsConnected() bool + func (clnt *Client) ListUDF(policy *BasePolicy) ([]*UDF, error) + func (clnt *Client) Operate(policy *WritePolicy, key *Key, operations ...*Operation) (*Record, error) + func (clnt *Client) Prepend(policy *WritePolicy, key *Key, bins BinMap) error + func (clnt *Client) PrependBins(policy *WritePolicy, key *Key, bins ...*Bin) error + func (clnt *Client) Put(policy *WritePolicy, key *Key, bins BinMap) error + func (clnt *Client) PutBins(policy *WritePolicy, key *Key, bins ...*Bin) error + func (clnt *Client) Query(policy *QueryPolicy, statement *Statement) (*Recordset, error) + func (clnt *Client) RegisterUDF(policy *WritePolicy, udfBody []byte, serverPath string, language Language) (*RegisterTask, error) + func (clnt *Client) RegisterUDFFromFile(policy *WritePolicy, clientPath string, serverPath string, language Language) (*RegisterTask, error) + func (clnt *Client) RemoveUDF(policy *WritePolicy, udfName string) (*RemoveTask, error) + func (clnt *Client) ScanAll(policy *ScanPolicy, namespace string, setName string, binNames ...string) (*Recordset, error) + func (clnt *Client) ScanNode(policy *ScanPolicy, node *Node, namespace string, setName string, ...) (*Recordset, error) + func (clnt *Client) Touch(policy *WritePolicy, key *Key) error + type ClientPolicy struct + ConnectionQueueSize int + FailIfNotConnected bool + Timeout time.Duration + func NewClientPolicy() *ClientPolicy + type Cluster struct + func NewCluster(policy *ClientPolicy, hosts []*Host) (*Cluster, error) + func (clstr *Cluster) AddSeeds(hosts []*Host) + func (clstr *Cluster) Close() + func (clstr *Cluster) FindNodeName(list []*Node, name string) bool + func (clstr *Cluster) GetNode(partition *Partition) (*Node, error) + func (clstr *Cluster) GetNodeByName(nodeName string) (*Node, error) + func (clstr *Cluster) GetNodes() []*Node + func (clstr *Cluster) GetRandomNode() (*Node, error) + func (clstr *Cluster) IsConnected() bool + func (clstr *Cluster) MigrationInProgress(timeout time.Duration) (res bool, err error) + func (clstr *Cluster) WaitUntillMigrationIsFinished(timeout time.Duration) (err error) + type Connection struct + func NewConnection(address string, timeout time.Duration) (*Connection, error) + func (ctn *Connection) Close() + func (ctn *Connection) IsConnected() bool + func (ctn *Connection) Read(buf []byte, length int) (total int, err error) + func (ctn *Connection) SetTimeout(timeout time.Duration) error + func (ctn *Connection) Write(buf []byte) (total int, err error) + type ExecuteTask struct + func NewExecuteTask(cluster *Cluster, statement *Statement) *ExecuteTask + func (etsk *ExecuteTask) IsDone() (bool, error) + func (etsk *ExecuteTask) OnComplete() chan error + type FieldType int + const DIGEST_RIPE + const DIGEST_RIPE_ARRAY + const INDEX_FILTER + const INDEX_LIMIT + const INDEX_NAME + const INDEX_ORDER_BY + const INDEX_RANGE + const KEY + const NAMESPACE + const QUERY_BINLIST + const SCAN_OPTIONS + const TABLE + const TRAN_ID + const UDF_ARGLIST + const UDF_FUNCTION + const UDF_OP + const UDF_PACKAGE_NAME + type Filter struct + func NewEqualFilter(binName string, value interface{}) *Filter + func NewRangeFilter(binName string, begin int64, end int64) *Filter + type GenerationPolicy int + const DUPLICATE + const EXPECT_GEN_EQUAL + const EXPECT_GEN_GT + const NONE + type Host struct + Name string + Port int + func NewHost(name string, port int) *Host + func (h *Host) String() string + type IndexTask struct + func NewIndexTask(cluster *Cluster, namespace string, indexName string) *IndexTask + func (tski *IndexTask) IsDone() (bool, error) + func (tski *IndexTask) OnComplete() chan error + type IndexType string + const NUMERIC + const STRING + type IntegerValue struct + func NewIntegerValue(value int) *IntegerValue + func (vl *IntegerValue) GetObject() interface{} + func (vl *IntegerValue) GetType() int + func (vl *IntegerValue) String() string + type Key struct + func NewKey(namespace string, setName string, key interface{}) (newKey *Key, err error) + func (ky *Key) Digest() []byte + func (ky *Key) Equals(other *Key) bool + func (ky *Key) Namespace() string + func (ky *Key) SetName() string + func (ky *Key) String() string + func (ky *Key) Value() Value + type Language string + const LUA + type LargeList struct + func NewLargeList(client *Client, policy *WritePolicy, key *Key, binName string, ...) *LargeList + func (ll *LargeList) Add(values ...interface{}) error + func (ll *LargeList) Destroy() error + func (ll *LargeList) Filter(filterName string, filterArgs ...interface{}) ([]interface{}, error) + func (ll *LargeList) Find(value interface{}) ([]interface{}, error) + func (ll *LargeList) FindThenFilter(value interface{}, filterName string, filterArgs ...interface{}) ([]interface{}, error) + func (ll *LargeList) GetCapacity() (int, error) + func (ll *LargeList) GetConfig() (map[interface{}]interface{}, error) + func (ll *LargeList) Remove(value interface{}) error + func (ll *LargeList) Scan() ([]interface{}, error) + func (ll *LargeList) SetCapacity(capacity int) error + func (ll *LargeList) Size() (int, error) + type LargeMap struct + func NewLargeMap(client *Client, policy *WritePolicy, key *Key, binName string, ...) *LargeMap + func (lm *LargeMap) Destroy() error + func (lm *LargeMap) Filter(filterName string, filterArgs ...interface{}) (map[interface{}]interface{}, error) + func (lm *LargeMap) Get(name interface{}) (map[interface{}]interface{}, error) + func (lm *LargeMap) GetCapacity() (int, error) + func (lm *LargeMap) GetConfig() (map[interface{}]interface{}, error) + func (lm *LargeMap) Put(name interface{}, value interface{}) error + func (lm *LargeMap) PutMap(theMap map[interface{}]interface{}) error + func (lm *LargeMap) Scan() (map[interface{}]interface{}, error) + func (lm *LargeMap) SetCapacity(capacity int) error + func (lm *LargeMap) Size() (int, error) + type LargeObject interface + Destroy func() error + GetCapacity func() (int, error) + GetConfig func() (map[interface{}]interface{}, error) + SetCapacity func(capacity int) error + Size func() (int, error) + type LargeSet struct + func NewLargeSet(client *Client, policy *WritePolicy, key *Key, binName string, ...) *LargeSet + func (ls *LargeSet) Add(values ...interface{}) error + func (ls *LargeSet) Destroy() error + func (ls *LargeSet) Exists(value interface{}) (bool, error) + func (ls *LargeSet) Filter(filterName string, filterArgs ...interface{}) ([]interface{}, error) + func (ls *LargeSet) Get(value interface{}) (interface{}, error) + func (ls *LargeSet) GetCapacity() (int, error) + func (ls *LargeSet) GetConfig() (map[interface{}]interface{}, error) + func (ls *LargeSet) Remove(value interface{}) error + func (ls *LargeSet) Scan() ([]interface{}, error) + func (ls *LargeSet) SetCapacity(capacity int) error + func (ls *LargeSet) Size() (int, error) + type LargeStack struct + func NewLargeStack(client *Client, policy *WritePolicy, key *Key, binName string, ...) *LargeStack + func (lstk *LargeStack) Destroy() error + func (lstk *LargeStack) Filter(peekCount int, filterName string, filterArgs ...interface{}) ([]interface{}, error) + func (lstk *LargeStack) GetCapacity() (int, error) + func (lstk *LargeStack) GetConfig() (map[interface{}]interface{}, error) + func (lstk *LargeStack) Peek(peekCount int) ([]interface{}, error) + func (lstk *LargeStack) Pop(count int) ([]interface{}, error) + func (lstk *LargeStack) Push(values ...interface{}) error + func (lstk *LargeStack) Scan() ([]interface{}, error) + func (lstk *LargeStack) SetCapacity(capacity int) error + func (lstk *LargeStack) Size() (int, error) + type ListValue struct + func NewListValue(list []interface{}) *ListValue + func (vl *ListValue) GetObject() interface{} + func (vl *ListValue) GetType() int + func (vl *ListValue) String() string + type LongValue struct + func NewLongValue(value int64) *LongValue + func (vl *LongValue) GetObject() interface{} + func (vl *LongValue) GetType() int + func (vl *LongValue) String() string + type MapValue struct + func NewMapValue(vmap map[interface{}]interface{}) *MapValue + func (vl *MapValue) GetObject() interface{} + func (vl *MapValue) GetType() int + func (vl *MapValue) String() string + type Node struct + func (nd *Node) AddAlias(aliasToAdd *Host) + func (nd *Node) Close() + func (nd *Node) DecreaseHealth() + func (nd *Node) Equals(other *Node) bool + func (nd *Node) GetAliases() []*Host + func (nd *Node) GetConnection(timeout time.Duration) (conn *Connection, err error) + func (nd *Node) GetHost() *Host + func (nd *Node) GetName() string + func (nd *Node) IsActive() bool + func (nd *Node) IsUnhealthy() bool + func (nd *Node) MigrationInProgress() (bool, error) + func (nd *Node) PutConnection(conn *Connection) + func (nd *Node) Refresh() ([]*Host, error) + func (nd *Node) RestoreHealth() + func (nd *Node) String() string + func (nd *Node) WaitUntillMigrationIsFinished(timeout time.Duration) (err error) + type NodeError struct + func (ne *NodeError) Node() *Node + type NullValue struct + func NewNullValue() *NullValue + func (vl *NullValue) GetObject() interface{} + func (vl *NullValue) GetType() int + func (vl *NullValue) String() string + type Operation struct + BinName *string + BinValue Value + OpType OperationType + func AddOp(bin *Bin) *Operation + func AppendOp(bin *Bin) *Operation + func GetHeaderOp() *Operation + func GetOp() *Operation + func GetOpForBin(binName string) *Operation + func PrependOp(bin *Bin) *Operation + func PutOp(bin *Bin) *Operation + func TouchOp() *Operation + type OperationType int + var ADD OperationType = 5 + var APPEND OperationType = 9 + var PREPEND OperationType = 10 + var READ OperationType = 1 + var READ_HEADER OperationType = 1 + var TOUCH OperationType = 11 + var WRITE OperationType = 2 + type Partition struct + Namespace string + PartitionId int + func NewPartition(namespace string, partitionId int) *Partition + func NewPartitionByKey(key *Key) *Partition + func (ptn *Partition) Equals(other *Partition) bool + func (ptn *Partition) String() string + type Policy interface + GetBasePolicy func() *BasePolicy + type Priority int + const DEFAULT + const HIGH + const LOW + const MEDIUM + type QueryPolicy struct + MaxConcurrentNodes int + RecordQueueSize int + func NewQueryPolicy() *QueryPolicy + type Record struct + Bins BinMap + Duplicates []BinMap + Expiration int + Generation int + Key *Key + Node *Node + func (rc *Record) String() string + type RecordExistsAction int + const CREATE_ONLY + const REPLACE + const REPLACE_ONLY + const UPDATE + const UPDATE_ONLY + type Recordset struct + Errors chan error + Records chan *Record + func NewRecordset(size int) *Recordset + func (rcs *Recordset) Close() + func (rcs *Recordset) IsActive() bool + type RegisterTask struct + func NewRegisterTask(cluster *Cluster, packageName string) *RegisterTask + func (tskr *RegisterTask) IsDone() (bool, error) + func (tskr *RegisterTask) OnComplete() chan error + type RemoveTask struct + func NewRemoveTask(cluster *Cluster, packageName string) *RemoveTask + func (tskr *RemoveTask) IsDone() (bool, error) + func (tskr *RemoveTask) OnComplete() chan error + type ScanPolicy struct + ConcurrentNodes bool + FailOnClusterChange bool + IncludeBinData bool + MaxConcurrentNodes int + RecordQueueSize int + ScanPercent int + func NewScanPolicy() *ScanPolicy + type Statement struct + BinNames []string + Filters []*Filter + IndexName string + Namespace string + SetName string + TaskId int + func NewStatement(ns string, set string, binNames ...string) *Statement + func (stmt *Statement) Addfilter(filter *Filter) error + func (stmt *Statement) IsScan() bool + func (stmt *Statement) SetAggregateFunction(packageName string, functionName string, functionArgs []Value, returnData bool) + type StringValue struct + func NewStringValue(value string) *StringValue + func (vl *StringValue) GetObject() interface{} + func (vl *StringValue) GetType() int + func (vl *StringValue) String() string + type Task interface + IsDone func() (bool, error) + OnComplete func() chan error + type UDF struct + Filename string + Hash string + Language Language + type Value interface + GetObject func() interface{} + GetType func() int + String func() string + func NewValue(v interface{}) Value + type ValueArray struct + func NewValueArray(array []Value) *ValueArray + func ToValueArray(array []interface{}) *ValueArray + func (vl *ValueArray) GetObject() interface{} + func (vl *ValueArray) GetType() int + func (vl *ValueArray) String() string + type WritePolicy struct + Expiration int + Generation int + GenerationPolicy GenerationPolicy + RecordExistsAction RecordExistsAction + SendKey bool + func NewWritePolicy(generation, expiration int) *WritePolicy