Serialized Form


Package messif.algorithms

Class messif.algorithms.Algorithm extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Deserialization method. Initialize the method class executor, because it is not serialized

Throws:
java.io.IOException - if there was an error reading from the input stream
java.lang.ClassNotFoundException - if there was an error resolving classes from the input stream
Serialized Fields

algorithmName

java.lang.String algorithmName
The name of this algorithm

Class messif.algorithms.AlgorithmMethodException extends java.lang.Exception implements Serializable

serialVersionUID: 1L

Class messif.algorithms.DistAlgReplyMessage extends ReplyMessage implements Serializable

serialVersionUID: 1L

Serialized Fields

operation

AbstractOperation operation
Operation processed by the algorithm

Class messif.algorithms.DistAlgRequestMessage extends Message implements Serializable

serialVersionUID: 1L

Serialized Fields

operation

AbstractOperation operation
Message extension

Class messif.algorithms.DistributedAlgorithm extends Algorithm implements Serializable

serialVersionUID: 5L

Serialized Fields

messageDisp

MessageDispatcher messageDisp
Message dispatcher for this distributed algorithm


Package messif.algorithms.impl

Class messif.algorithms.impl.ParallelSequentialScan extends Algorithm implements Serializable

serialVersionUID: 1L

Serialized Fields

buckets

LocalBucket[] buckets
Instances of bucket where all the objects are stored


insertBucket

int insertBucket
Index of the bucket that receives next inserted object

Class messif.algorithms.impl.SequentialScan extends Algorithm implements Serializable

serialVersionUID: 1L

Serialized Fields

bucket

LocalBucket bucket
One instance of bucket where all objects are stored


pivots

AbstractObjectList<E extends AbstractObject> pivots
A list of fixed pivots used for filtering


pivotDistsValidIfGiven

boolean pivotDistsValidIfGiven
Flag controlling the usage of PrecomputedDistancesFixedArrayFilter -- whether distances are set or appended (see the constructor below for details)


Package messif.buckets

Class messif.buckets.BucketDispatcher extends java.lang.Object implements Serializable

serialVersionUID: 2L

Serialized Fields

buckets

java.util.Map<K,V> buckets
The buckets maintained by this dispatcher organized in hashtable with bucket IDs as keys


maxBuckets

int maxBuckets
Maximal number of buckets maintained by this dispatcher


nextBucketID

java.util.concurrent.atomic.AtomicInteger nextBucketID
Automatic bucket ID generator


bucketCapacity

long bucketCapacity
Default bucket hard capacity for newly created buckets


bucketSoftCapacity

long bucketSoftCapacity
Default bucket soft capacity for newly created buckets


bucketLowOccupation

long bucketLowOccupation
Default bucket hard low-occupation for newly created buckets


bucketOccupationAsBytes

boolean bucketOccupationAsBytes
Default flag whether to store occupation & capacity in bytes (true) or number of objects (false) for newly created buckets


defaultBucketClass

java.lang.Class<T> defaultBucketClass
Default class for newly created buckets


defaultBucketClassParams

java.util.Map<K,V> defaultBucketClassParams
Default parameters for newly created buckets with default bucket class


autoPivotChooserClass

java.lang.Class<T> autoPivotChooserClass
The class of pivot chooser that is automatically created for newly created buckets


autoPivotChooserInstance

AbstractPivotChooser autoPivotChooserInstance
The pivot chooser instance that chooses pivots for all the buckets in this dispatcher


createdPivotChoosers

java.util.Map<K,V> createdPivotChoosers
The hash table of pivot choosers that are assigned to buckets of this dispatcher

Class messif.buckets.BucketErrorCode extends ErrorCode implements Serializable

serialVersionUID: 1L

Class messif.buckets.BucketStorageException extends java.lang.Exception implements Serializable

serialVersionUID: 1L

Serialized Fields

errorCode

BucketErrorCode errorCode
Bucket error code associated with this exception

Class messif.buckets.CapacityFullException extends BucketStorageException implements Serializable

serialVersionUID: 1L

Class messif.buckets.DuplicateObjectException extends BucketStorageException implements Serializable

serialVersionUID: 1L

Class messif.buckets.FilterRejectException extends BucketStorageException implements Serializable

serialVersionUID: 1L

Class messif.buckets.LocalBucket extends Bucket implements Serializable

serialVersionUID: 2L

Serialized Fields

bucketID

int bucketID
Unique identifier of this bucket


capacity

long capacity
The maximal (hard) capacity of this bucket


softCapacity

long softCapacity
The soft capacity of this bucket


lowOccupation

long lowOccupation
The minimal (hard) capacity of this bucket


occupationAsBytes

boolean occupationAsBytes
Flag if the occupation is stored as bytes or object count


occupation

long occupation
Actual bucket occupation in either bytes or object count (see occupationAsBytes flag)


beforeAddFilters

BucketFilterBeforeAdd[] beforeAddFilters
List of registered "before add" filters


afterAddFilters

BucketFilterAfterAdd[] afterAddFilters
List of registered "after add" filters


beforeRemoveFilters

BucketFilterBeforeRemove[] beforeRemoveFilters
List of registered "before remove" filters


afterRemoveFilters

BucketFilterAfterRemove[] afterRemoveFilters
List of registered "after remove" filters

Class messif.buckets.OccupationLowException extends BucketStorageException implements Serializable

serialVersionUID: 1L

Class messif.buckets.OrderedLocalBucket extends LocalBucket implements Serializable

serialVersionUID: 934001L

Class messif.buckets.StorageFailureException extends BucketStorageException implements Serializable

serialVersionUID: 1L


Package messif.buckets.impl

Class messif.buckets.impl.AlgorithmStorageBucket extends LocalBucket implements Serializable

serialVersionUID: -792888618241233159L

Serialized Fields

algorithm

Algorithm algorithm
Encapsulated algorithm


objectCount

int objectCount
Stored object count

Class messif.buckets.impl.DiskBlockBucket extends LocalBucket implements Serializable

