A B C D E F G H I J K L M N O P Q R S T U V W Y Z _

G

gcd(SafeBigInt) - Method in class ostore.security.SafeBigInt
 
general_num() - Method in class ostore.agree.RingState
The member number of the general in this view.
general() - Method in class ostore.agree.RingState
Are we the general in this view?
GENERATE_CHKPT_STAGE - Static variable in class ostore.util.StageId
 
GENERATE_FRAGS_STAGE - Static variable in class ostore.util.StageId
 
GenerateChkptStage - class ostore.archive.GenerateChkptStage.
The GenerateChkptStage generates a checkpoint for a particular version.
GenerateChkptStage() - Constructor for class ostore.archive.GenerateChkptStage
 
GenerateFragsBlkReq - class ostore.archive.events.GenerateFragsBlkReq.
GenerateFragsBlkReq is an event class that generates Fragments for a block.
GenerateFragsBlkReq() - Constructor for class ostore.archive.events.GenerateFragsBlkReq
Constructor: Initializes instance variables to null.
GenerateFragsBlkReq(CacheableIdentity, int, int, int, int, CacheableIdentity, CacheablePinned, Object, SinkIF) - Constructor for class ostore.archive.events.GenerateFragsBlkReq
Constructor.
GenerateFragsBlkReq(InputBuffer) - Constructor for class ostore.archive.events.GenerateFragsBlkReq
Constructs a GenerateFragsBlkReq from its serialized form.
GenerateFragsBlkReqContinuation - class ostore.archive.events.GenerateFragsBlkReqContinuation.
GenerateFragsBlkReqContinuation is an event class that continues a suspended GenerateFragsBlkReq.
GenerateFragsBlkReqContinuation() - Constructor for class ostore.archive.events.GenerateFragsBlkReqContinuation
Constructor: Initializes instance variables to null.
GenerateFragsBlkReqContinuation(InputBuffer) - Constructor for class ostore.archive.events.GenerateFragsBlkReqContinuation
Constructs a GenerateFragsBlkReqContinuation from its serialized form.
GenerateFragsBlkReqContinuation(SecureHash) - Constructor for class ostore.archive.events.GenerateFragsBlkReqContinuation
Constructor.
GenerateFragsBlkResp - class ostore.archive.events.GenerateFragsBlkResp.
GenerateFragsBlkResp is an event class that responds to a GenerateFragsBlkReq with the CacheableIdentity of the block that has been fragmented.
GenerateFragsBlkResp() - Constructor for class ostore.archive.events.GenerateFragsBlkResp
Constructor: Initializes instance variables to null.
GenerateFragsBlkResp(CacheableIdentity, SecureHash) - Constructor for class ostore.archive.events.GenerateFragsBlkResp
Constructor.
GenerateFragsBlkResp(CacheableIdentity, SecureHash, GuidResult) - Constructor for class ostore.archive.events.GenerateFragsBlkResp
Constructor.
GenerateFragsBlkResp(InputBuffer) - Constructor for class ostore.archive.events.GenerateFragsBlkResp
Constructs a GenerateFragsBlkResp from its serialized form.
GenerateFragsChkptReq - class ostore.archive.events.GenerateFragsChkptReq.
GenerateFragsChkptReq is an event class that generates Fragments for a version of an object or checkpoints the version.
GenerateFragsChkptReq() - Constructor for class ostore.archive.events.GenerateFragsChkptReq
Constructor: Initializes instance variables to null.
GenerateFragsChkptReq(CacheableIdentity, int, int, int) - Constructor for class ostore.archive.events.GenerateFragsChkptReq
Constructor.
GenerateFragsChkptReq(CacheableIdentity, int, int, int, HandleStore) - Constructor for class ostore.archive.events.GenerateFragsChkptReq
Constructor.
GenerateFragsChkptReq(InputBuffer) - Constructor for class ostore.archive.events.GenerateFragsChkptReq
Constructs a GenerateFragsChkptReq from its serialized form.
GenerateFragsChkptResp - class ostore.archive.events.GenerateFragsChkptResp.
GenerateFragsChkptResp is an event class that responds to a GenerateFragsChkptReq with the CacheableIdentity of the root block that has been checkpointed (i.e. fragments for a version of an object has been produced).
GenerateFragsChkptResp() - Constructor for class ostore.archive.events.GenerateFragsChkptResp
Constructor: Initializes instance variables to null.
GenerateFragsChkptResp(CacheableIdentity, SecureHash, Map) - Constructor for class ostore.archive.events.GenerateFragsChkptResp
Constructor.
GenerateFragsChkptResp(InputBuffer) - Constructor for class ostore.archive.events.GenerateFragsChkptResp
Constructs a GenerateFragsChkptResp from its serialized form.
GenerateFragsReqMsg - class ostore.archive.GenerateFragsReqMsg.
GenerateFragsReqMsg is an event class that generates Fragments for a version of an object or checkpoints the version.
GenerateFragsReqMsg() - Constructor for class ostore.archive.GenerateFragsReqMsg
Constructor: Initializes instance variables to null.
GenerateFragsReqMsg(InputBuffer) - Constructor for class ostore.archive.GenerateFragsReqMsg
Constructs a GenerateFragsReqMsg from its serialized form.
GenerateFragsReqMsg(SecureHash, GenerateFragsChkptReq, SecureHash, SecureHash, Selection, Map, boolean, boolean, boolean) - Constructor for class ostore.archive.GenerateFragsReqMsg
Constructor.
GenerateFragsRespMsg - class ostore.archive.GenerateFragsRespMsg.
GenerateFragsRespMsg is an event class that generates Fragments for a version of an object or checkpoints the version.
GenerateFragsRespMsg() - Constructor for class ostore.archive.GenerateFragsRespMsg
Constructor: Initializes instance variables to null.
GenerateFragsRespMsg(InputBuffer) - Constructor for class ostore.archive.GenerateFragsRespMsg
Constructs a GenerateFragsRespMsg from its serialized form.
GenerateFragsRespMsg(SecureHash, GenerateFragsChkptResp, SecureHash, SecureHash, boolean, boolean, boolean) - Constructor for class ostore.archive.GenerateFragsRespMsg
Constructor.
GenerateFragsStage - class ostore.archive.GenerateFragsStage.
The GenerateChkptStage generates a checkpoint for a particular version.
GenerateFragsStage() - Constructor for class ostore.archive.GenerateFragsStage
 
generateKeys(int, int) - Method in class ostore.security.thresh.Dealer
Generate a group public key and l shares for a (k,l)
threshold signatures scheme
GenerateRSAKeyPair - class ostore.security.GenerateRSAKeyPair.
 
GenerateRSAKeyPair() - Constructor for class ostore.security.GenerateRSAKeyPair
 
generateTables(int) - Static method in class ostore.archive.cauchy.InitField
This routine will generate tables for the input number of Lfields and output them to stdout.
GenerateThresholdKeyShares - class ostore.security.thresh.GenerateThresholdKeyShares.
Generates a set of key shares from the command line.
GenerateThresholdKeyShares() - Constructor for class ostore.security.thresh.GenerateThresholdKeyShares
 
genkeypair(int, boolean) - Static method in class ostore.security.GenerateRSAKeyPair
Generate a key pair with the default seed.
genkeypair(int, byte[], boolean) - Static method in class ostore.security.GenerateRSAKeyPair
Generate a key pair with the following seed.
get_all_counts() - Method in class ostore.oil.Screen
Returns the current sum of all counts.
get_bid() - Method in class ostore.dtree.DTreeServiceReq
Returns the sender's priority/bid for this request.
get_block(CacheableIdentity, int, boolean) - Method in class ostore.cache.BufferCache
 
get_blocks() - Method in class ostore.read.SliceReadResp
Returns the VID->block map containing the blocks that make up the slice read.
get_blocks() - Method in class ostore.read.ReplicaSliceReadResp
Returns the VID->VerifiableBlock map containing the blocks make up the slice that was read.
get_connection_id() - Method in class ostore.network.AuthenticationMsg
Returns the address and port used by this specific connection, which may be different from the sender's contact id.
get_contact_id() - Method in class ostore.network.VirtualizedNetCert
Returns the id at which to contact the virtual node.
get_contact_id() - Method in class ostore.network.AuthenticationMsg
Returns the primary id to use to contact the sender of this message.
get_count(QuickSerializable) - Method in class ostore.oil.Screen
Returns the current count for the specified key.
get_create_req() - Method in class ostore.replica.ReplicaCreateReq
Returns the signed CreateObjectReq request from the client.
get_create_resp() - Method in class ostore.replica.ReplicaCreateResp
Returns the result of the create.
get_data() - Method in class ostore.read.ReplicaBytesReadResp
Returns the bytes read.
get_data() - Method in class ostore.read.BytesReadResp
Returns the bytes read.
get_default() - Method in class ostore.oil.Array
Returns the value that this Array should return for unknown IDs.
get_depth() - Method in class ostore.dtree.DTreeServiceResp
Returns the depth of the sender in the dissemination tree.
get_digest() - Method in class ostore.dtree.DTreeResp
Returns the digest of this DTreeResp.
get_digest() - Method in class ostore.dtree.DTreeReq
Returns the digest of this DTreeReq.
get_digest() - Method in class ostore.read.ReadResp
Returns the digest of this ReadResp.
get_digest() - Method in class ostore.read.ReadReq
Returns the digest of this ReadReq.
get_digest() - Method in class ostore.replica.ReplicaResp
Returns the digest of this ReplicaResp.
get_digest() - Method in class ostore.replica.ReplicaReq
Returns the digest of this ReplicaReq.
get_distance() - Method in class ostore.dtree.DTreeServiceResp
Returns the distance of the sender from the root of tree.
get_dtree_status() - Method in class ostore.replica.Replica
Returns the current level for dissemination tree connectivity.
get_error_code() - Method in class ostore.dtree.DTreeResp
Returns the error code.
get_error_code() - Method in class ostore.read.ReadResp
Returns the error code.
get_error_code() - Method in class ostore.replica.ReplicaResp
Returns the error code.
get_error_code() - Method in class ostore.replica.RemoteReplicaOpenResp
 