serialVersionUID: 1L

Serialized Fields

objects

ModifiableIndex<T> objects
Object storage

Class messif.buckets.impl.DiskBlockObjectKeyBucket extends OrderedLocalBucket<AbstractObjectKey> implements Serializable

serialVersionUID: 1L

Serialized Fields

objects

ModifiableOrderedIndex<C,T> objects
Object storage

Class messif.buckets.impl.DiskBlockObjectKeyMemoryBucket extends OrderedLocalBucket<AbstractObjectKey> implements Serializable

serialVersionUID: 1L

Serialized Fields

objects

ModifiableOrderedIndex<C,T> objects
Object storage

Class messif.buckets.impl.MemoryStorageBucket extends LocalBucket implements Serializable

serialVersionUID: 4L

Serialized Fields

objects

ModifiableIndex<T> objects
Object storage

Class messif.buckets.impl.MemoryStorageIDBucket extends OrderedLocalBucket<UniqueID> implements Serializable

serialVersionUID: 1L

Serialized Fields

objects

ModifiableOrderedIndex<C,T> objects
Object storage with object-id index

Class messif.buckets.impl.MemoryStorageLocatorBucket extends OrderedLocalBucket<java.lang.String> implements Serializable

serialVersionUID: 1L

Serialized Fields

objects

ModifiableOrderedIndex<C,T> objects
Object storage with object-id index

Class messif.buckets.impl.MemoryStorageNoDupsBucket extends OrderedLocalBucket<LocalAbstractObject> implements Serializable

serialVersionUID: 1L

Serialized Fields

objects

ModifiableOrderedIndex<C,T> objects
Object storage with object-id index

Class messif.buckets.impl.MemoryStorageObjectKeyBucket extends OrderedLocalBucket<AbstractObjectKey> implements Serializable

serialVersionUID: 1L

Serialized Fields

objects

ModifiableOrderedIndex<C,T> objects
Object storage with object-id index

Class messif.buckets.impl.VirtualStorageBucket extends OrderedLocalBucket<C> implements Serializable

serialVersionUID: 1L

Serialized Fields

index

ModifiableOrderedIndex<C,T> index
Internal index with encapsulated storage


Package messif.buckets.index

Package messif.buckets.index.impl

Class messif.buckets.index.impl.AddressStorageIndex extends AbstractArrayIndex<K,T> implements Serializable

serialVersionUID: 2L

Serialized Fields

storage

Storage<T> storage
Storage associated with this index


index

Address<T>[] index
Index of addresses into the storage


comparator

IndexComparator<K,O> comparator
Comparator imposing natural order of this index

Class messif.buckets.index.impl.IntStorageIndex extends AbstractArrayIndex<K,T> implements Serializable

serialVersionUID: 2L

Serialized Fields

storage

IntStorage<T> storage
Storage associated with this index


index

int[] index
Index of addresses into the storage


comparator

IndexComparator<K,O> comparator
Comparator imposing natural order of this index

Class messif.buckets.index.impl.LongStorageIndex extends AbstractArrayIndex<K,T> implements Serializable

serialVersionUID: 2L

Serialized Fields

storage

LongStorage<T> storage
Storage associated with this index


index

long[] index
Index of addresses into the storage


comparator

IndexComparator<K,O> comparator
Comparator imposing natural order of this index

Class messif.buckets.index.impl.LongStorageMemoryIndex extends SortedArrayData<K,LongStorageMemoryIndex.KeyAddressPair<K>> implements Serializable

serialVersionUID: 102302L

Serialized Fields

storage

DiskStorage<T> storage
Storage associated with this index


index

java.util.ArrayList<E> index
Index of addresses into the storage


comparator

IndexComparator<K,O> comparator
Comparator imposing natural order of this index

Class messif.buckets.index.impl.LongStorageMemoryIndex.KeyAddressPair extends java.lang.Object implements Serializable

serialVersionUID: 102401L

Serialized Fields

key

java.lang.Object key

position

long position

Package messif.buckets.split

Class messif.buckets.split.BucketBallRegion extends BallRegion implements Serializable

serialVersionUID: 1L

Serialized Fields

bucket

LocalBucket bucket
The bucket on which this ball region should be maintained


needsAdjusting

boolean needsAdjusting
The flag if there was a modification to bucket


Package messif.buckets.storage

Class messif.buckets.storage.IntAddress extends java.lang.Object implements Serializable

serialVersionUID: 23101L

Serialized Fields

storage

IntStorage<T> storage
Storage associated with this address


address

int address
Actual address in the storage this object points to

Class messif.buckets.storage.InvalidAddressException extends StorageFailureException implements Serializable

serialVersionUID: 8785487981624795432L

Class messif.buckets.storage.LongAddress extends java.lang.Object implements Serializable

serialVersionUID: 23101L

Serialized Fields

storage

LongStorage<T> storage
Storage associated with this address


address

long address
Actual address in the storage this object points to

Class messif.buckets.storage.ReadonlyStorageException extends StorageFailureException implements Serializable

serialVersionUID: 8785489987624795491L


Package messif.buckets.storage.impl

Class messif.buckets.storage.impl.DatabaseStorage extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

storedObjectsClass

java.lang.Class<T> storedObjectsClass
Class of objects that the this storage works with


dbConnUrl

java.lang.String dbConnUrl
Database connection URL


dbConnInfo

java.util.Properties dbConnInfo
Properties with database connection info


columnConvertors

DatabaseStorage.ColumnConvertor<T>[] columnConvertors
List of column convertors


columnNames

java.lang.String[] columnNames
List of additional column names (same size as columnConvertors)


sizeSQL

java.lang.String sizeSQL
Number of objects SQL command


insertSQL

java.lang.String insertSQL
Insert object SQL command


deleteSQL

java.lang.String deleteSQL
Delete a single object (by primary key) SQL command


deleteAllSQL

java.lang.String deleteAllSQL
Delete all data SQL command


readSQL

java.lang.String readSQL
Read single object (by primary key) SQL command


readByDataSQL

java.lang.String readByDataSQL
Read single object (by data) SQL command


selectSQL

java.lang.String selectSQL
Select all data SQL command

Class messif.buckets.storage.impl.DatabaseStorage.BinarySerializableColumnConvertor extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

storedObjectsClass

java.lang.Class<T> storedObjectsClass
Class of instances serialized into the database


serializator

BinarySerializator serializator
Serializator that is used for storing/restoring the data into the database

Class messif.buckets.storage.impl.DiskStorage extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Read the serialized disk storage from an object stream.

Throws:
java.io.IOException - if there was an I/O error during deserialization
java.lang.ClassNotFoundException - if there was an unknown object in the stream
Serialized Fields

bufferSize

int bufferSize
Buffer sizes for read/write operations


bufferDirect

boolean bufferDirect
Allocate the buffers for read/write operations as direct


file

java.io.File file
The file with data


startPosition

long startPosition
The position in the file where this storage starts (the real data starts at startPosition + headerSize)


maximalLength

long maximalLength
The maximal length of the file


serializator

BinarySerializator serializator
Serializator responsible for storing (and restoring) binary objects in the file


storedObjectsClass

java.lang.Class<T> storedObjectsClass
Class of objects that the this storage works with


references

int references
Number of items that reference this disk storage

Class messif.buckets.storage.impl.MemoryStorage extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

storedObjectsClass

java.lang.Class<T> storedObjectsClass
Class of objects that the this storage works with


items

java.lang.Object[] items
Array buffer into which objects are stored


size

int size
Size of the actually used storage


deleted

int deleted
Number of deleted objects, i.e. "nulled" items


Package messif.netbucket

Class messif.netbucket.BucketCreateReplyMessage extends BucketReplyMessage implements Serializable

serialVersionUID: 2L

Serialized Fields

bucketID

int bucketID
ID of the bucket that was created on the remote network node


capacity

long capacity
Capacity of the created bucket

Class messif.netbucket.BucketCreateRequestMessage extends BucketRequestMessage<BucketCreateReplyMessage> implements Serializable

serialVersionUID: 1L

Class messif.netbucket.BucketExceptionReplyMessage extends BucketReplyMessage implements Serializable

serialVersionUID: 1L

Serialized Fields

bucketException

BucketStorageException bucketException
Bucket storage exception to pass back to the originator


runtimeException

java.lang.RuntimeException runtimeException
Runtime exception to pass back to the originator

Class messif.netbucket.BucketProcessQueryReplyMessage extends BucketReplyMessage implements Serializable

serialVersionUID: 1L

Serialized Fields

query

QueryOperation<TAnswer> query
Query operation processed on a remote bucket

Class messif.netbucket.BucketProcessQueryRequestMessage extends BucketRequestMessage<BucketProcessQueryReplyMessage> implements Serializable

serialVersionUID: 1L

Serialized Fields

query

QueryOperation<TAnswer> query
Query operation to process on a remote bucket

Class messif.netbucket.BucketRemoveReplyMessage extends BucketReplyMessage implements Serializable

serialVersionUID: 1L

Serialized Fields

removed

boolean removed

Class messif.netbucket.BucketRemoveRequestMessage extends BucketRequestMessage<BucketRemoveReplyMessage> implements Serializable

serialVersionUID: 1L

Class messif.netbucket.BucketReplyMessage extends ReplyMessage implements Serializable

serialVersionUID: 1L

Class messif.netbucket.BucketRequestMessage extends Message implements Serializable

serialVersionUID: 3L

Serialized Fields

bucketID

int bucketID
ID of a remote bucket on which to process the request

Class messif.netbucket.NetworkBucketDispatcher extends BucketDispatcher implements Serializable

serialVersionUID: 1L

Serialized Fields

messageDisp

MessageDispatcher messageDisp
Message dispatcher associated with this network bucket dispatcher

Class messif.netbucket.RemoteAbstractObject extends AbstractObject implements Serializable

serialVersionUID: 3L

Serialized Fields

bucket

RemoteBucket bucket
Bucket in which this object resides

Class messif.netbucket.RemoteBucket extends Bucket implements Serializable

serialVersionUID: 1L

Serialized Fields

bucketID

int bucketID
ID of the bucket on the remote node


remoteNetworkNode

NetworkNode remoteNetworkNode
Remote node on which the bucket resides


netbucketDisp

NetworkBucketDispatcher netbucketDisp
Network storage (bucket) dispatcher to which this remote bucket is associated


capacity

long capacity
The maximal (hard) capacity of the remote bucket


Package messif.netbucket.replication

Class messif.netbucket.replication.ReplicationBucket extends LocalBucket implements Serializable

serialVersionUID: 1L

Serialized Fields

bucketDispatcher

ReplicationNetworkBucketDispatcher bucketDispatcher

encapsulatedBucket

LocalBucket encapsulatedBucket

replicas

java.util.List<E> replicas

nextReplicaForGet

java.util.concurrent.atomic.AtomicInteger nextReplicaForGet

replicaManipulationLock

java.util.concurrent.locks.ReadWriteLock replicaManipulationLock

Class messif.netbucket.replication.ReplicationNetworkBucketDispatcher extends NetworkBucketDispatcher implements Serializable

serialVersionUID: 1L

Serialized Fields

bucketOperationDistcompCounter

StatisticSimpleWeakrefCounter bucketOperationDistcompCounter
Statistic for per query operation DC


replicateBucketsEqually

boolean replicateBucketsEqually
If true then automatically replicate all bucket at the same nodes


Package messif.netcreator

Class messif.netcreator.BroadcastCreator extends NetworkNodeDispatcher implements Serializable

serialVersionUID: 1L

Serialized Fields

pool

java.util.Set<E> pool
Internal data

Class messif.netcreator.CantStartException extends java.lang.Exception implements Serializable

serialVersionUID: 1L

Class messif.netcreator.CentralCreator extends NetworkNodeDispatcher implements Serializable

serialVersionUID: 1L