get_fault_mode() - Method in class ostore.read.ReplicaReadReq
Returns the code for the fault mode.
get_fault_mode() - Method in class ostore.read.ReadReq
Returns the code for the fault mode.
get_guid() - Method in class ostore.replica.ClientSignatureReq
Returns the AGUID for which we need the heartbeat.
get_handles() - Method in class ostore.cache.CacheUnpinRequest
Returns the array of handles to unpin.
get_hb() - Method in class ostore.replica.ReplicaOpenResp
Returns the most recent available Heartbeat for the replica (null if request was unsuccessful).
get_hb() - Method in class ostore.replica.Replica
Returns the most recent Heartbeat for this Replica.
get_hb() - Method in class ostore.replica.RemoteReplicaOpenResp
 
get_high() - Method in class ostore.read.NumberPredicate
Returns the highest accaptable sequence number;
get_high() - Method in class ostore.read.HeadPredicate
Returns the latest accaptable "head" date;
get_high() - Method in class ostore.read.DatePredicate
Returns the latest accaptable creation date;
get_id() - Method in class ostore.replica.RemoteReplicaOpenResp
 
get_id() - Method in class ostore.util.VID
Returns the VHash, VGUID, or GUID, as appropriate.
get_initial_update() - Method in class ostore.replica.ReplicaCreateReq
Return the initial update, null if none
get_initial_vhash() - Method in class ostore.replica.ReplicaCreateResp
Returns the VHASH of the intial version of the object.
get_lease() - Method in class ostore.dtree.DTreeServiceReq
Returns the number of bytes that the parent must send under this service agreement.
get_local_flag() - Method in class ostore.replica.Replica
Returns the current value of the local_only flag.
get_low() - Method in class ostore.read.NumberPredicate
Returns the lowest accaptable sequence number;
get_low() - Method in class ostore.read.HeadPredicate
Returns the earliest accaptable "head" date;
get_low() - Method in class ostore.read.DatePredicate
Returns the earliest accaptable creation date;
get_max_distance() - Method in class ostore.dtree.DTreeServiceReq
Returns the maximum acceptable distance from the sender to the root of tree.
get_metadata() - Method in class ostore.read.ReplicaMetadataReadResp
Returns the Metadata from a version of the specified replica, or null.
get_metadata(VID) - Method in class ostore.replica.Replica
Returns the Metadata object for the specified version, or null for unknown versions.
get_missing() - Method in class ostore.read.ReplicaReadResp
Returns the Selection which describes the portion of the Replica that was not successfuly read.
get_missing() - Method in class ostore.read.ReadResp
Returns the Selection which describes the portion of the DataObject that was not successfuly read.
get_next_message_buffer() - Method in class ostore.network.ConnectionStream
 
get_next() - Method in class ostore.cache.CachePolicy.Line
 
get_open_flag() - Method in class ostore.replica.Replica
Returns the current value of the open_locally flag.
get_predicate() - Method in class ostore.read.ReplicaReadReq
Returns the predicate specifying which version(s) of the Replica (a DataObject) to read.
get_prev() - Method in class ostore.cache.CachePolicy.Line
 
get_primary_flag() - Method in class ostore.replica.Replica
Returns the current value of the is_primary flag.
get_publish_flag() - Method in class ostore.dtree.JoinTreeReq
Returns true iff the local server wishes to publish itself as an available secondary replica in the tree.
get_publish_flag() - Method in class ostore.replica.ReplicaOpenReq
Returns true iff the local server wishes to publish itself as an available secondary replica in the tree.
get_read() - Method in class ostore.read.ReplicaReadResp
Returns the Selection which describes the portion of the Replica that was read.
get_read() - Method in class ostore.read.ReadResp
Returns the Selection which describes the portion of the DataObject that was read.
get_req_digest() - Method in class ostore.dtree.DTreeResp
Returns the digest of the corresponding DTreeReq.
get_req_digest() - Method in class ostore.read.ReadResp
Returns the digest over the corresponding ReadReq.
get_req_digest() - Method in class ostore.replica.ReplicaResp
Returns the digest of the corresponding ReplicaReq.
get_req_digest() - Method in class ostore.replica.ClientSignatureReq
Returns the digest of the original ReplicaReq which triggered this request.
get_req_seq_num() - Method in class ostore.read.ReadResp
Returns the sequence number of the request that generated this result.
get_requested_state() - Method in class ostore.dtree.DTreeServiceReq
Returns the connection state that the sender wants.
get_segment(QuickSerializable) - Method in class ostore.introspect.SemanticDistanceModel
Obtain a segment that contains the distance information between id and other types.
get_selection() - Method in class ostore.read.ReplicaReadReq
Returns the Selection describing the read.
get_selection() - Method in class ostore.read.ReadReq
Returns the Selection describing the read.
get_sender() - Method in class ostore.dtree.DTreeServiceReq
Returns the sender's GUID.
get_seq_num() - Method in class ostore.dtree.DTreeReq
Returns the sequence number of the request.
get_seq_num() - Method in class ostore.read.ReadReq
Returns the sequence number of the request.
get_seq_num() - Method in class ostore.replica.ReplicaReq
Returns the sequence number of the request.
get_signed_guid_hb() - Method in class ostore.replica.Replica
Returns the most recent signed Heartbeat received for this Replica that contains a valid Heartbeat.vguid field.
get_signed_hb() - Method in class ostore.dtree.JoinTreeResp
Returns the most recent heartbeat for the tree's data object, signed.
get_signed_hb() - Method in class ostore.dtree.DTreeServiceResp
Returns the most recent heartbeat for the tree's data object, signed.
get_signed_hb() - Method in class ostore.replica.Replica
Returns the most recent signed Heartbeat received for this Replica.
get_signed_resp() - Method in class ostore.dtree.JoinTreeResp
Returns signed CreateObjectResp containing the certificates required to check signatures on objects sent down the new tree.
get_signed_resp() - Method in class ostore.dtree.DTreeServiceResp
Returns signed CreateObjectResp containing the certificates required to check signatures on objects sent down the new tree.
get_signed_resp() - Method in class ostore.dtree.CreateTreeReq
Returns the signed CreateObjectResp that contains the certificates necessary to verify the signatures of the messages that will be sent down the new tree.
get_spares() - Method in class ostore.read.HandleStoreReadReq
Returns the VID->block map that contains extra blocks that the ReadStage may use in addition to those found in the memory cache.
get_spares() - Method in class ostore.read.BytesReadReq
Returns the VID->block map that contains extra blocks that the ReadStage may use in addition to those found in the memory cache.
get_success() - Method in class ostore.replica.RemoteReplicaOpenResp
 
get_target() - Method in class ostore.read.ReadReq
Returns the id of the DataObject to read.
get_target() - Method in class ostore.replica.ReplicaResp
Returns the AGUID from the original request.
get_target() - Method in class ostore.replica.RemoteReplicaOpenResp
 
get_target() - Method in class ostore.replica.ReplicaReq
Returns the AGUID of the Replica on which to operate.
get_timestamp() - Method in class ostore.replica.ClientSignatureReq
Returns the earliest acceptable heartbeat timestamp.
get_tree_id() - Method in class ostore.dtree.DTreeResp
Returns the name of the dissemination tree from the original request.
get_tree_id() - Method in class ostore.dtree.DTreeReq
Returns the name of the dissemination tree on which to operate.
get_tree_id() - Method in class ostore.read.ReadReq
Returns the GUID of the dissemination tree for the DataObject to read.
get_type() - Method in class ostore.util.VID
Returns the type of identifier for this VID.
get_update_resp() - Method in class ostore.replica.ReplicaUpdateResp
Returns the result of the update.
get_update() - Method in class ostore.replica.ReplicaUpdateReq
Returns the signed Update request from the client.
get_version() - Method in class ostore.read.ReplicaReadResp
Returns id for the version of the Replica that was read.
get_vid() - Method in class ostore.read.VIDPredicate
Returns the id of the desired version.
get_virtual_node_id() - Method in class ostore.network.VirtualizedNetCert
Returns the id of the virtual node.
get_virtualized_net_certs() - Method in class ostore.network.AuthenticationMsg
Returns an array of VirtualizedNetCert objects.
get(CacheableIdentity) - Method in class ostore.cache.BufferCache
 
get(int) - Method in class ostore.cache.CacheableIdentity
return the object associated with type where type is one of the globally defined types above (ie GUID, VHASH...)
get(int) - Method in class ostore.client.OSMetadata
 
get(int) - Method in class ostore.dataobj.Metadata
Retrieve an element from Metadata
get(int) - Method in class ostore.util.QSVector
Return the object at the specified index.
get(int) - Method in class ostore.util.QSArray
 
get(int) - Method in class ostore.util.IntHashtable
Returns the value to which the specified key is mapped in this hashtable.
get(Object) - Method in class ostore.util.LruMap
Specified by java.util.Map
get(Object) - Method in class ostore.util.MultiMap
 
get(QuickSerializable) - Method in class ostore.oil.Matrix
Returns the Array indexed by the specified ID.
get(QuickSerializable) - Method in class ostore.oil.Array
Returns the value indexed by the specified ID, or the default element if no such value exists.
get(QuickSerializable) - Method in class ostore.util.QSHashMap
Returns the object mapped to the given key in this map if it is present.
get(SecureHash) - Method in class ostore.archive.ArchiveObjBucket
get returns an entry from the block map that matches the key.
get(String) - Method in class ostore.client.OSMetadata
 