Serialized Fields

pool

java.util.Set<E> pool
Internal data


centralNode

NetworkNode centralNode

active

boolean active

Class messif.netcreator.MessageActivate extends Message implements Serializable

serialVersionUID: 1L

Serialized Fields

netnodes

java.util.Set<E> netnodes
Message extensions

Class messif.netcreator.MessageActivateResponse extends ReplyMessage implements Serializable

serialVersionUID: 1L

Serialized Fields

response

byte response
Message extensions


activatedNode

NetworkNode activatedNode

Class messif.netcreator.MessageImHere extends Message implements Serializable

serialVersionUID: 1L

Class messif.netcreator.MessageImUsed extends Message implements Serializable

serialVersionUID: 1L

Class messif.netcreator.NetworkNodeDispatcher extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

startables

Startable[] startables
Registered startables


Package messif.network

Class messif.network.Message extends java.lang.Object implements Serializable

serialVersionUID: 3L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Deserialization from network socket. The actual navigation element is added to the navigation path and a new element is created.

Throws:
java.io.IOException - if there was a problem reading the data from the stream
java.lang.ClassNotFoundException - if an unknown class was encountered while reading objects from the stream
Serialized Fields

messageID

long messageID
The message ID


navigationPath

java.util.List<E> navigationPath
Navigation path this message has gone through


actualNavigationElement

NavigationElement actualNavigationElement
Actual navigation element

Class messif.network.MessageDispatcher extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialization Methods

writeReplace

private java.lang.Object writeReplace()
Returns an alternative object to be used when serializing MessageDispatcher. During its deserialization the correct full MessageDispatcher is recreated.

Serialized Fields

receivers

java.util.List<E> receivers
List of currently registered receivers


replyReceivers

messif.network.ReplyReceiverList replyReceivers
List of currently registered reply receivers


udpSocket

java.net.DatagramSocket udpSocket
UDP socket for communication


tcpSocket

java.net.ServerSocket tcpSocket
TCP socket for communication


broadcastSocket

java.net.MulticastSocket broadcastSocket
UDP multicast socket for broadcast communication It is null if broadcast is not initialized.


ourNetworkNode

NetworkNode ourNetworkNode
Identification of this network node


topMessageDispatcher

MessageDispatcher topMessageDispatcher
Top most message dispatcher in the hierarchy

Class messif.network.NavigationElement extends java.lang.Object implements Serializable

serialVersionUID: 2L

Serialized Fields

sender

NetworkNode sender
The sender of the message for this particular hop


destination

NetworkNode destination
The destination of the message for this particular hop


notWaitingDestinations

java.util.Set<E> notWaitingDestinations
The destinations, where the message was sent so far using the sendMessage during this particular hop


waitingDestinations

java.util.Set<E> waitingDestinations
The destinations, where the message was sent so far using the sendMessageWaitReply during this particular hop


reply

boolean reply
The flag if the message was sent as reply


skipWaiting

boolean skipWaiting
The flag if this message was marked to skip the message waiting for the sender node


statistics

OperationStatistics statistics
OperationStatistics gathered during this particular hop

Class messif.network.NetworkNode extends java.lang.Object implements Serializable

serialVersionUID: 3L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Deserialization method. Object is loaded as usuall, but its host (and optionally port) is changed according to the mapping table.

Throws:
java.io.IOException
java.lang.ClassNotFoundException
Serialized Fields

host

java.net.InetAddress host
IP address of this network node


port

int port
TCP/UDP port of this network node


nodeID

java.lang.Integer nodeID
Identification of a specific node, when several logical nodes are running on one physical peer. They will also share the message dispatchers, where the top-level dispatcher has no nodeID set. It is null if nodeID is not used.

Class messif.network.ReplyMessage extends Message implements Serializable

serialVersionUID: 1L


Package messif.objects

Class messif.objects.AbstractObject extends UniqueID implements Serializable

serialVersionUID: 4L

Serialized Fields

objectKey

AbstractObjectKey objectKey
The key of this object - it must contain the URI.

Class messif.objects.BallRegion extends LocalAbstractObject implements Serializable

serialVersionUID: 1L

Serialized Fields

pivot

LocalAbstractObject pivot
Center of the ball region


radius

float radius
Radius of this region

Class messif.objects.LocalAbstractObject extends AbstractObject implements Serializable

serialVersionUID: 4L

Serialized Fields

suppData

java.lang.Object suppData
Supplemental data object


distanceFilter

PrecomputedDistancesFilter distanceFilter
Object for storing and using precomputed distances

Class messif.objects.LocalAbstractObjectAutoImpl extends LocalAbstractObject implements Serializable

serialVersionUID: 1L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Throws:
java.io.IOException
java.lang.ClassNotFoundException

writeObject

private void writeObject(java.io.ObjectOutputStream out)
                  throws java.io.IOException
Binary serialization

Throws:
java.io.IOException

Class messif.objects.MetaObject extends LocalAbstractObject implements Serializable

serialVersionUID: 2L

Serialization Methods

readObject

protected <E> E readObject(java.io.BufferedReader stream,
                           java.lang.Class<E> objectClass)
                throws java.io.IOException
Reads one object with the specified class name from the stream. The class name is looked up first - it must be a descendant of LocalAbstractObject. Then, a constructor with BufferedReader argument is used to load the object up.

Throws:
java.io.IOException - if there was an error resolving the specified class or its constuctor or a problem occurred while reading from the stream

readObject

protected LocalAbstractObject readObject(java.io.BufferedReader stream,
                                         java.lang.String className)
                                  throws java.io.IOException
Reads one object with the specified class name from the stream. The class name is looked up first - it must be a descendant of LocalAbstractObject. Then, a constructor with BufferedReader argument is used to load the object up.

Throws:
java.io.IOException - if there was an error resolving the specified class or its constuctor or a problem occurred while reading from the stream

Class messif.objects.NoDataObject extends AbstractObject implements Serializable

serialVersionUID: 1L

Class messif.objects.PrecompDistPerforatedArrayFilter extends PrecomputedDistancesFixedArrayFilter implements Serializable

serialVersionUID: 1L

Class messif.objects.PrecomputedDistancesFilter extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

nextFilter

PrecomputedDistancesFilter nextFilter
The next filter in this chain

Class messif.objects.PrecomputedDistancesFixedArrayFilter extends PrecomputedDistancesFilter implements Serializable

serialVersionUID: 1L

Serialized Fields

precompDist

float[] precompDist
The list of precomputed distances


actualSize

int actualSize
The actual size of precompDist (if it was pre-buffered)

Class messif.objects.PrecomputedDistancesPivotMapFilter extends PrecomputedDistancesFilter implements Serializable

serialVersionUID: 1L

Serialized Fields

precompDistMapping

java.util.Map<K,V> precompDistMapping
The hash table of precomputed distances

Class messif.objects.UniqueID extends java.lang.Object implements Serializable

serialVersionUID: -1584641682281614360L

Serialized Fields

mostSigBits

long mostSigBits
The most significant 64 bits of this UniqueID.


leastSigBits

long leastSigBits
The least significant 64 bits of this UniqueID.


Package messif.objects.extraction

Class messif.objects.extraction.ExtractorException extends java.lang.Exception implements Serializable

serialVersionUID: 1L


Package messif.objects.impl

Class messif.objects.impl.MetaObjectMap extends MetaObject implements Serializable

serialVersionUID: 1L

Serialized Fields

objects

java.util.Map<K,V> objects
List of encapsulated objects

Class messif.objects.impl.ObjectByteVector extends LocalAbstractObject implements Serializable

serialVersionUID: 1L

Serialized Fields

data

byte[] data

Class messif.objects.impl.ObjectByteVectorL1 extends ObjectByteVector implements Serializable

serialVersionUID: 1L

Class messif.objects.impl.ObjectFloatUnitVector extends ObjectFloatVector implements Serializable

serialVersionUID: 23701L

Class messif.objects.impl.ObjectFloatUnitVectorL2 extends ObjectFloatUnitVector implements Serializable

serialVersionUID: 23601L

Class messif.objects.impl.ObjectFloatVector extends LocalAbstractObject implements Serializable

serialVersionUID: 1L

Serialized Fields

data

float[] data
Data array

Class messif.objects.impl.ObjectFloatVectorL1 extends ObjectFloatVector implements Serializable

serialVersionUID: 1L

Class messif.objects.impl.ObjectFloatVectorL2 extends ObjectFloatVector implements Serializable

serialVersionUID: 1L

Class messif.objects.impl.ObjectIntVector extends LocalAbstractObject implements Serializable

serialVersionUID: 1L

Serialized Fields

data

int[] data

Class messif.objects.impl.ObjectIntVectorL1 extends ObjectIntVector implements Serializable

serialVersionUID: 1L

Class messif.objects.impl.ObjectIntVectorL2 extends ObjectIntVector implements Serializable

serialVersionUID: 1L

Class messif.objects.impl.ObjectShortVector extends LocalAbstractObject implements Serializable

serialVersionUID: 1L

Serialized Fields

data

short[] data

Class messif.objects.impl.ObjectShortVectorL1 extends ObjectShortVector implements Serializable

serialVersionUID: 1L

Class messif.objects.impl.ObjectShortVectorL2 extends ObjectShortVector implements Serializable

serialVersionUID: 1L

Class messif.objects.impl.ObjectString extends LocalAbstractObject implements Serializable

serialVersionUID: 1L

Serialized Fields

text

java.lang.String text

Class messif.objects.impl.ObjectStringEditDist extends ObjectString implements Serializable

serialVersionUID: 1L

Serialized Fields

insertDeleteWeight

int insertDeleteWeight
Weight of the insert and delete operations during the edit distance computation


Package messif.objects.keys

Class messif.objects.keys.AbstractObjectKey extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

locatorURI

java.lang.String locatorURI
The URI locator

Class messif.objects.keys.DoubleKey extends AbstractObjectKey implements Serializable

serialVersionUID: 1L

Serialized Fields

key

double key
The double key

Class messif.objects.keys.DoubleKeyInterval extends KeyInterval<DoubleKey> implements Serializable

serialVersionUID: 1L

Serialized Fields

from

DoubleKey from
Lower bound (inclusive).


to

DoubleKey to
Upeer bound (inclusive).

Class messif.objects.keys.DoubleKeyOperator extends KeyOperator<DoubleKey> implements Serializable

serialVersionUID: 1L

Class messif.objects.keys.IntegerKey extends AbstractObjectKey implements Serializable

serialVersionUID: 1L

Serialized Fields

key

int key
The integer key

Class messif.objects.keys.LongKey extends AbstractObjectKey implements Serializable

serialVersionUID: 1L

Serialized Fields

key

long key
The long key


Package messif.objects.nio

Class messif.objects.nio.CachingSerializator extends MultiClassSerializator<T> implements Serializable

serialVersionUID: 1L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Read this serializator from the object stream

Throws:
java.io.IOException
java.lang.ClassNotFoundException
Serialized Fields

cachedClasses

java.util.Map<K,V> cachedClasses
The hash table of cached classes with references to the constructor/factory method lists

Class messif.objects.nio.MultiClassSerializator extends BinarySerializator implements Serializable

serialVersionUID: 2L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Read this serializator from an object stream.

Throws:
java.io.IOException - if there was an I/O error reading the serializator from the stream
java.lang.ClassNotFoundException - if there was an error resolving object class

readObject

public T readObject(BinaryInput input)
             throws java.io.IOException,
                    java.lang.IllegalArgumentException
Reads an instance from the input using this serializator. The default class that is expected to be in the buffer.

Throws:
java.io.IOException - if there was an I/O error
java.lang.IllegalArgumentException - if the constructor or the factory method has a wrong prototype
Serialized Fields

defaultClass

java.lang.Class<T> defaultClass
The first class in the predefinedClasses is used as default