get(String) - Method in class ostore.dataobj.Metadata
Retrieve an element from Metadata
getAck() - Method in class ostore.apps.qtree.impl.QTreeGroupMsgAck
 
getAcks() - Method in class ostore.archive.dissemination.DisseminateFragAckMsg
getAcks returns the acks to the DisseminateFragMsg.
getAcksRecv(int) - Method in class ostore.archive.FragmentBucket
getAcksRecv return true if fragment at given index has been received; otherwise, false.
getAcksRecv(int) - Method in interface ostore.archive.DisseminatableBucket
getAcksRecv return true if disseminatable at given index has been received; otherwise, false.
getActionAt(int) - Method in class ostore.update.UpdateTuple
Returns the action at the given index in this tuple.
getActionNumber() - Method in class ostore.update.UpdateContinuation
 
getActions() - Method in class ostore.client.OSUpdateTuple
Returns a vector of the tuple's actions.
getActions() - Method in class ostore.update.UpdateTuple
Returns the actions in this tuple.
getAge() - Method in class ostore.introspect.SemanticDistanceModel.Segment
Get the age
getAguid() - Method in class ostore.archive.RequestFragMsg
getAguid returns the aguid associated with the request.
getAguid() - Method in class ostore.archive.GenerateFragsRespMsg
getAguid returns the A-GUID of the object.
getAguid() - Method in class ostore.archive.GenerateFragsReqMsg
getAguid returns the A-GUID of the object.
getAguid() - Method in class ostore.cache.CachePinnedRequest.Local
getAguid returns A-GUID of the object that the block belongs.
getAguid() - Method in class ostore.cache.CachePinnedRequest
getAguid returns A-GUID of the object that the block belongs.
getAguid() - Method in class ostore.cache.CacheBlockRequestMessage
getAguid returns A-GUID of the object that the block belongs.
getAguid() - Method in class ostore.client.OSRead
 
getAguid() - Method in class ostore.client.OSOpenReplicaResult
Returns the aguid of the replica that was opened.
getAguid() - Method in class ostore.client.OSOpenReplicaRequest
 
getAguid() - Method in class ostore.client.OSMetadataResult
 
getAguid() - Method in class ostore.client.OSCreateObjectResult
Returns the Aguid of the new data object.
getAguid() - Method in class ostore.client.OSCreateObjectRequest
Returns the Aguid of the data object to be created.
getAguid() - Method in class ostore.client.OSCloseReplicaResult
Returns the aguid of the replica that was closed.
getAguid() - Method in class ostore.client.OSCloseReplicaRequest
 
getAguid() - Method in class ostore.client.OSReadResult
 
getAguid() - Method in class ostore.replica.RemoteReplicaProbe
 
getAguid() - Method in class ostore.rp.InnerRingKeyRespMsg
 
getAguid() - Method in class ostore.archive.events.UpdateVerifiableBlocksResp
getAguid returns the A-GUID of the object.
getAguid() - Method in class ostore.archive.events.UpdateVerifiableBlocksReq
getAguid returns the A-GUID of the object.
getAguid() - Method in class ostore.archive.dissemination.DisseminateFragMsg
getAguid returns the aguid that matches the object that the dissemintables belong.
getAguid() - Method in class ostore.archive.dissemination.DisseminateFragAckMsg
getAguid returns the aguid that matches the object that was disseminated.
getAlgorithm() - Method in class ostore.security.thresh.ThresholdPublicKey
 
getAlgorithmEncoding() - Method in class ostore.security.RawNativeRSASignature_PKCS1_SHA1
 
getAlgorithmEncoding() - Method in class ostore.security.NativeRSASignature_PKCS1_SHA1
 
getAppId() - Method in class ostore.client.OSRequest
Returns the OSAppId that identifies the requesting application.
getAppId() - Method in class ostore.client.OSResult
Returns the OSAppId that identifies the requesting application.
getArchiveInterpretFlag() - Method in class ostore.archive.FragmentBucket
returns archive interpret decoded block flag.
GETATTR - Static variable in class ostore.apps.traces.TraceIterator
 
getAvailability() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getAvailability returns minimum threshold of availability for a node in the dissemination set.
getBIT(int) - Static method in class ostore.archive.cauchy.InitField
Retreve the BIT table for the input Lfield.
getBlkBuckets() - Method in class ostore.archive.ArchiveObjBucket
getBlkBuckets returns the block map.
getBlock() - Method in class ostore.cache.CachePinnedReply.Local
return the cacheable requested
getBlock() - Method in class ostore.cache.CachePinnedReply
return the cacheable requested
getBlock() - Method in class ostore.cache.CacheInsertMessage
 
getBlock() - Method in class ostore.cache.CacheBlockReplyMessage
return the cacheable requested
getBlock() - Method in class ostore.dtree.RemoteCacheReplyMessage
 
getBlockIds() - Method in class ostore.archive.ArchiveObjBucket
getBlockIds returns a map of fhash's created from the GenerateFragsStage.
getBlockIds() - Method in class ostore.archive.events.UpdateVerifiableBlocksReq
getBlockIds returns a VHASH->FHASH Map containing the blockIds(vhashes) that make up the slice of the of modified and Fragmented blocks of an object.
getBlockInProgress() - Method in class ostore.dataobj.DataObjectReplaceException
 
getBlockInProgress() - Method in class ostore.dataobj.DataObjectAppendException
 
getBlockNumber() - Method in class ostore.dataobj.DataObjectReadSliceException
 
getBlocks() - Method in class ostore.archive.GenerateFragsReqMsg
getBlocks returns the SortedMap that contains the slice of the object.
getBlocks() - Method in class ostore.cache.CacheFullException
 
getBlockSize() - Method in class ostore.archive.Fragment
Gets the block_size of this Fragment.
getBlockSize() - Method in class ostore.archive.ArchiveObjBucket
getBlockSize returns the block size used for each block, except the topblock can be larger or smaller.
getBlockSize() - Method in class ostore.cache.CacheFullException
 
getBlockSize() - Method in class ostore.dataobj.Btree
 
getBlockSize(int, int, int) - Method in class ostore.archive.Erasure
getBlockSize returns the message size corresponding to the input blockSize, numFragments, and inverseRate.
getBlockSize(int, int, int) - Method in class ostore.archive.cauchy.Cauchy
getBlockSize returns the message size corresponding to the input block size.
getBlockSize(int, int, int) - Method in class ostore.archive.interleaved.Interleaved
returns the message size corresponding to the input block size NOTE: this function assumes encodeSize has already been set
getBlockSize(int, int, int, int) - Static method in class ostore.archive.Erasure
getBlockSize computes the block size corresponding to the input blocksize, numFragments, inverseRate, and erasureType.
getBlockType() - Method in class ostore.archive.FragmentBucket
getBlockType returns the type of block that we are encoding or decoding.
getBlockVHash() - Method in class ostore.archive.Fragment
Get the hash of the corresponding block in the verification information.
getBound() - Method in class ostore.introspect.SemanticDistanceModel.BoundedPrioQueue
Get the max number of elements allowed in the queue.
getBranch() - Method in class ostore.client.OSCreateObjectRequest
 
getBranchAGUID() - Method in class ostore.client.OSCreateObjectRequest
 
getBranchVGUID() - Method in class ostore.client.OSCreateObjectRequest
 
getBtree() - Method in class ostore.dataobj.DataObject
Returns the btree containing the data of the object.
getBucket(Object) - Static method in class ostore.archive.Fragment
 
getBytes() - Method in class ostore.security.thresh.SigShare
Return a byte array representation of this signature
getBytesInProgress() - Method in class ostore.dataobj.DataObjectReplaceException
 
getBytesInProgress() - Method in class ostore.dataobj.DataObjectAppendException
 
getBytesRead() - Method in class ostore.dataobj.DataObjectReadException
 
getBytesWritten() - Method in class ostore.dataobj.DataObjectReplaceException
 
getBytesWritten() - Method in class ostore.dataobj.DataObjectAppendException
 
getC() - Method in class ostore.security.thresh.Verifier
 
getCache() - Method in class ostore.cache.CacheManager.CacheAvailable
getCache returns a reference to the cache.
getCacheables() - Method in class ostore.cache.CacheAssignRequest
Returns the array of cacheables to assign.
getCacheables() - Method in class ostore.cache.CacheAssignReply
Returns the array of cacheables from the original CacheAssignRequest.
getCacheException() - Method in class ostore.dataobj.DataObjectException
 
getCacheType() - Method in class ostore.cache.CacheReserveSpaceMessage
return the cacheType of cache that needs to be used to respond to request.
getCardinality() - Method in class ostore.archive.RequestFragQueryState
getCardinality returns the number of back pointers pursued for a fragment or block.
getChild() - Method in class ostore.apps.qtree.impl.QTreeCloseMsgAck
 
getChild() - Method in class ostore.apps.qtree.impl.QTreeGroupMsgAck
 
getChild(int, HandleStore, DataCache) - Method in class ostore.dataobj.Btree.InteriorNode
 
getChildGuid(int) - Method in class ostore.dataobj.Btree.InteriorNode
 
getChildren(SecureHash) - Method in class ostore.apps.qtree.impl.QTree
 
getChildVhash(int) - Method in class ostore.dataobj.Btree.InteriorNode
 