Class messif.objects.nio.SingleClassSerializator extends BinarySerializator implements Serializable

serialVersionUID: 1L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Read this serializator from an object stream.

Throws:
java.io.IOException - if there was an I/O error reading the serializator from the stream
java.lang.ClassNotFoundException - if there was an error resolving object class

readObject

public T readObject(BinaryInput input)
             throws java.io.IOException,
                    java.lang.IllegalArgumentException
Reads an instance from the input using this serializator. The default class that is expected to be in the buffer.

Throws:
java.io.IOException - if there was an I/O error
java.lang.IllegalArgumentException - if the constructor or the factory method has a wrong prototype
Serialized Fields

deserializationClass

java.lang.Class<T> deserializationClass
The class of objects created by this serializator during deserialization


Package messif.objects.util

Class messif.objects.util.AbstractObjectList extends java.util.ArrayList<E extends AbstractObject> implements Serializable

serialVersionUID: 1L

Class messif.objects.util.AggregationFunction extends java.lang.Object implements Serializable

serialVersionUID: 1L

Class messif.objects.util.DistanceRankedObject extends java.lang.Object implements Serializable

serialVersionUID: 50201L

Serialized Fields

object

java.lang.Object object
Encapsulated object


distance

float distance
Distance that represents the rank of this object

Class messif.objects.util.DoubleSortedCollection extends RankedSortedCollection implements Serializable

Serialized Fields

originalDistances

java.util.Map<K,V> originalDistances
Distances to be used for pivot filtering - the original distances without the new sorting distances.


thresholdObject

RankedAbstractObject thresholdObject
Object from the collectio with the threshold distance for pivot filtering - this distance cannot be simply the last distance including the keywords distance, because the keywords ditance cannot be considered for filtering.

Class messif.objects.util.GenericMatchingObjectList extends java.util.TreeMap<java.lang.Integer,AbstractObjectList<E extends AbstractObject>> implements Serializable

serialVersionUID: 1L

Class messif.objects.util.RankedAbstractMetaObject extends RankedAbstractObject implements Serializable

serialVersionUID: 1L

Serialized Fields

subDistances

float[] subDistances
Array of distances to respective sub-objects

Class messif.objects.util.RankedAbstractObject extends DistanceRankedObject<AbstractObject> implements Serializable

serialVersionUID: 1L

Class messif.objects.util.RankedSortedCollection extends SortedCollection<RankedAbstractObject> implements Serializable

serialVersionUID: 1L


Package messif.objects.util.impl

Class messif.objects.util.impl.AggregationFunctionEvaluator extends AggregationFunction implements Serializable

serialVersionUID: 1L

Serialized Fields

variableNames

java.lang.String[] variableNames
Parsed variable names that are used in evaluation


maxDistances

float[] maxDistances
Maximal distances for the variables


pattern

PatternToken pattern
The top level token that encapsulates the whole aggregation function string.

Class messif.objects.util.impl.ArithmeticFunctionToken extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

function

ArithmeticFunctionToken.FunctionType function
Function type


operand

PatternToken operand
Operand

Class messif.objects.util.impl.ArithmeticOperatorToken extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

operand1

PatternToken operand1
First operand


operator

ArithmeticOperatorToken.OperatorType operator
Operator type


operand2

PatternToken operand2
Second operand

Class messif.objects.util.impl.ConstantToken extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

constant

float constant
The float constant.

Class messif.objects.util.impl.SubdistanceToken extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

name

java.lang.String name
Subdistance string name


index

int index
Subdistance index

Class messif.objects.util.impl.ThresholdFunctionSimpleEvaluator extends AggregationFunction implements Serializable

serialVersionUID: 1L

Serialized Fields

variableNames

java.lang.String[] variableNames
Parsed variable names that are used in evaluation


variableCoeffs

float[] variableCoeffs
Parsed variable coefficients (weights) that are used in evaluation


Package messif.operations

Class messif.operations.AbstractOperation extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

suppData

java.lang.Object suppData
Supplemental data object


operID

java.util.UUID operID
An universaly unique identification of the operation


errValue

ErrorCode errValue
Operation result code

Class messif.operations.ListingQueryOperation extends QueryOperation<AbstractObject> implements Serializable

serialVersionUID: 1L

Serialized Fields

answer

java.util.List<E> answer
List holding the answer of this query

Class messif.operations.OperationErrorCode extends ErrorCode implements Serializable

serialVersionUID: 1L

Class messif.operations.QueryOperation extends AbstractOperation implements Serializable

serialVersionUID: 2L

Serialized Fields

answerType

AnswerType answerType
Types of objects this query operation will return

Class messif.operations.RankingQueryOperation extends QueryOperation<RankedAbstractObject> implements Serializable

serialVersionUID: 1L

Serialized Fields

answer

RankedSortedCollection answer
Set holding the answer of this query


storeMetaDistances

boolean storeMetaDistances
Flag whether to store sub-distances for metaobjects

Class messif.operations.SingletonQueryOperation extends QueryOperation<AbstractObject> implements Serializable

serialVersionUID: 1L

Serialized Fields

answer

AbstractObject answer
Answer of this query, will be null if the object cannot be found


Package messif.operations.data

Class messif.operations.data.BulkInsertOperation extends AbstractOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

insertedObjects

AbstractObjectList<E extends AbstractObject> insertedObjects
List of objects to insert

Class messif.operations.data.DeleteByLocatorOperation extends AbstractOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

locators

java.util.Set<E> locators
The locators of the objects to delete


deleteLimit

int deleteLimit
Maximal number of deleted objects, zero means unlimited


objects

java.util.List<E> objects
List of all actually deleted objects

Class messif.operations.data.DeleteOperation extends AbstractOperation implements Serializable

serialVersionUID: 2L

Serialized Fields

deletedObject

LocalAbstractObject deletedObject
Object to match the data against


deleteLimit

int deleteLimit
Maximal number of deleted objects, zero means unlimited


checkLocator

boolean checkLocator
Flag whether to check that the deleted object's locator is equal to DeleteOperation.deletedObject's locator


objects

java.util.List<E> objects
List of all actually deleted objects

Class messif.operations.data.InsertOperation extends AbstractOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

insertedObject

LocalAbstractObject insertedObject
Inserted object


Package messif.operations.query

Class messif.operations.query.AggregationFunctionQueryOperation extends RankingQueryOperation implements Serializable

serialVersionUID: 29601L

Serialized Fields

queryObject

MetaObject queryObject
Query object (accessible directly)


k

int k
Number of nearest (top) objects to retrieve


aggregationFunction

AggregationFunction aggregationFunction
Threshold function for measuring the overall similarity

Class messif.operations.query.ApproxKNNQueryOperation extends KNNQueryOperation implements Serializable

serialVersionUID: 3L

Serialized Fields

localSearchType

ApproxKNNQueryOperation.LocalSearchType localSearchType
Type of the local approximation parameter used.


localSearchParam

int localSearchParam
Value of the local approximation parameter. Its interpretation depends on the value of ApproxKNNQueryOperation.localSearchType.


radiusGuaranteed

float radiusGuaranteed
Radius for which the answer is guaranteed as correct. It is specified in the constructor and can influence the level of approximation. An algorithm evaluating this query can also change this value, so it can notify about the guarantees of evaluation.

Class messif.operations.query.ApproxRangeQueryOperation extends RangeQueryOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

localSearchType

ApproxRangeQueryOperation.LocalSearchType localSearchType
Type of the local approximation parameter used.


localSearchParam

int localSearchParam
Value of the local approximation parameter. Its interpretation depends on the value of ApproxRangeQueryOperation.localSearchType.


radiusGuaranteed

float radiusGuaranteed
Radius for which the answer is guaranteed as correct. It is specified in the constructor and can influence the level of approximation. An algorithm evaluating this query can also change this value, so it can notify about the guarantees of evaluation.

Class messif.operations.query.GetAllObjectsQueryOperation extends ListingQueryOperation implements Serializable

serialVersionUID: 1L

Class messif.operations.query.GetObjectByLocatorOperation extends SingletonQueryOperation implements Serializable

serialVersionUID: 2L

Serialized Fields

locator

java.lang.String locator
The locator of the desired object

Class messif.operations.query.GetObjectCountOperation extends AbstractOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

objectCount

int objectCount
The number of objects counted by this operation

Class messif.operations.query.GetObjectQueryOperation extends SingletonQueryOperation implements Serializable

serialVersionUID: 2L

Serialized Fields

objectID

UniqueID objectID
Identifier for which to retrieve object

Class messif.operations.query.GetObjectsByLocatorsOperation extends RankingQueryOperation implements Serializable

serialVersionUID: 3L

Serialized Fields

locators

java.util.Set<E> locators
The locators of the desired objects


queryObjectForDistances

LocalAbstractObject queryObjectForDistances
The object to compute distances to; if null, UNKNOWN_DISTANCE will be used in answer

Class messif.operations.query.GetRandomObjectQueryOperation extends SingletonQueryOperation implements Serializable

serialVersionUID: 1L

Class messif.operations.query.GetRandomObjectsQueryOperation extends ListingQueryOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

count

int count
Number of random objects to retrieve

Class messif.operations.query.IncrementalNNQueryOperation extends RankingQueryOperation implements Serializable

serialVersionUID: 2L

Serialized Fields

queryObject

LocalAbstractObject queryObject
kNN query object


minNN

int minNN
Minimum number of objects returned by this query. Default value is 1. It can be set to any larger value in order to optimize the process of searching for nearest neighbors. This feature is usually used by distributed incremental search algoritms.


nnAddedToAnswer

int nnAddedToAnswer
The number of nearest neighbors added to the answer since the last call to endOperation(). I.e., how many NN were added in one evaluation of this operation.

Class messif.operations.query.KNNMultiQueryOperation extends RankingQueryOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

queryObjects

LocalAbstractObject[] queryObjects
Query object


k

int k
Number of nearest objects to retrieve

Class messif.operations.query.KNNQueryOperation extends RankingQueryOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

queryObject

LocalAbstractObject queryObject
Query object


k

int k
Number of nearest objects to retrieve

Class messif.operations.query.RangeQueryOperation extends RankingQueryOperation implements Serializable

serialVersionUID: 1L

Serialized Fields

queryObject

LocalAbstractObject queryObject
Range query object


radius

float radius
Range query radius

Class messif.operations.query.TopCombinedQueryOperation extends AggregationFunctionQueryOperation implements Serializable

serialVersionUID: 85603L

Serialized Fields

numberOfInitialSA

int numberOfInitialSA
Number of sorted access objects to retrieve


numberOfInitialSAProgressive

boolean numberOfInitialSAProgressive
Progressive flag for the number of initial sorted accesses. If set to true, the number of numberOfInitialSA is multiplied by k.


numberOfRandomAccesses

int numberOfRandomAccesses
Number of random accesses to execute


initialSAQueryClass

java.lang.Class<T> initialSAQueryClass
Query operation to execute for sorted accesses


Package messif.pivotselection

Class messif.pivotselection.ClusterPivotChooser extends AbstractPivotChooser implements Serializable

serialVersionUID: 1L

Serialized Fields

maxClusterRadius

float maxClusterRadius
Threshold on the maximum distance within a single cluster.

Class messif.pivotselection.CoveragePivotChooser extends AbstractPivotChooser implements Serializable

serialVersionUID: 1L

Serialized Fields

clusterRadius

float clusterRadius
Ball size -- radius of the cluster.


clusterDiameter

float clusterDiameter
Ball size multiplied by two

Class messif.pivotselection.IncrementalIDistanceChooser extends AbstractPivotChooser implements Serializable

serialVersionUID: 1L

Serialized Fields

sampleSetSize

int sampleSetSize
Size of the sample set used to test the candidate pivot (used to estimate mu_d)


samplePivotSize

int samplePivotSize
Size of the candidate set of pivots from which one pivot will be picked.