getChkpt() - Method in class ostore.archive.ArchiveObjBucket
getChkpt returns the guid of the checkpoint.
getClassification() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getClassification returns classification constraint that the dissemination set needs to satifsfy.
getClassifier(NodeId) - Static method in class ostore.dispatch.Classifier
Returns the Classifier instance corresponding to a NodeId.
getClient() - Method in class ostore.update.Update
Return the hash of the client machine from which the update originated.
getClients() - Method in class ostore.introspect.SemanticDistanceModel.Table
Get the number of clients represented by this model.
getClients() - Method in class ostore.introspect.SemanticDistanceModel.Segment
Get the number of clients represented
getClients() - Method in class ostore.introspect.SemanticDistanceModel
Get the number of clients represented by this model.
getCodeHandlerTimeSquareSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSquareSum return total square sum time coding the current object.
getCodeHandlerTimeSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSum return total sum time coding the current object.
getCodeMethodTimeSquareSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSquareSum return total square sum time coding the current object.
getCodeMethodTimeSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSum return total sum time coding the current object.
getCodeTime() - Method in class ostore.archive.ArchiveObjBucket
getCodeTime return total coding time of the current object.
getCodeTimeCount() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeCount return total count of times summed together.
getCodeTimeSquareSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSquareSum return total square sum time coding the current object.
getCodeTimeSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSum return total sum time coding the current object.
getCodeTotalTimeSquareSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSquareSum return total square sum time coding the current object.
getCodeTotalTimeSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSum return total sum time coding the current object.
getCodeVHashTreeTimeSquareSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSquareSum return total square sum time coding the current object.
getCodeVHashTreeTimeSum() - Method in class ostore.archive.ArchiveObjBucket
getCodeTimeSum return total sum time coding the current object.
getCOLBIT(int) - Static method in class ostore.archive.cauchy.InitField
Retrieve the COLBIT table for the input Lfield.
getCommit() - Method in class ostore.archive.ArchiveObjBucket
 
getCommit() - Method in class ostore.client.OSUpdateResult
Returns an indication of whether the update committed or aborted.
getCommitted() - Method in class ostore.update.UpdateResult
Returns whether the update committed.
getCompare() - Method in class ostore.update.PredicateCompareBytes
The bytes we are comparing to
getData() - Method in class ostore.archive.Fragment
getData returns the Fragment in byte array form.
getData() - Method in class ostore.client.OSActionReplace
Returns the data that this update replaces.
getData() - Method in class ostore.client.OSActionAppend
Returns the data that this update appends.
getData() - Method in class ostore.client.OSReadResult
 
getData() - Method in class ostore.dataobj.DataObject.DataBlock
 
getData() - Method in class ostore.apps.traces.TraceObject
Returns a human-readable representation of this ReplicaReq.
getData(byte[], int, int, int) - Method in class ostore.archive.Fragment
Gets a portion of this Fragment's data.
getDataBuffer() - Method in class ostore.dataobj.DataObjectReplaceException
 
getDataBuffer() - Method in class ostore.dataobj.DataObjectAppendException
 
getDataLength() - Method in class ostore.archive.Fragment
Calculates and returns the length of a fragment's data in bytes (not including the index), based on block_size, numFrags, and rate.
getDataObjectException() - Method in class ostore.update.UpdateContinuation
 
getDispatchTime() - Method in class ostore.client.OSRequest
Returns the time (as recorded by System.currentTimeMillis()) that this request was dispatched from the ClientStage.
getDiss() - Method in class ostore.cache.TestBlock
 
getDissBucket() - Method in class ostore.cache.TestBlock
 
getDisseminatable(int) - Method in class ostore.archive.FragmentBucket
Retrieve a single Disseminatable object
getDisseminatable(int) - Method in interface ostore.archive.DisseminatableBucket
getDisseminatable returns a single Disseminatable at the specified index.
getDisseminatables() - Method in class ostore.archive.dissemination.DisseminateFragMsg
getDisseminatables returns the guid->disseminatable map containing the disseminatables that make up an archived object version.
getDisseminateBucket() - Method in class ostore.archive.ArchiveObjBucket
getDisseminateBucket returns a map of dissemination buckets to disseminate.
getDisseminateGuid() - Method in class ostore.archive.ArchiveObjBucket
getDisseminateGuid returns a map of guid's for dissemination buckets to disseminate and their block types.
getDisseminationSets() - Method in class ostore.archive.dissemination.RequestDisseminationSetResponseMsg
getDisseminationSets returns the dissemination sets.
getDistance() - Method in class ostore.introspect.SemanticDistanceModel.Tuple
Get the distance value.
getDistance(QuickSerializable) - Method in class ostore.introspect.SemanticDistanceModel.BoundedPrioQueue
Get the distance value to type to.
getDistance(QuickSerializable, QuickSerializable) - Method in class ostore.introspect.SemanticDistanceModel.Table
Get the distance between observations from and to.
getDistances(QuickSerializable) - Method in class ostore.introspect.SemanticDistanceModel.Table
Get a sorted iterator of the distances between from and other types.
getDomain() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getDomain returns domain constraint that the dissemination set needs to satifsfy.
getDtreeId() - Method in class ostore.dtree.RemoteCacheRequestMessage
 
getEncoded() - Method in class ostore.mac.STSVerify
 
getEncoded() - Method in class ostore.security.thresh.ThresholdPublicKey
 
getEncodeType() - Method in class ostore.archive.Fragment
Gets the encodeType.
getEncodeType() - Method in class ostore.archive.Erasure
getEncodeType returns the encode type of this Erasure coder.
getEncodeType() - Method in class ostore.archive.cauchy.Cauchy
getEncodeType returns the encode type of this Erasure coder.
getEncodeType() - Method in class ostore.archive.interleaved.Interleaved
returns the encode type of this Erasure coder
getEncrypt() - Method in class ostore.client.OSUpdate
Returns the value of the encryption flag.
getEndTime() - Method in class ostore.archive.FragmentBucket
getEndTime returns the time the Bucket was destroyed(removed from table).
getEndTime() - Method in interface ostore.archive.DisseminatableBucket
getEndTime returns the time the Bucket was destroyed (i.e. removed from table).
getEndTime() - Method in class ostore.archive.ArchiveObjBucket
getEndTime return the endTime of the archiving or recoalescing process.
getErasure(Erasure, int, int, int, int, boolean, NodeId, SecureHash) - Static method in class ostore.archive.Erasure
getErasure creates and initializes a new Erasure coder if the current passed in one is null or does not support the correct blockSize; otherwise, getErasure will return the original Erasure coder unchanged.
getErasureType() - Method in class ostore.archive.ArchiveObjBucket
getErasureType returns the type of erasure code to use.
getErrorCode() - Method in class ostore.client.OSVIDResult
 
getErrorCode() - Method in class ostore.client.OSMetadataResult
 
getErrorCode() - Method in class ostore.client.OSCloseReplicaResult
Returns the error code that describes why the request failed.
getErrorCode() - Method in class ostore.client.OSReadResult
 
getErrorCode() - Method in class ostore.util.QueueElementRespIF
getErrorCode returns the error code.
getExptoFE(int) - Static method in class ostore.archive.cauchy.InitField
Retreve the ExptoFE table for the input Lfield.
getFEtoExp(int) - Static method in class ostore.archive.cauchy.InitField
Retreve the FEtoExp table for the input Lfield.
getFhash() - Method in class ostore.dataobj.DataObject.DataBlock
 
getFhash() - Method in class ostore.dataobj.Btree.InteriorNode
 
getFhash() - Method in class ostore.dataobj.DataObject
 
getFhash() - Method in class ostore.dataobj.Btree
 