Class messif.pivotselection.IncrementalPivotChooser extends AbstractPivotChooser implements Serializable

serialVersionUID: 1L

Serialized Fields

sampleSize

int sampleSize
Current size of sample sets used to estimate the quality of pivots. Equal to zero when not initilized.


leftPair

AbstractObjectList<E extends AbstractObject> leftPair
Two lists of objects used as samples to estimate the quality of pivots. They are randomly picked among all objects in the bucket.


rightPair

AbstractObjectList<E extends AbstractObject> rightPair

distsFormer

float[] distsFormer
Using pivots we transform the metric space into (R^np,L_max) space where np is the number of pivots. This array caches maximum distances between a left and a right sample objects with respect to the currently selected pivots.


changesFromLastSampleSetSelection

int changesFromLastSampleSetSelection
Number of objects added to or deleted from this bucket since the last selection of sample sets.

Class messif.pivotselection.OnFlyRandomPivotChooser extends RandomPivotChooser implements Serializable

serialVersionUID: 1L

Class messif.pivotselection.OutlierPivotChooser extends AbstractPivotChooser implements Serializable

serialVersionUID: 1L

Class messif.pivotselection.RandomPivotChooser extends AbstractPivotChooser implements Serializable

serialVersionUID: 1L

Class messif.pivotselection.StreamSequencePivotChooser extends AbstractPivotChooser implements Serializable

serialVersionUID: 1L

Serialized Fields

stream

AbstractStreamObjectIterator<E extends LocalAbstractObject> stream
Stream to read pivots from

Class messif.pivotselection.TwoDistantIncrementalPivotChooser extends AbstractPivotChooser implements Serializable

serialVersionUID: 1L

Serialized Fields

pivotsDistance

float pivotsDistance
Actual selected pivots' distance


Package messif.statistics

Class messif.statistics.OperationStatistics extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

statistics

messif.statistics.StatisticsList statistics
Local operation statistic objects

Class messif.statistics.StatisticCounter extends Statistics<StatisticCounter> implements Serializable

serialVersionUID: 1L

Serialized Fields

value

long value

valueCheckpoint

long valueCheckpoint

Class messif.statistics.StatisticMinMaxCounter extends Statistics<StatisticMinMaxCounter> implements Serializable

serialVersionUID: 1L

Serialized Fields

min

double min
Counter operation


max

double max

sum

double sum

count

long count

countCheckpoint

long countCheckpoint

Class messif.statistics.StatisticObject extends Statistics<StatisticObject> implements Serializable

serialVersionUID: 1L

Serialized Fields

value

java.lang.Object value
Object operation


valueCheckpoint

java.lang.Object valueCheckpoint

Class messif.statistics.StatisticRefCounter extends Statistics<StatisticRefCounter> implements Serializable

serialVersionUID: 1L

Serialized Fields

values

java.util.Map<K,V> values
Reference counter data


valueSumCheckpoint

long valueSumCheckpoint

Class messif.statistics.Statistics extends java.lang.Object implements Serializable

serialVersionUID: 3L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Throws:
java.io.IOException
java.lang.ClassNotFoundException

writeObject

private void writeObject(java.io.ObjectOutputStream out)
                  throws java.io.IOException
Throws:
java.io.IOException

readResolve

protected java.lang.Object readResolve()
                                throws java.io.ObjectStreamException
Throws:
java.io.ObjectStreamException
Serialized Fields

name

java.lang.String name
Name of this statistic

Class messif.statistics.StatisticSimpleWeakrefCounter extends Statistics<StatisticSimpleWeakrefCounter> implements Serializable

serialVersionUID: 1L

Serialization Methods

readObject

private void readObject(java.io.ObjectInputStream in)
                 throws java.io.IOException,
                        java.lang.ClassNotFoundException
Constructors

Throws:
java.io.IOException
java.lang.ClassNotFoundException
Serialized Fields

checkpointValue

int checkpointValue
Checkpoint value for recognizing change of state

Class messif.statistics.StatisticSlidingAvgCounter extends Statistics<StatisticSlidingAvgCounter> implements Serializable

serialVersionUID: 1L

Serialized Fields

resetTime

long resetTime
Remember the time stamp of reseting (or creating) the statistics


values

java.util.LinkedList<E> values
Queue of actual values with their time stamps - expect that this queue is sorted according to the times


sum

double sum
aggregated values


count

int count

maxNumberOfValues

int maxNumberOfValues
number of values taken into account if <= 0 then use all values - default is 100


windowSizeMilis

long windowSizeMilis
size of time window in milis - default is -1 (do not use time)


countCheckpoint

long countCheckpoint
backed-up state for checkpointing feature

Class messif.statistics.StatisticSlidingAvgCounter.ValueTime extends java.lang.Object implements Serializable

serialVersionUID: 2L

Serialized Fields

value

double value

time

long time

key

java.lang.Object key

Class messif.statistics.StatisticTimer extends Statistics<StatisticTimer> implements Serializable

serialVersionUID: 1L

Serialized Fields

time

long time

lastStartTime

long lastStartTime

timeCheckpoint

long timeCheckpoint

Package messif.utility

Class messif.utility.ErrorCode extends java.lang.Object implements Serializable

serialVersionUID: 1L

Serialized Fields

text

java.lang.String text
Holder of the current error code text

Class messif.utility.ExtendedProperties extends java.util.Properties implements Serializable

serialVersionUID: 1L

Class messif.utility.ExtendedPropertiesException extends java.lang.RuntimeException implements Serializable

serialVersionUID: 1L

Class messif.utility.SortedCollection extends SortedArrayData<T,T> implements Serializable

serialVersionUID: 1L

Serialized Fields

comparator

java.util.Comparator<T> comparator
Comparator used to maintain order in this collection


items

java.lang.Object[] items
Array buffer into which the elements of the SortedCollection are stored


size

int size
Size of the SortedCollection (the number of elements it contains)


capacity

int capacity
Maximal capacity of the collection