getFhash() - Method in interface ostore.util.VerifiableBlock
Return the secure hash at the root of the verification tree constructed from the erasure-encoded fragments of a block.
getFHash() - Method in class ostore.archive.Fragment
Get the hash of the corresponding to the top of the fragment vhash tree (hash adjacent to blockVHash.
getField() - Method in class ostore.client.OSActionSetMetadata
Returns the name of the metadata field to be modified.
getFilter() - Method in class ostore.introspect.SemanticDistanceModel.Delta
Get the filter used for this delta's computations
getFilter() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getFilter returns an application filter summarizing the applications that hosts must export.
getFirstTarget() - Method in class ostore.update.Update
 
getFormat() - Method in class ostore.security.thresh.ThresholdPublicKey
 
getFragment(int) - Method in class ostore.archive.FragmentBucket
Retrieve a single Disseminatable object
getFragmentArrayLength() - Method in class ostore.archive.Erasure
getFragmentArrayLength returns the length of the Fragment array divisible by Erasure.sizeOfLong.
getFragmentArrayLength() - Method in class ostore.archive.cauchy.Cauchy
 
getFragmentArrayLength() - Method in class ostore.archive.interleaved.Interleaved
 
getFromMetadata(int) - Method in class ostore.dataobj.DataObject
 
getFromMetadata(String) - Method in class ostore.dataobj.DataObject
 
getGeometricMean() - Method in class ostore.util.StatRecorder
 
getGroupKey() - Method in class ostore.security.thresh.Dealer
Returns the group key
getGroupVerifier() - Method in class ostore.security.thresh.Verifier
 
getGuid() - Method in class ostore.archive.FragmentBucket
Get GUID that is the name of the diss objects in this bucket.
getGuid() - Method in interface ostore.archive.DisseminatableBucket
getGuid returns the GUID that is the name of the Disseminatables in this bucket.
getGuid() - Method in class ostore.cache.TestBlock
 
getGuid() - Method in class ostore.apps.qtree.api.QTreeStateMsg
 
getGuid() - Method in class ostore.apps.qtree.impl.QTreeCloseMsgAck
 
getHandle() - Method in class ostore.cache.CachePinnedReply.Local
return the CacheablePinned for the Cacheable requested (null if the request could not be satisfied)
getHandle() - Method in class ostore.cache.CachePinnedReply
return the CacheablePinned for the Cacheable requested (null if the request could not be satisfied)
getHandle() - Method in class ostore.cache.CacheInsertDone
 
getHandle() - Method in class ostore.cache.CacheBlockReplyMessage
return the CacheableHandle for the Cacheable requested
getHandle() - Method in class ostore.archive.events.ReconstructBlkResp
getHandle returns the handle associated with the blockId.
getHandles() - Method in class ostore.cache.CacheAssignRequest
Returns the array of handles to be assigned.
getHandles() - Method in class ostore.cache.CacheAssignReply
Returns the array of handles from the original CacheAssignRequest.
getHandleStore() - Method in class ostore.archive.ArchiveObjBucket
getHandleStore returns the handleStore that stores all the handles for blocks being archived.
getHandleStore() - Method in class ostore.read.HandleStoreReadResp
Returns the VID->block map containing the blocks that make up the slice read.
getHandleStore() - Method in class ostore.archive.events.GenerateFragsChkptReq
getHandleStore returns the HandleStore of VerifiableBlocks to Fragment.
getHashMap() - Method in class ostore.util.QSHashMap
 
getHeartbeatMap() - Method in class ostore.client.OSUpdateResult
 
getHistogram() - Method in class ostore.util.StatRecorder
 
getHistogram(int) - Method in class ostore.util.StatRecorder
 
getId() - Method in class ostore.cache.CacheNotify
getId returns the id stored in the CacheNotify.
getId() - Method in class ostore.cache.CacheMissException
 
getId() - Method in class ostore.cache.CacheDeleteItem
 
getId() - Method in class ostore.cache.CacheDeleteConfirm
 
getId() - Method in class ostore.security.thresh.KeyShare
 
getId() - Method in class ostore.security.thresh.SigShare
Return this share's id.
getId() - Method in class ostore.apps.qtree.impl.QTreeUpMsgAck
 
getID() - Method in class ostore.cache.CachePinnedReply.Local
return the CacheableIdentity stored in the CachePinnedReply
getID() - Method in class ostore.cache.CachePinnedRequest.Local
return the CacheableIdentity id
getID() - Method in class ostore.cache.CacheablePinned
returns true if the cached object has an id (CacheableIdentity)
getID() - Method in class ostore.cache.CachePinnedRequest
 
getID() - Method in class ostore.cache.CachePinnedReply
return the CacheableIdentity stored in the CachePinnedReply
getID() - Method in class ostore.cache.CacheInsertMessage
 
getID() - Method in class ostore.cache.CacheInsertDone
 
getID() - Method in class ostore.cache.CacheBlockRequestMessage
 
getID() - Method in class ostore.cache.CacheBlockReplyMessage
return the CacheableIdentity stored in the CacheBlockReplyMessage
getIdentifier() - Method in class ostore.archive.RequestFragMsg
getIdentifier returns the identifier; a unique id of node (i.e. nodeGuid) or app (e.g.
getIdentifier() - Method in class ostore.archive.GenerateFragsRespMsg
getIdentifier returns the unique id of node (i.e. nodeGuid) or app (e.g.
getIdentifier() - Method in class ostore.archive.GenerateFragsReqMsg
getIdentifier returns the unique id of node (i.e. nodeGuid) or app (e.g.
getIdentifier() - Method in class ostore.archive.ArchiverLocateRespMsg
getIdentifier returns the identifier.
getIdentifier() - Method in class ostore.archive.ArchiverLocateReqMsg
getIdentifier returns the identifier.
getIdentifier() - Method in class ostore.archive.dissemination.RequestDisseminationSetResponseMsg
getIdentifier returns the identifier.
getIdentifier() - Method in class ostore.archive.dissemination.RequestDisseminationSetMsg
getIdentifier returns the identifier.
getIdentifiers() - Method in class ostore.cache.CacheAssignRequest
Returns the array of identifiers to assign.
getIdentifiers() - Method in class ostore.cache.CacheAssignReply
Returns the array of identifiers from the original CacheAssignRequest.
getIndex() - Method in class ostore.archive.Fragment
 
getIndex() - Method in interface ostore.archive.Disseminatable
getIndex get the index of this object.
getIndex() - Method in class ostore.archive.dissemination.DisseminateFragMsg
getIndex returns the index of disseminatable being acknowledged.
getIndex() - Method in class ostore.archive.dissemination.DisseminateFragAckMsg
getIndex returns the index of disseminatable being acknowledged.
getInitialUpdate() - Method in class ostore.client.OSCreateObjectRequest
Compile (if necessary) and return the initial_update action array for this create request.
getInlinedData() - Method in class ostore.dataobj.DataObject
Returns the inlined data.
getInstance() - Static method in class ostore.client.ClientCryptModule
 
getInstance(NodeId) - Static method in class ostore.archive.GenerateFragsStage
getInstance returns the SinkIF associated with the given node_id.
getInstance(NodeId) - Static method in class ostore.cache.LRUCache
return an instance of the cache and initialize the database if we are not using java io.
getInstance(NodeId) - Static method in class ostore.util.StopWatch
Returns the StopWatch instance corresponding to a NodeId.
getInstance(SecureHash) - Static method in class ostore.mac.HMACDHHandler
Return the HMACDHHandler associated with a particular guid.
getInverseRate() - Method in class ostore.archive.Fragment
Gets the rate field from this fragment.
getInverseRate() - Method in class ostore.archive.Erasure
getOmverseRate returns the inverse rate of encoding.
getInverseRate() - Method in class ostore.archive.ArchiveObjBucket
getInverseRate returns the inverse rate of encoding.
getIRGuid() - Method in class ostore.client.OSCreateObjectResult
Returns the guid that identifies the inner ring that is maintaining the new data object.
getIRKey() - Method in class ostore.rp.InnerRingKeyRespMsg
 
getKey() - Method in class ostore.dataobj.KeyedSelection
The key which selects a subtree from the top-level btree.
getKey() - Method in class ostore.introspect.SemanticDistanceModel.Tuple
Get the observation type.
getKey(int) - Method in class ostore.dataobj.Btree.InteriorNode
 
getKeys() - Method in class ostore.introspect.SemanticDistanceModel.Table
Get the set of all observation types known.
getLength() - Method in class ostore.archive.FragmentBucket
Retrieve the total capacity of this bucket.
getLength() - Method in interface ostore.archive.DisseminatableBucket
getLength return the total capacity of this bucket.
getLength() - Method in class ostore.archive.ArchiveObjBucket
getLength returns the number of data bytes to read.
getLength() - Method in class ostore.client.OSActionReplace
Returns the number of bytes that this update replaces.
getLength() - Method in class ostore.client.OSActionExpand
Returns the length to which the action will expand the data object.
getLength() - Method in class ostore.client.OSActionAppend
Returns the number of bytes that this update appends.
getLength() - Method in class ostore.dataobj.Range
The number of bytes to include.
getLength() - Method in class ostore.update.ActionTruncate
getLength returns the length of the ActionTruncate.
getLength() - Method in class ostore.update.ActionSetMetadata
getLength returns the length of the ActionSetMetadata.
getLength() - Method in class ostore.update.ActionReplaceBlocks
getLength returns the length of the ActionReplaceBlocks.
getLength() - Method in class ostore.update.ActionExpand
getLength returns the length of the ActionExpand.
getLength() - Method in class ostore.update.ActionAppendBlocks
getLength returns the length of the ActionAppendBlocks.
getLength() - Method in class ostore.update.Action
Return the length of data modified (in bytes).
getLength() - Method in class ostore.apps.traces.TraceObject
Returns a human-readable representation of this ReplicaReq.
getLifetime() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getLifetime returns minimum threshold of lifetime (in us) for a node in the dissemination set.
getLocation() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getLocation returns location constraint that the dissemination set needs to satifsfy.
getMap() - Method in class ostore.update.UpdateResult
Returns the map from Aguid to Vhash for all objects modified by the update.
getMap() - Method in class ostore.update.UpdateRequest
Returns the mapping from Aguid to version identifier (either Vhash or Vguid) for all objects that may be accessed by the update.
getMax() - Method in class ostore.util.StatRecorder
 
getMaxNumNodes() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getMaxNumNodes returns the maximum number of nodes requested to be returned; that is, size of the returned dissemination set.
getMean() - Method in class ostore.util.StatRecorder
 
getMedian() - Method in class ostore.util.StatRecorder
 
getMemoryHandle() - Method in class ostore.update.UpdateContinuation
 
getMessage() - Method in class ostore.apps.test.TputMicroBenchmarkMessage
 
getMessage() - Method in class ostore.apps.test.TagMicroBenchmarkMessage
 
getMessage() - Method in class ostore.apps.test.StreamMicroBenchmarkMessage
 
getMetadata() - Method in class ostore.client.OSMetadataResult
 
getMetadata() - Method in class ostore.dataobj.DataObject
 
getMin() - Method in class ostore.util.StatRecorder
 
getMinNumNodes() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getMinNumNodes returns the minimum number of nodes requested to be returned; that is, size of the returned dissemination set.
getMissingSelection() - Method in class ostore.client.OSReadResult
 
getModifiedDataObjects() - Method in class ostore.update.VersionHandleCache
Returns an enumeration of all data objects for which this object stores a pinned cache handle.
getModifiedVHash(SecureHash) - Method in class ostore.archive.ArchiveObjBucket
getModifiedVHash returns the Object (i.e. pending block) associated with guid.
getModifiedVHashes() - Method in class ostore.archive.ArchiveObjBucket
getModifiedVHashes returns a map of modified vhashes.
getMsg(int) - Method in class ostore.archive.Erasure
getMsg initializes array message with a fake message (string of bytes) up to len bytes long.
getMsgArrayLength() - Method in class ostore.archive.Erasure
getMsgArrayLength returns the length of the msg array divisible by Erasure.sizeOfLong.
getMsgArrayLength() - Method in class ostore.archive.cauchy.Cauchy
 
getMsgArrayLength() - Method in class ostore.archive.interleaved.Interleaved
 
getNackCount() - Method in class ostore.archive.FragmentBucket
getNackCount returns the number of NACK's received.
getNackCount() - Method in interface ostore.archive.DisseminatableBucket
getNackCount returns the number of NACK's received.
getName() - Method in class ostore.client.OSCreateObjectRequest
Returns the desired name of the data object to be created.
getName() - Method in class ostore.dataobj.RPCert
 
getName() - Method in class ostore.apps.traces.TraceObject
Returns a human-readable representation of this ReplicaReq.
getNextBucket() - Method in class ostore.archive.FragmentBucket
Get the next Bucket in this chain.
getNextBucket() - Method in interface ostore.archive.DisseminatableBucket
getNextBucket returns the SecureHash of the next Bucket in this chain.
getNodeId() - Method in class ostore.apps.qtree.impl.QTreeCloseMsgAck
 
getNodeIds() - Static method in class ostore.dispatch.Classifier
Returns a Set containing the NodeIds for each Classifier in this jvm.
getNonce() - Method in class ostore.client.OSRegisterAppResult
 
getNonce() - Method in class ostore.client.OSRegisterAppRequest
 
getNonce() - Method in class ostore.util.NonceMsg
 
getNonceAcks() - Method in class ostore.util.NonceAckMsg
 
getNum() - Method in class ostore.introspect.SemanticDistanceModel.Tuple
Get the approximate number of measurements incorporated into this distance approximation.
getNumAcksRecv() - Method in class ostore.archive.FragmentBucket
getNumAcksRecv returns the number of ack's recv'd
getNumAcksRecv() - Method in interface ostore.archive.DisseminatableBucket
getNumAcksRecv returns the number of ack's recv'd.
getNumberOfFragments() - Method in class ostore.archive.Fragment
Gets the number of fragments field from this Fragment.
getNumBytes() - Method in class ostore.archive.FragmentBucket
Retrieve the total number of bytes stored in this bucket.
getNumBytes() - Method in interface ostore.archive.DisseminatableBucket
getNumBytes returns the total number of bytes stored in this bucket.
getNumFragments() - Method in class ostore.archive.Erasure
numFragments returns the number of Fragments after encoding (without loss of Fragments).
getNumFragments() - Method in class ostore.archive.ArchiveObjBucket
getNumFragments returns the number of fragments to generate for each block.
getNumFragments() - Method in class ostore.archive.cauchy.Cauchy
numFragments returns the number of fragments after encoding (without loss of fragments).
getNumFragments() - Method in class ostore.archive.interleaved.Interleaved
numFragments returns the number of fragments after encoding (without loss of fragments).
getNumGood() - Method in class ostore.archive.FragmentBucket
Retrieve the total number of disseminatables stored in this bucket.
getNumGood() - Method in interface ostore.archive.DisseminatableBucket
getNumGood returns the total number of Disseminatables stored in this bucket.
getNumNeeded() - Method in class ostore.archive.ErasureDecodeException
getNumNeeded returns the number of Disseminatables needed to recover msg.
getNumPendingBlk() - Method in class ostore.archive.ArchiveObjBucket
getNumPendingBlk returns number of pending blocks.
getNumReceived() - Method in class ostore.archive.ErasureDecodeException
getNumReceived returns the number of Disseminatables received for recovery of msg.
getNumSamples() - Method in class ostore.util.StatRecorder
 
getOffset() - Method in class ostore.archive.ArchiveObjBucket
getOffset returns the position in data byte sequence to start reconstruction.
getOffset() - Method in class ostore.dataobj.Range
The index of the first byte to include.
getOffset() - Method in class ostore.update.ActionReplaceBlocks
getOffset returns the offset of the ActionReplaceBlocks.
getOffset() - Method in class ostore.util.ByteArrayInputBuffer
Returns the current offset into the original array
getOffset() - Method in class ostore.apps.traces.TraceObject
Returns a human-readable representation of this ReplicaReq.
getOffTime() - Method in class ostore.apps.traces.TraceObject
Returns a human-readable representation of this ReplicaReq.
getOpenReq() - Method in class ostore.replica.RemoteReplicaOpenReq
 
getOperation() - Method in class ostore.apps.traces.TraceObject
Returns a human-readable representation of this ReplicaReq.
getOrphan() - Method in class ostore.apps.qtree.impl.QTreeRepairMsg
 
getOutlier() - Method in class ostore.introspect.WeightedAvgFilter
Get the outlier value.
getParent() - Method in class ostore.apps.qtree.impl.QTreeCloseMsg
 
getParent() - Method in class ostore.apps.qtree.impl.QTreeGroupMsg
 
getParents(SecureHash) - Method in class ostore.apps.qtree.impl.QTree
 
getPartialResult() - Method in class ostore.dataobj.DataObjectReadException
 
getPath() - Method in class ostore.apps.qtree.impl.QTreeGroupMsg
 
getPeer() - Method in class ostore.client.OSOpenReplicaRequest
 
getPendingBlk(SecureHash) - Method in class ostore.archive.ArchiveObjBucket
getPendingBlk returns the Object (i.e. pending block) associated with guid.
getPendingBlks() - Method in class ostore.archive.ArchiveObjBucket
getPendingBlks returns the GUIDs of the blks which have been requested, but which have yet to be encoded or recoalesced
getPercentile(double) - Method in class ostore.util.StatRecorder
 
getPin(CacheableIdentity) - Method in class ostore.cache.BufferCache
 
getPin(CacheableIdentity, DataCache) - Method in class ostore.dataobj.HandleStore
 
getPinned() - Method in class ostore.cache.CacheReserveSpaceDone
 
getPinned() - Method in class ostore.cache.CacheInsertDone
 
getPinWithException(CacheableIdentity) - Method in interface ostore.cache.DataCache
Request a page and pin it (regardless if it's already pinned).
getPinWithException(CacheableIdentity) - Method in class ostore.cache.BufferCache
 
getPredicate() - Method in class ostore.client.OSUpdateTuple
Returns the tuple's predicate.
getPredicate() - Method in class ostore.update.UpdateTuple
Return the predicate of this tuple.
getPredicate() - Method in class ostore.archive.dissemination.RequestDisseminationSetMsg
getPredicate returns the DisseminationSetPredicate.
getPredicateNumber() - Method in class ostore.update.UpdateContinuation
 
getPrincipal() - Method in class ostore.client.OSRead
Return the hash of the principal that created the read request.
getPrincipal() - Method in class ostore.client.OSMetadataRequest
Return the hash of the principal that created the read request.
getPrincipal() - Method in class ostore.dataobj.RPCert
 
getPrincipal() - Method in class ostore.update.Update
Return the hash of the principal that created the update.
getPrincipalPrivateKey() - Method in class ostore.client.OSCreateObjectRequest
Returns the principal's private (secret) key.
getPrincipalPublicKey() - Method in class ostore.client.OSCreateObjectRequest
Returns the principal's public key.
getPriority() - Method in class ostore.introspect.SemanticDistanceModel.Tuple
Get the priority of this tuple in a queue.
getProperty() - Method in class ostore.client.OSSetAppPropertyRequest
 
getProximity() - Method in class ostore.client.OSOpenReplicaRequest
 
getPublicKey() - Method in class ostore.security.thresh.Dealer
 
getQSArray() - Method in class ostore.util.QSArray
 
getQueue() - Method in class ostore.introspect.SemanticDistanceModel.Segment
Get the queue of distances.
getQueue(QuickSerializable) - Method in class ostore.introspect.SemanticDistanceModel.Table
Get the queue of distances associated with key
getReadResp() - Method in class ostore.update.UpdateContinuation
Response to a BytesReadResp we performed on behalf of an Action or Predicate.
getReadSelection() - Method in class ostore.client.OSReadResult
 
getReason() - Method in class ostore.client.OSCreateObjectResult
Returns a non-success reason code is getSuccess() is false.
getRecp() - Method in class ostore.apps.qtree.impl.QTreeCloseMsg
 
getRefGuid() - Method in class ostore.archive.FragmentBucket
Get GUID that refers to this bucket (in some higher-level hashtable).
getRefGuid() - Method in interface ostore.archive.DisseminatableBucket
getRefGuid returns the GUID that refers to this bucket (in some higher-level hashtable).
getReq() - Method in class ostore.archive.GenerateFragsReqMsg
getReq returns the GenerateFragsChkptReq
getReqSeqNum() - Method in class ostore.client.OSResult
Returns the sequence number of the request that generated this result.
getRequestDelay() - Method in class ostore.apps.traces.TraceObject
Returns a human-readable representation of this ReplicaReq.
getRequestedCardinality() - Method in class ostore.archive.RequestFragQueryState
getRequestedCardinality returns the requested number of back pointers pursued for a fragment.
getRequestId() - Method in class ostore.cache.CachePinnedReply.Local
id of stage requesting the block.
getRequestId() - Method in class ostore.cache.CachePinnedRequest.Local
 
getRequestId() - Method in class ostore.cache.CacheReserveSpaceDone
 
getRequestId() - Method in class ostore.cache.CachePinnedRequest
 
getRequestId() - Method in class ostore.cache.CachePinnedReply
id of stage requesting the block
getRequestId() - Method in class ostore.cache.CacheInsertDone
 
getRequestId() - Method in class ostore.cache.CacheDeleteItem
 
getRequestId() - Method in class ostore.cache.CacheDeleteConfirm
 
getRequestId() - Method in class ostore.cache.CacheBlockRequestMessage
 
getRequestId() - Method in class ostore.cache.CacheBlockReplyMessage
id of stage requesting the block
getRequestTag() - Method in class ostore.cache.CacheReserveSpaceMessage
 
getRequestType() - Method in class ostore.client.OSRegisterAppRequest
 
getRequestType() - Method in class ostore.client.OSOpenReplicaRequest
 
getRequestType() - Method in class ostore.client.OSCloseReplicaRequest
 
getReqUniqueId() - Method in class ostore.cache.CacheAssignReply
Returns the unique identifier for the original CacheAssignRequest
getReqVersion() - Method in class ostore.archive.ArchiveObjBucket
getReqVersion returns the guid of the requested obj.
getReservedBlocks() - Method in class ostore.dataobj.DataObjectReplaceException
 
getResp() - Method in class ostore.archive.GenerateFragsRespMsg
getResp returns the GenerateFragsChkptResp
getResponse() - Method in class ostore.archive.RequestFragResponseMsg
getResponse returns the response to the RequestFragMsg.
getResponse() - Method in class ostore.archive.ArchiverLocateRespMsg
getResponse returns the response from the ArchiverStage.
getResponseGuid() - Method in class ostore.archive.RequestFragResponseMsg
getResponseGuid returns the guid of the originally requested obj specified in the RequestFragMsg.
getResponses() - Method in class ostore.cache.CacheAssignReply
Returns the array of respones.
getResult() - Method in class ostore.dataobj.DataObjectReadSliceException
 
getRevpointers(Map, int) - Method in class ostore.apps.qtree.impl.QTree
Copied from Router.
getRoot() - Method in class ostore.dataobj.Btree
 
getRootNode() - Method in class ostore.apps.qtree.api.QTreeStateMsg
 
getRP() - Method in class ostore.dataobj.RPCert
 
getRPCert() - Method in class ostore.client.OSCreateObjectRequest
Returns the responsible party certificate needed for this request.
getRPKey() - Method in class ostore.client.OSCreateObjectRequest
Returns the responsible party's public key.
getSecret() - Method in class ostore.security.thresh.KeyShare
 
getSelection() - Method in class ostore.archive.GenerateFragsReqMsg
getSelection returns the portion of DataObject to create Fragments for.
getSelection() - Method in class ostore.client.OSRead
 
getSelection() - Method in class ostore.dataobj.KeyedSelection
The desired Selection of the subtree.
getSelection() - Method in class ostore.update.PredicateCompareBytes
The selection we are comparing against.
getSelections() - Method in class ostore.dataobj.CompositeSelection
An array of Selections in canonical form, the union of which define this CompositeSelection.
getSeqNum() - Method in class ostore.client.OSRequest
Returns the sequence number of the request.
getSerializedKeySize(int) - Static method in class ostore.dataobj.Btree.InteriorNode
 
getSerializedOverhead(int) - Static method in class ostore.dataobj.Btree.InteriorNode
 
getSerializedPointerSize(int) - Static method in class ostore.dataobj.Btree.InteriorNode
 
getShares() - Method in class ostore.security.thresh.Dealer
Returns the initialized secret key shares
getShareVerifier() - Method in class ostore.security.thresh.Verifier
 
getSig() - Method in class ostore.security.thresh.SigShare
Return a SafeBigInt representation of this signature
getSignal(NodeId) - Static method in class ostore.dispatch.Signal
Returns the Signal instance corresponding to a NodeId.
getSignVal() - Method in class ostore.security.thresh.KeyShare
 
getSigVerifier() - Method in class ostore.security.thresh.SigShare
Return this signature's verifier
getSize() - Method in class ostore.archive.Erasure
getSize returns the size of the msg that can be encoded.
getSize() - Method in class ostore.cache.CacheablePinned
returns the size of the block or space taken for this CacheLine
getSize() - Method in class ostore.cache.CacheableHandle
the size of the Cacheable block in the cache
getSizeInBytes() - Method in class ostore.dataobj.DataObject.DataBlock
 
getSizeInBytes(int, int) - Static method in class ostore.dataobj.Btree.InteriorNode
 
getSpace() - Method in class ostore.cache.CacheReserveSpaceMessage
return amount of space requested in the cache
getStageId() - Method in class ostore.util.NonceAckMsg
 
getStart() - Method in class ostore.client.OSActionReplace
Returns the offset at which to start replacing data.
getStartTime() - Method in class ostore.archive.FragmentBucket
getStartTime returns the time the Bucket was created(put on table).
getStartTime() - Method in interface ostore.archive.DisseminatableBucket
getStartTime returns the time the Bucket was created (i.e. put on table).
getStartTime() - Method in class ostore.archive.ArchiveObjBucket
getStartTime return the startTime of the archiving or recoalescing process.
getState() - Method in class ostore.cache.CacheNotify
getState returns the state of object in the cache.
getState() - Method in class ostore.apps.qtree.api.QTreeStateMsg
 
getStats() - Method in class ostore.apps.test.TputMicroBenchmarkMessage
 
getStddev() - Method in class ostore.util.StatRecorder
 
getSuccess() - Method in class ostore.client.OSVIDResult
 
getSuccess() - Method in class ostore.client.OSOpenReplicaResult
Returns whether the replica was successfully opened.
getSuccess() - Method in class ostore.client.OSMetadataResult
 
getSuccess() - Method in class ostore.client.OSCreateObjectResult
Returns true if the object was successfully created; returns false otherwise.
getSuccess() - Method in class ostore.client.OSCloseReplicaResult
Returns whether the replica was successfully closed.
getSuccess() - Method in class ostore.client.OSReadResult
 
getTable() - Method in class ostore.introspect.SemanticDistanceModel.Delta
Get the table of distance values in this delta
getTable() - Method in class ostore.introspect.SemanticDistanceModel
Get the semantic distance table.
getTarget() - Method in class ostore.client.OSVIDRequest
 
getTarget() - Method in class ostore.client.OSRead
 
getTarget() - Method in class ostore.client.OSMetadataRequest
 
getTargetAguid() - Method in class ostore.client.OSActionTruncate
Returns the Aguid of the object that this update modifies.
getTargetAguid() - Method in class ostore.client.OSActionSetMetadata
Returns the Aguid of the object that this update modifies.
getTargetAguid() - Method in class ostore.client.OSActionReplace
Returns the Aguid of the object that this update modifies.
getTargetAguid() - Method in class ostore.client.OSActionExpand
Returns the Aguid of the object that this update modifies.
getTargetAguid() - Method in class ostore.client.OSActionAppend
Returns the Aguid of the object that this update modifies.
getTargetAguid() - Method in class ostore.client.OSAction
 
getTargets() - Method in class ostore.update.UpdateTuple
Returns a set containing all of the potential targets of this tuple.
getTargets() - Method in class ostore.update.PredicateCompareBytes
 
getTargets() - Method in class ostore.update.ActionTruncate
 
getTargets() - Method in class ostore.update.ActionSetMetadata
 
getTargets() - Method in class ostore.update.ActionReplaceBlocks
 
getTargets() - Method in class ostore.update.ActionExpand
 
getTargets() - Method in class ostore.update.ActionAppendBlocks
 
getTargets() - Method in class ostore.update.Update
Returns the set of potential targets of this update.
getThrowException() - Static method in class ostore.util.Carp
Returns the flag that controls whether croak and die should throw a RuntimeException (true) or call System.exit (false).
getTime(QuickSerializable) - Method in class ostore.introspect.SemanticDistanceModel.Table
Get the last time we saw this observation
getTimestamp() - Method in class ostore.update.Update
Return the timestamp of the update.
getTimeZone() - Method in class ostore.archive.dissemination.DisseminationSetPredicate
getTimeZone returns timeZone constraint that the dissemination set needs to satifsfy.
getTopBlockId() - Method in class ostore.archive.ArchiveObjBucket
 
getTopBlockId() - Method in class ostore.archive.events.UpdateVerifiableBlocksResp
getTopBlockId returns the VID of root block.
getTopBlockId() - Method in class ostore.archive.events.UpdateVerifiableBlocksReq
getTopBlockId returns the VID of root block.
getTopBlockSize(int) - Static method in class ostore.dataobj.DataObject
 
getTotalBlockSizes() - Method in class ostore.archive.ArchiveObjBucket
getTotalBlockSizes returns the total size of all VerifiableBlocks being archived or reconstructed.
getTotalDisseminateSizes() - Method in class ostore.archive.ArchiveObjBucket
getTotalDisseminateSizes returns the total disseminate size of all VerifiableBlocks being archived or reconstructed.
getTotalErasureBlockSizes() - Method in class ostore.archive.ArchiveObjBucket
getTotalErasureBlockSizes returns the total Erasure size of all VerifiableBlocks being archived or reconstructed.
getTotalObjSizes() - Method in class ostore.archive.ArchiveObjBucket
getTotalObjSizes returns the total size of object that includes all VerifiableBlocks being archived or reconstructed.
getTreeId() - Method in class ostore.apps.qtree.api.QTreeUp
 
getTreeId() - Method in class ostore.apps.qtree.api.QTreeDown
 
getTreeId() - Method in class ostore.apps.qtree.impl.QTreeDownMsgAck
 
getTreeId() - Method in class ostore.apps.qtree.impl.QTreeUpMsgAck
 
getTreeId() - Method in class ostore.apps.qtree.impl.QTreeDownMsg
 
getTreeId() - Method in class ostore.apps.qtree.impl.QTreeUpMsg
 
getTreeKey() - Method in class ostore.apps.qtree.impl.QTreeCloseMsgAck
 
getTreeKey() - Method in class ostore.apps.qtree.impl.QTreeCloseMsg
 
getTreeKey() - Method in class ostore.apps.qtree.impl.QTreeRepairMsg
 
getTreeKey() - Method in class ostore.apps.qtree.impl.QTreeGroupMsgAck
 
getTreeKey() - Method in class ostore.apps.qtree.impl.QTreeGroupMsg
 
getTreeSet() - Method in class ostore.util.QSTreeSet
 
getTSink(String) - Method in class ostore.dispatch.Classifier
Gets the TSink for the stage given as an argument.
getTuple(int) - Method in class ostore.update.Update
Return a specified tuple.
getTuple(QuickSerializable) - Method in class ostore.introspect.SemanticDistanceModel.BoundedPrioQueue
Get the tuple to type key
getTupleExecuted() - Method in class ostore.update.UpdateResult
Returns the number of the tuple that was executed.
getTupleNumber() - Method in class ostore.client.OSUpdateResult
Returns the number of the tuple that was executed.
getTupleNumber() - Method in class ostore.update.UpdateContinuation
 
getTuples() - Method in class ostore.client.OSUpdate
Returns an Iterator of the tuples in this update.
getTuples() - Method in class ostore.update.Update
Return an iterator of the tuples in the update.
getTVal(int) - Static method in class ostore.archive.Stats
getTVal Return the T-value for a given number of degrees of freedom (assuming a tail of .025...for 95% confidence intervals).
getType() - Method in class ostore.archive.dissemination.TypeResponseMsg
getType returns the type to the RequestFragMsg.
getType(SecureHash) - Method in class ostore.archive.ArchiveObjBucket
getType returns type of block associated with guid.
getTypeCode() - Method in class ostore.util.TypeTable.NoSuchTypeCode
 
getTypes() - Method in class ostore.cache.CacheManager.CacheAvailable
getTypes return the types of cacheables that the cache is exporting.
getUniqueId() - Method in class ostore.cache.CacheAssignRequest
Returns the unique identifier for the CacheAssignRequest
getUpdate() - Method in class ostore.update.UpdateRequest
Returns the update to be executed.
getUpdateDigest() - Method in class ostore.update.UpdateResult
Returns the digest of the update whose result is reported.
getUpdateDigest() - Method in class ostore.update.UpdateRequest
Returns the digest of the update
getUsed() - Method in class ostore.dataobj.Btree.InteriorNode
 
getUseDisk() - Method in class ostore.cache.CachePinnedRequest.Local
getUseDisk returns true if cache should automatically go to disk.
getUseDisk() - Method in class ostore.cache.CachePinnedRequest
getUseDisk returns true if cache should automatically go to disk.
getUseDisk() - Method in class ostore.cache.CacheBlockRequestMessage
getUseDisk returns true if cache should automatically go to disk.
getUseNetwork() - Method in class ostore.cache.CachePinnedRequest.Local
getUseNetwork returns true if cache should automatically go to network.
getUseNetwork() - Method in class ostore.cache.CachePinnedRequest
getUseNetwork returns true if cache should automatically go to network.
getUseNetwork() - Method in class ostore.cache.CacheBlockRequestMessage
getUseNetwork returns true if cache should automatically go to network.
getUserTag() - Method in class ostore.client.OSRequest
Returns the user tag.
getUserTag() - Method in class ostore.client.OSResult
Returns the user tag.
getValue() - Method in class ostore.client.OSSetAppPropertyRequest
 
getValue() - Method in class ostore.client.OSActionSetMetadata
Returns the value to which the specified metadata field will be set.
getValue() - Method in class ostore.introspect.SimpleRealTime.Distance
Get the value of this distance as a double
getVCreateTime() - Method in class ostore.update.UpdateRequest
Returns the version create time.
getVerifier() - Method in class ostore.security.thresh.KeyShare
 
getVerify(int) - Method in class ostore.archive.Fragment
Get one of the hashes in the verification information.
getVerifyLength() - Method in class ostore.archive.Fragment
Return the length of the verification array.
getVersionCache() - Method in class ostore.update.UpdateContinuation
 
getVersionHandle(SecureHash) - Method in class ostore.update.VersionHandleCache
Returns a pinned cache handle to the modified version of the data object identified by an Aguid.
getVersionId() - Method in class ostore.client.OSVIDResult
 
getVersionId() - Method in class ostore.client.OSOpenReplicaResult
Returns the most recent heartbeat available for the replica.
getVersionId() - Method in class ostore.client.OSMetadataResult
 
getVersionId() - Method in class ostore.client.OSReadResult
 
getVersionIdMap() - Method in class ostore.client.OSUpdateResult
Returns a mapping from Aguids to version identifiers for all data objects changed by the update.
getVersionPredicate() - Method in class ostore.client.OSVIDRequest
 
getVersionPredicate() - Method in class ostore.client.OSRead
 
getVersionPredicate() - Method in class ostore.client.OSMetadataRequest
 
getVguid() - Method in class ostore.client.OSCreateObjectResult
Returns the Vguid of the first version of the new data object.
getVguid() - Method in class ostore.archive.events.UpdateVerifiableBlocksResp
getVguid returns the V-GUID (i.e. version GUID)of the object.
getVguid() - Method in class ostore.archive.events.UpdateVerifiableBlocksReq
getVguid returns the V-GUID (i.e. version GUID)of the object.
getVguid() - Method in class ostore.archive.dissemination.DisseminateFragMsg
getVguid returns the vguid that matches the version that the dissemintables belong.
getVguid() - Method in class ostore.archive.dissemination.DisseminateFragAckMsg
getVguid returns the vguid that matches the version that was disseminated.
getVGuid() - Method in class ostore.archive.ArchiveObjBucket
 
getVguid(SecureHash) - Method in class ostore.update.GuidVersionMap
Returns the Vguid of the current version of the data object identified by an Aguid.
getVhash() - Method in class ostore.client.OSCreateObjectResult
Returns the Vhash of the first version of the new data object.
getVHash() - Method in class ostore.cache.TestBlock
 
getVhash(SecureHash) - Method in class ostore.update.GuidVersionMap
Returns the Vhash of the current version of the data object identified by an Aguid.
getVid() - Method in class ostore.dtree.RemoteCacheRequestMessage
 
getVid() - Method in class ostore.dtree.RemoteCacheReplyMessage
 
getWithException(CacheableIdentity) - Method in interface ostore.cache.DataCache
Request a handle to a block in the cache.
getWithException(CacheableIdentity) - Method in class ostore.cache.BufferCache
 
getZ() - Method in class ostore.security.thresh.Verifier
 
got_msg(GenerateFragsBlkResp) - Method in class ostore.archive.TputGenerateFragsTest
 
got_msg(GenerateFragsChkptResp) - Method in class ostore.archive.TputGenerateChkptTest
 
got_msg(TputTest.Msg) - Method in class ostore.network.TputTest
 
greaterThan(BtreeKey) - Method in class ostore.dataobj.SHA1HashKey
 
greaterThan(BtreeKey) - Method in class ostore.dataobj.LongKey
 
greaterThan(BtreeKey) - Method in interface ostore.dataobj.BtreeKey
 
greaterThanEqual(BtreeKey) - Method in class ostore.dataobj.SHA1HashKey
 
greaterThanEqual(BtreeKey) - Method in class ostore.dataobj.LongKey
 
greaterThanEqual(BtreeKey) - Method in interface ostore.dataobj.BtreeKey
 
guid - Variable in class ostore.inner.LatestHeartbeatReq
 
guid - Variable in class ostore.mac.HMACDHHandler.TellStsTimeout
 
guid - Variable in class ostore.mac.HMACDHHandler.TellInit
 
guid - Variable in class ostore.mac.MacHandler.HandshakeFailed
 
guid - Variable in class ostore.mac.MacHandler.KeyEstablished
 
guid - Variable in class ostore.archive.events.ResurrectTombResp
guid == Archive GUID of object resurrected.
guid - Variable in class ostore.archive.events.ResurrectTombReq
guid == Archive GUID of Tombstone.
guid - Variable in class ostore.archive.events.GenerateFragsBlkResp
guid == Resulting guid for fragmentation of block.
guid - Variable in class ostore.archive.events.DisseminateFragsResp
guid == GUID of the version disseminated.
guid - Variable in class ostore.archive.events.DisseminateFragsReq
guid == GUID of the version to disseminate.
guid - Variable in class ostore.apps.qtree.impl.TreeKey
 
GUID - Static variable in class ostore.cache.CacheableIdentity
indicates that this object has a GUID
GUID - Static variable in class ostore.dataobj.HandleStore
 
guid_to_member - Variable in class ostore.agree.RingState
Maps the guids of the machines in this ring (SecureHashes) to their member numbers (Integers).
guid() - Method in class ostore.dataobj.RPCert
 
guid(QSPublicKey, String) - Static method in class ostore.dataobj.RPCert
 
guidResult - Variable in class ostore.archive.events.GenerateFragsBlkResp
guidResult == Resulting statistics of the guid fragmentation process of the block.
GuidResult - class ostore.archive.GuidResult.
The GuidResult class is an object that encapsulates the the GUID generated by the GenerateFragsStage or recoalesed by the RecoalesceBlkStage, the total Erasure code time, the code method time, the Erasure encode or decode time, and the VHashTree time.
GuidResult(DisseminatableBucket, SecureHash, long, long, long, long, long, int, int, int) - Constructor for class ostore.archive.GuidResult
Constructor.
GuidResult(InputBuffer) - Constructor for class ostore.archive.GuidResult
Constructs a GuidResult from its serialized form.
GuidVersionMap - class ostore.update.GuidVersionMap.
The GuidVersionMap records a mapping from Aguid to Vguid.
GuidVersionMap() - Constructor for class ostore.update.GuidVersionMap
Construct a new GuidVersionMap.

A B C D E F G H I J K L M N O P Q R S T U V W Y Z _