Index

A B C D E F G H I J K L M N O P Q R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

add(int, long) - Method in class org.rostore.v2.seq.BlockIndexSequence
 
add(long, long) - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
add(long, long, boolean) - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Adds a set of blocks from the range - to the catalog.
add(CatalogBlockIndices) - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
add(CatalogBlockIndices, boolean) - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
add(CatalogBlockIndices, boolean) - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Adds a set of blocks to the catalog.
addEntriesNumber(int) - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Adds number of entries in this block
addFreeBlock(int) - Method in class org.rostore.v2.seq.BlockSequence
Inserts a new block after the given index in the sequence.
addKey(byte[]) - Method in class org.rostore.v2.keys.KeyList
Add a key to the list
addListener(BlockAllocatorListener) - Method in class org.rostore.v2.media.block.allocator.BlockAllocatorListeners
Add listener to be notified
addNewEntryFor(long, long) - Method in class org.rostore.v2.catalog.CatalogBlockEntry
 
addOption(RecordOption) - Method in class org.rostore.entity.Record
Adds an option to the record object
addOptions(Set<RecordOption>) - Method in class org.rostore.entity.Record
Adds a set of options to the record object
allocate(BlockType) - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Allocate one block
allocate(BlockType, boolean) - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
Allocate just one block
allocate(BlockType, int) - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Allocates a given number of blocks.
allocate(BlockType, int, boolean) - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
provide a list of blocks to be used
allocateBlock(BlockType) - Method in interface org.rostore.v2.media.block.BlockProvider
Allocates a block with the help of BlockAllocator and adds it to the associated BlockContainer.
APIKEY_CONTAINER_NAME - Static variable in class org.rostore.service.apikey.ApiKeyManager
 
APIKEY_HEADER - Static variable in class org.rostore.service.Headers
 
ApiKeyDefinition - Class in org.rostore.entity.apikey
A class that puts together the api key and value in form of ApiKeyPermissions.
ApiKeyDefinition() - Constructor for class org.rostore.entity.apikey.ApiKeyDefinition
 
ApiKeyDefinition(String, ApiKeyPermissions) - Constructor for class org.rostore.entity.apikey.ApiKeyDefinition
 
ApiKeyManager - Class in org.rostore.service.apikey
Singleton used in the RoStore service to control access to the APIKeys.
ApiKeyManager() - Constructor for class org.rostore.service.apikey.ApiKeyManager
 
ApiKeyPermissions - Class in org.rostore.entity.apikey
Defines permissions associated with APIKEY
ApiKeyPermissions() - Constructor for class org.rostore.entity.apikey.ApiKeyPermissions
 
ApiKeyRequestContext - Class in org.rostore.service.apikey
Class is injected in the REST filters and extract information about the API key of the current request.
ApiKeyRequestContext() - Constructor for class org.rostore.service.apikey.ApiKeyRequestContext
 
ApiKeys - Class in org.rostore.client
Class is used to access and modify the api keys on the storage.
ApiKeys(RoStoreClient) - Constructor for class org.rostore.client.ApiKeys
 
ApiKeyService - Class in org.rostore.service
 
ApiKeyService() - Constructor for class org.rostore.service.ApiKeyService
 
apply(long, long) - Method in interface org.rostore.v2.catalog.EntrySizeListener
Called when the number of entries changes
AsyncContainer - Class in org.rostore.v2.container.async
A representation of the rostore container.
AsyncContainer(AsyncContainers, Container) - Constructor for class org.rostore.v2.container.async.AsyncContainer
 
AsyncContainerAccessException - Exception Class in org.rostore.v2.container.async
 
AsyncContainerAccessException(String) - Constructor for exception class org.rostore.v2.container.async.AsyncContainerAccessException
 
AsyncContainerAccessException(String, Throwable) - Constructor for exception class org.rostore.v2.container.async.AsyncContainerAccessException
 
AsyncContainerMedia - Class in org.rostore.v2.container.async
 
AsyncContainerMediaProperties - Class in org.rostore.v2.container.async
 
AsyncContainerMediaProperties() - Constructor for class org.rostore.v2.container.async.AsyncContainerMediaProperties
 
AsyncContainers - Class in org.rostore.v2.container.async
 
AsyncException - Exception Class in org.rostore.v2.container.async
 
AsyncException(Throwable) - Constructor for exception class org.rostore.v2.container.async.AsyncException
 
AsyncFunction<I> - Interface in org.rostore.v2.container.async
 
AsyncListener - Interface in org.rostore.v2.container.async
 
AsyncStatus - Enum Class in org.rostore.v2.container.async
 
AsyncStream<S> - Class in org.rostore.v2.container.async
This class is a wrapper around the stream (input or output).
autonomousKey(int, OperationType, Runnable) - Static method in class org.rostore.v2.container.async.Operation
 
autonomousValue(int, OperationType, long, Runnable) - Static method in class org.rostore.v2.container.async.Operation
 
AVG_FREE_BLOCK_NUMBER - Static variable in class org.rostore.v2.seq.Properties
The expected number of free blocks the sequence should preferably have.

B

back(int) - Method in class org.rostore.v2.media.block.Block
Moves current position by the provided number of bytes back.
backBlockIndex() - Method in class org.rostore.v2.media.block.Block
Moves current position by the size of the block index length back (see MapperProperties.getBytesPerBlockIndex()).
backInt() - Method in class org.rostore.v2.media.block.Block
Moves current position by the size of the 4 bytes back.
backLong() - Method in class org.rostore.v2.media.block.Block
Moves current position by the size of the 8 bytes back.
BINARY - Enum constant in enum class org.rostore.client.ContentType
 
BinaryMapper - Class in org.rostore.mapper
A class to serialize and deserialize java classes to the binary stream.
BinaryMapper() - Constructor for class org.rostore.mapper.BinaryMapper
 
Block - Class in org.rostore.v2.media.block
An object to access and modify the data in the boundaries of one block.
Block(ByteBuffer, MappedPhysicalBlock, BlockContainer) - Constructor for class org.rostore.v2.media.block.Block
 
BlockAllocation - Interface in org.rostore.entity
Information regarding allocation of the blocks with the ro-store components
BlockAllocationState - Class in org.rostore.entity
Materialized object that implements BlockAllocation
BlockAllocator - Class in org.rostore.v2.media.block.allocator
This interface allows to allocate and free blocks.
BlockAllocatorInternal - Interface in org.rostore.v2.media.block.allocator
This interface allows to allocate and free blocks What rebalance is? The allocation involves usage of blocks where the catalog is stored.
BlockAllocatorListener - Interface in org.rostore.v2.media.block.allocator
An instance of this listener can be provided to BlockAllocator, which will be notified if the blocks are freed or allocated
BlockAllocatorListeners - Class in org.rostore.v2.media.block.allocator
This is the holder of all block allocator's listeners.
BlockAllocatorListeners() - Constructor for class org.rostore.v2.media.block.allocator.BlockAllocatorListeners
 
BlockContainer - Class in org.rostore.v2.media.block.container
Specifies a set of blocks in the current transaction.
BlockContainer(Media, int) - Constructor for class org.rostore.v2.media.block.container.BlockContainer
This should never be used directly Use Media.newBlockContainer() instead or InternalBlockProvider.create(BlockAllocator)
BlockIndex - Annotation Interface in org.rostore.mapper
Annotation that can be used on the fields of the java objects that store a block index.
BlockIndexSequence - Class in org.rostore.v2.seq
This is the list of blocks which is used in the sequences
BlockIndexSequence() - Constructor for class org.rostore.v2.seq.BlockIndexSequence
 
BlockIndexSequences - Class in org.rostore.v2.seq
This clas holds all the block sequences in the Media object.
BlockIndexSequences(Media) - Constructor for class org.rostore.v2.seq.BlockIndexSequences
 
BlockOffset - Annotation Interface in org.rostore.mapper
Annotation that can be used on the fields of the java objects that store an offset within a block.
BlockProvider - Interface in org.rostore.v2.media.block
A structure that combines both BlockAllocator and BlockContainer.
blocksAllocated(String, BlockType, CatalogBlockIndices, boolean) - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorListener
Notifies that the blocks have been allocated
blocksAllocated(String, BlockType, CatalogBlockIndices, boolean) - Method in class org.rostore.v2.media.block.allocator.BlockVerifierListener
 
BlockSequence<T> - Class in org.rostore.v2.seq
Sequences manage a set of blocks.
BlockSequence(BlockProvider, long, Function<BlockSequence<T>, T>, BlockType) - Constructor for class org.rostore.v2.seq.BlockSequence
load existing
BlockSequence(BlockProvider, CatalogBlockIndices, Function<BlockSequence<T>, T>, BlockType) - Constructor for class org.rostore.v2.seq.BlockSequence
Create a new sequence.
BlockSequence(BlockProvider, BlockIndexSequence, Function<BlockSequence<T>, T>, BlockType) - Constructor for class org.rostore.v2.seq.BlockSequence
Creates block sequence from cached blockIndex sequence
blocksFreed(String, CatalogBlockIndices, boolean) - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorListener
Notifies that the blocks have been freed
blocksFreed(String, CatalogBlockIndices, boolean) - Method in class org.rostore.v2.media.block.allocator.BlockVerifierListener
 
blockSize(int) - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Sets the block size that will be used by the storage
BlockType - Enum Class in org.rostore.v2.media.block
A type of the block.
BlockVerifierListener - Class in org.rostore.v2.media.block.allocator
Special kind of listener that can be used to verify the block allocations
BlockVerifierListener() - Constructor for class org.rostore.v2.media.block.allocator.BlockVerifierListener
 
BYTES_PER_EOL - Static variable in class org.rostore.Utils
 
BYTES_PER_VERSION - Static variable in class org.rostore.Utils
 

C

CachedCatalogBlockOperations - Class in org.rostore.v2.catalog
This class extends CatalogBlockOperations by caching some subset of the catalog in memory.
CachedCatalogBlockOperations(CatalogBlockOperations, int, int) - Constructor for class org.rostore.v2.catalog.CachedCatalogBlockOperations
Creates a cached version with the CatalogBlockOperations backend
cancel(boolean) - Method in class org.rostore.v2.container.async.AsyncStream
Cancels the processing of the stream.
cancel(boolean) - Method in class org.rostore.v2.container.async.InterruptedShardOperation
 
cancel(boolean) - Method in class org.rostore.v2.container.async.Operation
 
cancel(R) - Method in class org.rostore.v2.container.async.Operation
 
CANCELED - Enum constant in enum class org.rostore.v2.container.async.AsyncStatus
Canceled manually
CATALOG - Enum constant in enum class org.rostore.v2.media.block.BlockType
Block belongs to the block catalog and used for block accounting (e.g.
CatalogBlockEntry - Class in org.rostore.v2.catalog
An entry used to store the elements of catalog.
CatalogBlockEntry(FixSizeEntryBlock<CatalogBlockEntry>) - Constructor for class org.rostore.v2.catalog.CatalogBlockEntry
 
CatalogBlockEntryInstance - Class in org.rostore.v2.catalog
 
CatalogBlockEntryInstance(CatalogBlockEntry) - Constructor for class org.rostore.v2.catalog.CatalogBlockEntryInstance
 
CatalogBlockEntryInstance(CatalogBlockEntry, long) - Constructor for class org.rostore.v2.catalog.CatalogBlockEntryInstance
 
CatalogBlockIndices - Class in org.rostore.v2.catalog
 
CatalogBlockIndices() - Constructor for class org.rostore.v2.catalog.CatalogBlockIndices
 
CatalogBlockIndicesIterator - Class in org.rostore.v2.catalog
 
CatalogBlockIndicesIterator(CatalogBlockIndices) - Constructor for class org.rostore.v2.catalog.CatalogBlockIndicesIterator
 
CatalogBlockOperations - Class in org.rostore.v2.catalog
This is the major class to manage a catalog of blocks.
checkAndCloseIfNeeded() - Method in class org.rostore.service.RoStoreAccessor
 
checkAndThrow(long, long, boolean) - Static method in exception class org.rostore.entity.VersionMismatchException
Checks if the version of the request fits the underlying stored version.
checkAndThrow(long, Record) - Static method in exception class org.rostore.entity.VersionMismatchException
Checks if the version of the request fits the underlying stored version.
checkAndThrow(Record) - Static method in exception class org.rostore.entity.VersionMismatchInitException
Checks if the record can be initialized with the given set of RecordOption and the version.
checkContainerPermission(String, Set<Permission>) - Method in class org.rostore.service.apikey.ApiKeyManager
 
checkContainerRequestsAllowed() - Method in enum class org.rostore.service.RoStoreState
 
checkFreeSpaceToCreateContainer(String, Media, ContainerMeta) - Static method in class org.rostore.v2.container.Container
 
checkInsertRecord(Record) - Static method in exception class org.rostore.entity.OptionMismatchException
Checks options when an entry should be inserted and throws an exception if the state is invalid (insert is not allowed).
checkOpened() - Method in interface org.rostore.v2.media.Closeable
 
checkRequestsAllowed() - Method in enum class org.rostore.service.RoStoreState
 
checkStorePermission(Set<Permission>) - Method in class org.rostore.service.apikey.ApiKeyManager
 
checkUpdateRecord(KeyBlockEntry, Record) - Static method in exception class org.rostore.entity.OptionMismatchException
Checks options when an entry should be updated and throws an exception if the state is invalid (update is not allowed).
clean() - Method in class org.rostore.v2.media.block.Block
Sets a position to 0 and sets the content to 0
clean() - Method in class org.rostore.v2.seq.SequenceBlock
 
CLEANUP_INTERVAL_MILLIS_DEFAULT - Static variable in class org.rostore.entity.media.ContainerListProperties
 
CleanupManager - Class in org.rostore.v2.container.async
 
CleanupManager(ExecutorService, long) - Constructor for class org.rostore.v2.container.async.CleanupManager
 
clear() - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
Cli - Class in org.rostore.cli
 
Cli() - Constructor for class org.rostore.cli.Cli
 
ClientException - Exception Class in org.rostore.client
The exception is thrown by rostore client, in case of any issue in the communication with the remote rostore service.
ClientException(String, RequestProperties) - Constructor for exception class org.rostore.client.ClientException
 
ClientException(String, RequestProperties, String, String) - Constructor for exception class org.rostore.client.ClientException
 
ClientException(String, RequestProperties, String, String, Throwable) - Constructor for exception class org.rostore.client.ClientException
 
ClientException(String, RequestProperties, Throwable) - Constructor for exception class org.rostore.client.ClientException
 
CliException - Exception Class in org.rostore.cli
 
CliException(String) - Constructor for exception class org.rostore.cli.CliException
 
CliException(String, Throwable) - Constructor for exception class org.rostore.cli.CliException
 
close() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Returns all the entries from the cache back to catalog and closes it.
close() - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Closes the catalog and frees the sequence, blocks still needs to be committed/closed by the usage of CatalogBlockOperations.getBlockProvider()
close() - Method in class org.rostore.v2.container.async.AsyncContainer
 
close() - Method in class org.rostore.v2.container.async.AsyncContainerMedia
 
close() - Method in class org.rostore.v2.container.async.AsyncContainers
 
close() - Method in class org.rostore.v2.container.async.AsyncStream
 
close() - Method in class org.rostore.v2.container.Container
Closes the container and removes any references of it from the ContainerListOperations
close() - Method in class org.rostore.v2.container.ContainerListOperations
 
close() - Method in class org.rostore.v2.container.ContainerShard
 
close() - Method in class org.rostore.v2.container.ContainerShardKeyOperations
Closes this entity and all related blocks
close() - Method in class org.rostore.v2.data.DataReader
 
close() - Method in class org.rostore.v2.data.DataWriter
 
close() - Method in class org.rostore.v2.keys.KeyBlockOperations
 
close() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Closes this entity and all related blocks
close() - Method in class org.rostore.v2.media.block.Block
 
close() - Method in class org.rostore.v2.media.block.container.BlockContainer
Close all the blocks and the instance of block container.
close() - Method in interface org.rostore.v2.media.Closeable
Closes this entity and all related blocks
close() - Method in class org.rostore.v2.media.Media
Closes the instance of media.
close() - Method in class org.rostore.v2.media.RootClosableImpl
 
close() - Method in class org.rostore.v2.seq.BlockIndexSequence
 
close() - Method in class org.rostore.v2.seq.BlockSequence
Closes an instance of the block sequence, and decrements the number of references in BlockIndexSequence.
close() - Method in class org.rostore.v2.seq.SequenceBlock
Closes an underlying sequence
close(String) - Method in class org.rostore.v2.container.async.AsyncContainers
 
Closeable - Interface in org.rostore.v2.media
An interface that marks an entity that holds opened blocks, which should be closed after its usage.
closeContainer(String) - Method in class org.rostore.v2.container.ContainerListOperations
Use Container.close() to close the containers.
CLOSED - Enum constant in enum class org.rostore.v2.media.block.container.Status
 
closeExpired() - Method in class org.rostore.v2.media.block.MappedPhysicalBlocks
 
closeExpired() - Method in class org.rostore.v2.media.Media
This function can be called periodically to close the unused blocks and sequences.
closeExpired() - Method in class org.rostore.v2.seq.BlockIndexSequences
Closes the block sequence if it is not in use for the MediaProperties.getCloseUnusedSequencesAfterMillis()}
closeIfIdle(long) - Method in class org.rostore.v2.container.async.AsyncContainer
Will close the instance in case no active key operation has been observed for the given time.
closeInternal() - Method in class org.rostore.v2.container.Container
Use Container.close() to close the containers.
closeUnused() - Method in class org.rostore.v2.media.block.MappedPhysicalBlocks
 
closeUnusedBlocksAfterMillis(long) - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Sets the time interval in milliseconds after each the unused blocks will be removed from the memory.
closeUnusedSequencesAfterMillis(long) - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Sets the time interval in milliseconds after each the unused block sequences will be removed from the memory.
collapseWindow(int, int) - Method in class org.rostore.v2.media.block.Block
This function moves the data that starts at position+bytes to position the position is set back to the current position
commit() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Operation commits all the active blocks.
commit() - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Commit all the active blocks from the associated container
commit() - Method in class org.rostore.v2.container.ContainerShardKeyOperations
Operation commits all the active blocks.
commit() - Method in class org.rostore.v2.data.DataReader
 
commit() - Method in class org.rostore.v2.data.DataWriter
Synchronizes the written data with the storage
commit() - Method in class org.rostore.v2.keys.KeyBlockOperations
 
commit() - Method in class org.rostore.v2.media.block.container.BlockContainer
Operation commits all the active blocks.
commit() - Method in interface org.rostore.v2.media.Committable
Operation commits all the active blocks.
Committable - Interface in org.rostore.v2.media
Marks an entity that holds active blocks, which needs to be committed.
compare(byte[]) - Method in class org.rostore.v2.keys.VarSizeBlock
 
compare(byte[]) - Method in class org.rostore.v2.keys.VarSizeEntry
Compares the currently selected entry with the data provided
compare(byte[]) - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Compares the provided key data array to the data stored in the multi block sequence
compare(byte[], int, int) - Method in class org.rostore.v2.media.block.Block
Compares the given number of bytes from starting from the given offset in the byte array with the block's respective data.
computeBytesForMaxValue(long) - Static method in class org.rostore.Utils
Computes how many bytes is needed to represent the value
computeHeaderSize(byte) - Method in class org.rostore.v2.keys.VarSizeBlock
 
Container - Class in org.rostore.v2.container
Container class to manage access to the set of keys and their values.
Container(ContainerListOperations, String, ContainerMeta) - Constructor for class org.rostore.v2.container.Container
This constructor creates a new container.
Container(ContainerListOperations, String, ContainerDescriptor) - Constructor for class org.rostore.v2.container.Container
This one opens up the container if it has already been created.
ContainerAdminService - Class in org.rostore.service
 
ContainerAdminService() - Constructor for class org.rostore.service.ContainerAdminService
 
ContainerAlreadyExistsException - Exception Class in org.rostore.entity
Thrown when the container name is already in use.
ContainerAlreadyExistsException(String) - Constructor for exception class org.rostore.entity.ContainerAlreadyExistsException
Creates an exception for the provided container
ContainerDescriptor - Class in org.rostore.v2.container
This class is created on the container creation event and should be stored in the container list, so it can be reopened again.
ContainerDescriptor() - Constructor for class org.rostore.v2.container.ContainerDescriptor
Needed for the load
ContainerDescriptor(ContainerMeta) - Constructor for class org.rostore.v2.container.ContainerDescriptor
 
containerList(String) - Method in class org.rostore.service.KeyValueService
 
ContainerListHeader - Class in org.rostore.v2.container
This class is serialized and stored in the media header at the time of Media creation.
ContainerListHeader() - Constructor for class org.rostore.v2.container.ContainerListHeader
Is used by the serializer/deserializer
ContainerListHeader(ContainerListProperties) - Constructor for class org.rostore.v2.container.ContainerListHeader
 
ContainerListOperations - Class in org.rostore.v2.container
This is the major class to manage the containers on the rostore.
ContainerListOperations(Media, ContainerListProperties) - Constructor for class org.rostore.v2.container.ContainerListOperations
Creates a new container list
ContainerListOperations(Media, ContainerListHeader) - Constructor for class org.rostore.v2.container.ContainerListOperations
Loads an existing container list
ContainerListProperties - Class in org.rostore.entity.media
The class contains the properties that steers the list of containers.
ContainerListProperties() - Constructor for class org.rostore.entity.media.ContainerListProperties
 
ContainerMeta - Class in org.rostore.entity.media
Specifies the major container properties, such as the maximum size and maximum TTL of the keys the container will allow to store, as well as the number of container's shard.
ContainerMeta() - Constructor for class org.rostore.entity.media.ContainerMeta
 
ContainerMetaCompatibility - Class in org.rostore.entity.media
 
ContainerMetaCompatibility() - Constructor for class org.rostore.entity.media.ContainerMetaCompatibility
 
ContainerShard - Class in org.rostore.v2.container
Container Shards ar independent portion of the Container, that have its own BlockAllocator and independent set of keys.
ContainerShardCleanupManager - Class in org.rostore.v2.container.async
This is a manager to clean up if needed
ContainerShardCleanupManager(ContainerShardExecutor) - Constructor for class org.rostore.v2.container.async.ContainerShardCleanupManager
 
ContainerShardDescriptor - Class in org.rostore.v2.container
This information meant to be serialized and stored to the Media so that the shard can be recreated.
ContainerShardDescriptor() - Constructor for class org.rostore.v2.container.ContainerShardDescriptor
Needed for load
ContainerShardDescriptor(long, long) - Constructor for class org.rostore.v2.container.ContainerShardDescriptor
Creates the descriptor
ContainerShardExecutor - Class in org.rostore.v2.container.async
 
ContainerShardExecutor(AsyncContainer, ContainerShard) - Constructor for class org.rostore.v2.container.async.ContainerShardExecutor
 
ContainerShardKeyOperations - Class in org.rostore.v2.container
Encapsulates the operation context on the shard level.
ContainerShardKeyOperations(ContainerShard) - Constructor for class org.rostore.v2.container.ContainerShardKeyOperations
Creates an instance for the shard's operations.
contains(long) - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
contentType(String) - Method in class org.rostore.client.RequestProperties
 
ContentType - Enum Class in org.rostore.client
Specify a content-type header for the request to the remote rostore service.
convert(Exception) - Static method in class org.rostore.service.RestError
 
COPY_CONTAINER - Enum constant in enum class org.rostore.cli.Operation
 
COPY_KEY - Enum constant in enum class org.rostore.cli.Operation
 
COPY_STORAGE - Enum constant in enum class org.rostore.cli.Operation
 
create(File, ExecutorService, AsyncContainerMediaProperties) - Static method in class org.rostore.v2.container.async.AsyncContainerMedia
 
create(File, AsyncContainerMediaProperties) - Static method in class org.rostore.v2.container.async.AsyncContainerMedia
 
create(File, MediaProperties) - Static method in class org.rostore.v2.media.Media
Creates a blank media
create(File, MediaProperties, BiConsumer<Media, DataWriter>) - Static method in class org.rostore.v2.media.Media
Creates a new media and store with an option to store to headers stream of the media.
create(File, MediaProperties, Function<Media, T>) - Static method in class org.rostore.v2.media.Media
Creates a new media and store a header class to the header of the media
create(String) - Method in class org.rostore.client.RoStoreClient
Creates a base request properties for the given path
create(String, ContainerMeta) - Method in class org.rostore.v2.container.async.AsyncContainers
 
create(String, ContainerMeta) - Method in class org.rostore.v2.container.ContainerListOperations
 
create(String, BlockAllocator, long) - Static method in class org.rostore.v2.media.block.allocator.SecondaryBlockAllocator
Creates a new secondary block allocator.
create(K, V, Long, Long) - Static method in class org.rostore.client.VersionedObject
Creates a versioned object (general case)
create(ApiKeyPermissions, Record) - Method in class org.rostore.service.apikey.ApiKeyManager
 
create(ContainerMeta) - Method in class org.rostore.client.GeneralContainer
Creates a new container
create(ContainerMeta) - Method in class org.rostore.client.MappedContainer
Creates a new container
create(AsyncContainerMediaProperties) - Method in class org.rostore.service.RoStoreAccessor
 
create(Container, int) - Static method in class org.rostore.v2.container.ContainerShard
Creates a new shard in the storage
create(BlockAllocator) - Static method in class org.rostore.v2.media.block.InternalBlockProvider
Creates a block provider that contains a new BlockContainer.
create(BlockAllocator, RecordLengths) - Static method in class org.rostore.v2.keys.KeyBlockOperations
Creates a new key operations, allocates a new sequence to manage the keys.
create(BlockProvider) - Static method in class org.rostore.v2.catalog.CatalogBlockOperations
Creates a new catalog.
create(BlockProvider, Function<BlockSequence<T>, T>, BlockType) - Static method in class org.rostore.v2.seq.SequenceBlock
Creates a new block sequence and initialize a sequence block on its basis
create(BlockProvider, CatalogBlockIndices) - Static method in class org.rostore.v2.catalog.CatalogBlockOperations
Creates a new catalog.
create(BlockProvider, CatalogBlockIndices, Function<BlockSequence<T>, T>, BlockType) - Static method in class org.rostore.v2.seq.SequenceBlock
Creates a new block sequence and initialize a sequence block on its basis
create(Media) - Static method in class org.rostore.v2.media.block.allocator.RootBlockAllocator
Creates a new root block allocator.
create(Media) - Static method in class org.rostore.v2.media.block.InternalBlockProvider
Creates a block provider that contains a new BlockContainer.
create(Media, ContainerListProperties) - Static method in class org.rostore.v2.container.async.AsyncContainers
 
create(Media, ContainerListProperties, ExecutorService) - Static method in class org.rostore.v2.container.async.AsyncContainers
 
CREATE - Enum constant in enum class org.rostore.entity.apikey.Permission
Permission to create entries.
CREATE_CONTAINER - Enum constant in enum class org.rostore.cli.Operation
 
createApiKey(String, Long, Long, ApiKeyPermissions) - Method in class org.rostore.service.ApiKeyService
 
createCatalogBlockIndices() - Method in class org.rostore.v2.seq.BlockIndexSequence
 
createContainer(String, ContainerMeta) - Method in class org.rostore.service.ContainerAdminService
 
createDeserialized(VersionedObject<K, V1>, V2) - Static method in class org.rostore.client.VersionedObject
 
createEternal(K, V, Long) - Static method in class org.rostore.client.VersionedObject
Creates an eternal versioned object
createNewAfter() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Creates a new block after the current one and move to it.
createNewAfter() - Method in class org.rostore.v2.seq.SequenceBlock
Creates a new block after the current one and move to it.
createNewVersioned(K, V, Long) - Static method in class org.rostore.client.VersionedObject
Creates first version of the entity with the expiration timestamp
createNewVersionedEternal(K, V) - Static method in class org.rostore.client.VersionedObject
Creates first version of eternal object
createSecondaryBlockAllocator(String, long) - Method in class org.rostore.v2.media.Media
Creates SecondaryBlockAllocator based on the internal root allocator.
createUnversionedEternal(K, V) - Static method in class org.rostore.client.VersionedObject
Creates an eternal unversioned object

D

DATA - Enum constant in enum class org.rostore.v2.media.block.BlockType
This is the value data block, allocated by DataWriter or DataReader.
DataReader - Class in org.rostore.v2.data
This is a counterpart of DataWriter, that allows to read the data from the storage that has been previously written by the writer.
DataTransferException - Exception Class in org.rostore.v2.data
Thrown when data transfer is aborted out of any reason
DataTransferException(Exception) - Constructor for exception class org.rostore.v2.data.DataTransferException
 
DataTransferException(String, Exception) - Constructor for exception class org.rostore.v2.data.DataTransferException
 
DataWithRecord<T> - Class in org.rostore.v2.container
Represents a combination of the value data and the metadata associated with the entry
DataWithRecord(Record, T) - Constructor for class org.rostore.v2.container.DataWithRecord
 
DataWriter - Class in org.rostore.v2.data
Class to write the data to the storage using the provided block allocator.
defaultContainerProperties(MediaPropertiesBuilder) - Static method in class org.rostore.v2.container.async.AsyncContainerMediaProperties
 
DefaultKeySerializer<K> - Class in org.rostore.client
A default key serializer.
delete() - Method in class org.rostore.v2.seq.SequenceBlock
Removes the current block and mark it as free.
delete(String, String, String, Long) - Method in class org.rostore.service.KeyValueService
 
delete(RequestProperties) - Method in class org.rostore.client.RoStoreClient
Executes a delete command
DELETE - Enum constant in enum class org.rostore.entity.apikey.Permission
Permission to delete entries.
DELETE - Enum constant in enum class org.rostore.v2.container.async.OperationType
 
DELETE_GROUPS - Static variable in class org.rostore.v2.data.Properties
 
deleteContainer(String) - Method in class org.rostore.service.ContainerAdminService
 
deserialize(MapperProperties, Type, InputStream) - Static method in class org.rostore.mapper.BinaryMapper
 
deserialize(MapperProperties, Type, InputStream, int) - Static method in class org.rostore.mapper.BinaryMapper
 
done() - Method in class org.rostore.v2.container.async.Operation
 
dump() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
 
dump() - Method in class org.rostore.v2.catalog.CatalogBlockOperations
 
dump() - Method in class org.rostore.v2.container.ContainerShardKeyOperations
 
dump() - Method in class org.rostore.v2.keys.KeyBlockOperations
Dumps the content of the key catalog to the System.out.
dump() - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
 
dump() - Method in class org.rostore.v2.media.Media
 

E

empty() - Method in class org.rostore.v2.container.async.AsyncStream
 
EntrySizeListener - Interface in org.rostore.v2.catalog
A listener get called when number of entries in the block changes.
eol(long) - Method in class org.rostore.entity.Record
Sets end of live of the record
EOL_FOREVER - Static variable in class org.rostore.Utils
 
EOL_HEADER - Static variable in class org.rostore.service.Headers
 
eol2ttl(long) - Static method in class org.rostore.Utils
 
eol2unix(long) - Static method in class org.rostore.Utils
 
EOLIncorrectException - Exception Class in org.rostore.entity
Exception is thrown if the value of EOL violates some validation rules.
EOLIncorrectException(long) - Constructor for exception class org.rostore.entity.EOLIncorrectException
 
error(Exception) - Method in interface org.rostore.v2.container.async.AsyncListener
 
ERROR - Enum constant in enum class org.rostore.v2.container.async.AsyncStatus
Error happened
ErrorHandler - Class in org.rostore.service
 
ErrorHandler() - Constructor for class org.rostore.service.ErrorHandler
 
ErrorRepresentation - Class in org.rostore.service
 
ErrorRepresentation(String, String) - Constructor for class org.rostore.service.ErrorRepresentation
 
evict(String) - Method in class org.rostore.v2.container.async.AsyncContainers
 
evict(String) - Method in class org.rostore.v2.container.ContainerListOperations
Should only be used internally
evict(Block) - Method in class org.rostore.v2.media.block.container.BlockContainer
Evicts a block from the current container
evictIfLoaded(long) - Method in class org.rostore.v2.media.block.container.BlockContainer
Checks if the block is loaded within this container, and then evict it.
exchangeBlockAllocator(BlockAllocator) - Method in class org.rostore.v2.media.block.InternalBlockProvider
Exchange a block allocator.
EXCLUSIVE - Enum constant in enum class org.rostore.v2.container.async.KeyExecutionState
 
execute() - Method in class org.rostore.v2.container.async.CleanupManager
 
execute() - Method in class org.rostore.v2.container.async.ContainerShardCleanupManager
 
execute() - Method in class org.rostore.v2.container.async.Operation
 
execute(Operation<R>, boolean) - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
executeAutonomousValue(int, OperationType, long, boolean, Runnable) - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
executeKey(int, OperationType, boolean, Function<ContainerShardKeyOperations, R>) - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
executeValue(int, OperationType, long, boolean, Supplier<R>) - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
expand() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Creates an entry at the end of the current block.
expand(byte[]) - Method in class org.rostore.v2.keys.VarSizeEntry
Expands the block by adding the data provided to the end of the block.
extract() - Method in class org.rostore.v2.keys.VarSizeEntry
Extracts the currently selected entry as a byte array
extract(int) - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
extractIndex(int, boolean) - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
This is the version of CatalogBlockOperations.extractIndex(long, boolean) that uses internal cache
extractIndex(long, boolean) - Method in class org.rostore.v2.catalog.CatalogBlockOperations
This function will extract the requested number of blocks from the catalog.

F

fail(Exception) - Method in class org.rostore.v2.container.async.AsyncStream
Called by the internal processing logic in case any error occurs during processing
filter(ContainerRequestContext) - Method in class org.rostore.service.RequestFilter
 
filter(ContainerRequestContext, ContainerResponseContext) - Method in class org.rostore.service.RequestFilter
 
filter(Function<BlockIndexSequence, Boolean>) - Method in class org.rostore.v2.seq.BlockIndexSequences
 
finalized() - Method in class org.rostore.v2.container.async.CleanupManager
 
finalized() - Method in class org.rostore.v2.container.async.ContainerShardCleanupManager
 
first() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Moves the current index to the first available entry in the block
FixSizeEntry - Class in org.rostore.v2.fixsize
Abstract entry that encapsulates operation on the entries with the fixed size.
FixSizeEntry(FixSizeEntryBlock) - Constructor for class org.rostore.v2.fixsize.FixSizeEntry
Initializes the entry
FixSizeEntryBlock<T> - Class in org.rostore.v2.fixsize
This is an extension of sequence block that maps the block area as a set of the fixed-sized entries.
FixSizeEntryBlock(BlockSequence<FixSizeEntryBlock>, int, Function<FixSizeEntryBlock<T>, T>, EntrySizeListener) - Constructor for class org.rostore.v2.fixsize.FixSizeEntryBlock
 
flush() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
Execute a flushing of the current state of the block back to the storage.
free() - Method in class org.rostore.v2.data.DataReader
Operation is to free the blocks that has previously been allocated by the DataWriter.
free() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Free all the blocks in the multi block sequence
free(long) - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Marks the provided block as free
free(long, boolean) - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
Marks a provided block as free
free(CatalogBlockIndices) - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Marks all the blocks in the provided index as free
free(CatalogBlockIndices, boolean) - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
Free a set of blocks
freeBlock(long) - Method in interface org.rostore.v2.media.block.BlockProvider
Frees a block from the allocator and removes it from the container.
freeBlockContainer(int) - Method in class org.rostore.v2.media.Media
Frees a block container
from(MediaPropertiesBuilder) - Static method in class org.rostore.v2.media.MediaProperties
Used to create the MediaProperties based on the desired input in form of MediaPropertiesBuilder.
fromInputStream(BlockAllocator, T) - Static method in class org.rostore.v2.data.DataWriter
Writes the data from the input stream
fromObject(V, K) - Method in class org.rostore.client.mapper.JsonMapper
Serialization function
fromObject(V, K) - Method in interface org.rostore.client.mapper.Mapper
Serialization function
fromObject(V, K) - Method in class org.rostore.client.mapper.NativeMapper
Serialization function
fromRoStorePropertiesFile(File) - Static method in class org.rostore.cli.RoStorePropertiesLoader
 

G

GeneralContainer<K> - Class in org.rostore.client
Represents a simple rostore container.
GeneralContainer(RoStoreClient, String, KeySerializer<K>) - Constructor for class org.rostore.client.GeneralContainer
 
get() - Method in class org.rostore.v2.catalog.CatalogBlockIndicesIterator
 
get() - Method in class org.rostore.v2.container.async.AsyncStream
This one will only work if the object is created as blocking
get() - Method in class org.rostore.v2.container.async.InterruptedShardOperation
 
get() - Method in class org.rostore.v2.container.async.Operation
 
get() - Method in class org.rostore.v2.keys.VarSizeBlock
Gets the data payload for currently selected entry
get() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Reads the data from the multi block sequence and stores it to the data array
get(byte[], int, int) - Method in class org.rostore.v2.media.block.Block
Loads the length number of bytes from the current block's position to the offset in the data array
get(int, byte[], Class<T>) - Method in class org.rostore.v2.container.async.AsyncContainer
Gets a value based on key from container.
get(int, byte[], Function<InputStream, T>) - Method in class org.rostore.v2.container.async.AsyncContainer
Gets a value based on key from container.
get(int, String, Class<T>) - Method in class org.rostore.v2.container.async.AsyncContainer
Gets a value based on key from container.
get(long, TimeUnit) - Method in class org.rostore.v2.container.async.AsyncStream
 
get(long, TimeUnit) - Method in class org.rostore.v2.container.async.InterruptedShardOperation
 
get(long, TimeUnit) - Method in class org.rostore.v2.container.async.Operation
 
get(long, Function<BlockIndexSequence, BlockSequence<T>>) - Method in class org.rostore.v2.seq.BlockIndexSequences
 
get(String) - Method in class org.rostore.client.ApiKeys
Get the api-key permissions by the key
get(String) - Method in class org.rostore.service.apikey.ApiKeyManager
 
get(String) - Method in class org.rostore.v2.container.async.AsyncContainers
 
get(String) - Method in class org.rostore.v2.container.ContainerListOperations
 
get(String, String, HttpServletResponse, HttpServletRequest) - Method in class org.rostore.service.KeyValueService
 
get(K, Class<V>) - Method in class org.rostore.client.MappedContainer
Retrieves the object from the storage
get(K, EnumSet<RecordOption>, Function<InputStream, V>) - Method in class org.rostore.client.GeneralContainer
 
get(K, Function<InputStream, V>) - Method in class org.rostore.client.GeneralContainer
 
get(RequestProperties, Function<CloseableHttpResponse, T>) - Method in class org.rostore.client.RoStoreClient
Executes a get request on the rostore
get(BlockContainer) - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
 
get(BlockContainer, long, BlockType) - Method in class org.rostore.v2.media.block.MappedPhysicalBlocks
Creates a BlockContainer private Block.
GET_KEY - Enum constant in enum class org.rostore.cli.Operation
 
getAbsoluteIndex() - Method in class org.rostore.v2.media.block.Block
Provides the index of the current block in the rostore media.
getAddedNumber() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Catalog counts and persists internally the total number of blocks in the catalog.
getAddedNumber() - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Provides a total number of blocks added to the catalog, stored in the first block of the sequence.
getAddedNumber() - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Catalog counts and persists internally the total number of blocks in the catalog.
getAllContainerIds() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
Provides all container ids where this physical block is used.
getAllocatorStartIndex() - Method in class org.rostore.v2.container.ContainerShardDescriptor
The first block of the allocator's sequence
getAndCheckKey() - Method in class org.rostore.service.apikey.ApiKeyManager
 
getApiKey() - Method in class org.rostore.client.RoStoreClientProperties
Returns the api key used to access the rostore
getApiKey() - Method in class org.rostore.service.apikey.ApiKeyRequestContext
 
getApiKey(String, Long) - Method in class org.rostore.service.ApiKeyService
 
getApiKeyPermissions() - Method in class org.rostore.entity.apikey.ApiKeyDefinition
 
getApiKeys() - Method in class org.rostore.client.RoStoreClient
Returns object that manage the api keys
getApiVersion() - Method in class org.rostore.entity.media.Version
 
getAsync(int, byte[], AsyncStream<T>) - Method in class org.rostore.v2.container.async.AsyncContainer
Gets a value based on key from container.
getAsyncContainerMedia() - Method in class org.rostore.service.RoStoreAccessor
 
getAsyncContainers() - Method in class org.rostore.v2.container.async.AsyncContainer
 
getAsyncContainers() - Method in class org.rostore.v2.container.async.AsyncContainerMedia
 
getAsyncContainers() - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
getAutoCloseContainersAfterMillis() - Method in class org.rostore.entity.media.ContainerListProperties
 
getBaseUrl() - Method in class org.rostore.client.RoStoreClientProperties
Returns the base url of the rostore instance, e.g.
getBlock() - Method in class org.rostore.v2.keys.VarSizeBlock
 
getBlock() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Provides a block associated with current position
getBlock() - Method in class org.rostore.v2.seq.SequenceBlock
Get the block this sequence's block internal pointer points to
getBlock(long, BlockType) - Method in class org.rostore.v2.media.block.container.BlockContainer
Provides a block to read and write
getBlockAllocation() - Method in class org.rostore.v2.container.Container
 
getBlockAllocation() - Method in class org.rostore.v2.container.ContainerShard
Provides information about block allocation within the shard
getBlockAllocation() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Provides information about block allocation within this block allocator
getBlockAllocation() - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
Provides information about block allocation within this block allocator
getBlockAllocation() - Method in class org.rostore.v2.media.Media
Provides information about block allocation within the media
getBlockAllocator() - Method in interface org.rostore.v2.media.block.BlockProvider
Provides a block allocator
getBlockAllocator() - Method in class org.rostore.v2.media.block.InternalBlockProvider
Provides a block allocator
getBlockAllocatorInternal() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
 
getBlockAllocatorListeners() - Method in class org.rostore.v2.media.Media
 
getBlockByIndex(int) - Method in class org.rostore.v2.seq.BlockSequence
Provides a block by the sequence number, starting from 0
getBlockContainer() - Method in interface org.rostore.v2.media.block.BlockProvider
Provides a block container.
getBlockContainer() - Method in class org.rostore.v2.media.block.InternalBlockProvider
Provides a block container.
getBlockContainer(int) - Method in class org.rostore.v2.media.Media
Provides a block container by its id
getBlockContainerAllocated() - Method in class org.rostore.v2.media.MemoryConsumption
Provides a number of BlockContainer instances that are currently open and are kept in memory.
getBlockDataSize() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Provides the data stored in this block
getBlockIndex() - Method in class org.rostore.v2.keys.VarSizeBlock
Gets the currently selected memory block, this entry works with.
getBlockIndex(int) - Method in class org.rostore.v2.seq.BlockIndexSequence
 
getBlockIndexSequence() - Method in class org.rostore.v2.seq.BlockSequence
Provides the underlying block index sequence
getBlockIndexSequences() - Method in class org.rostore.v2.media.Media
Provides the set of currently opened BlockIndexSequence
getBlockProvider() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
A block provider that is used to manage the blocks in this catalog operations
getBlockProvider() - Method in class org.rostore.v2.catalog.CatalogBlockOperations
A block provider that is used to manage the blocks in this catalog operations
getBlockProvider() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
A block provider based on the one of associated BlockSequence
getBlockProvider() - Method in class org.rostore.v2.keys.VarSizeBlock
 
getBlockProvider() - Method in class org.rostore.v2.seq.BlockSequence
 
getBlocksAllocated() - Method in class org.rostore.v2.media.MemoryConsumption
Provides a number of blocks which are currently mapped from the physical storage to the memory.
getBlockSequence() - Method in class org.rostore.v2.container.ContainerShardKeyOperations
The sequence of the blocks that manages the shard's keys
getBlockSequence() - Method in class org.rostore.v2.keys.KeyBlockOperations
A block sequence that underlies this operation's object
getBlockSequence() - Method in class org.rostore.v2.seq.SequenceBlock
 
getBlockSequencesAllocated() - Method in class org.rostore.v2.media.MemoryConsumption
Provides a number of currently active BlockIndexSequence that are kept in memory.
getBlockSize() - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Provides the block size
getBlockSize() - Method in class org.rostore.v2.media.MediaHeader
getBlockSize() - Method in class org.rostore.v2.media.MediaProperties
Provides the block size
getBlocksNumber() - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Get the number of blocks in the current entry
getBlockType() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
 
getByCliName(String) - Static method in enum class org.rostore.cli.Operation
 
getByte() - Method in class org.rostore.v2.media.block.Block
Reads a byte from the current position and increments the current position.
getBytes(String) - Static method in class org.rostore.Utils
 
getBytes(RequestProperties) - Method in class org.rostore.client.RoStoreClient
Executes the request on rostore and return the response as byte array
getBytesPerBlockIndex() - Method in class org.rostore.mapper.MapperProperties
 
getBytesPerBlockOffset() - Method in class org.rostore.mapper.MapperProperties
 
getCachedBlockNumber() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Provides the number of blocks in the cache
getCleanupIntervalMillis() - Method in class org.rostore.entity.media.ContainerListProperties
 
getCleanupManager() - Method in class org.rostore.v2.container.async.AsyncContainers
 
getCliName() - Method in enum class org.rostore.cli.Operation
 
getCloseUnusedBlocksAfterMillis() - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Provides the time interval in milliseconds after each the unused blocks will be removed from the memory.
getCloseUnusedBlocksAfterMillis() - Method in class org.rostore.v2.media.MediaHeader
getCloseUnusedBlocksAfterMillis() - Method in class org.rostore.v2.media.MediaProperties
Provides the time interval in milliseconds after each the unused blocks will be removed from the memory.
getCloseUnusedSequencesAfterMillis() - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Gets the time interval in milliseconds after each the unused block sequences will be removed from the memory.
getCloseUnusedSequencesAfterMillis() - Method in class org.rostore.v2.media.MediaHeader
getCloseUnusedSequencesAfterMillis() - Method in class org.rostore.v2.media.MediaProperties
Gets the time interval in milliseconds after each the unused block sequences will be removed from the memory.
getConnectionManager() - Method in class org.rostore.client.RoStoreClient
 
getConnectTimeout() - Method in class org.rostore.client.RoStoreClientProperties
 
getContainer() - Method in class org.rostore.v2.container.async.AsyncContainer
 
getContainer() - Method in class org.rostore.v2.container.ContainerShard
 
getContainerId() - Method in class org.rostore.v2.media.block.container.BlockContainer
A unique container id
getContainerListHeader() - Method in class org.rostore.v2.container.async.AsyncContainers
 
getContainerListHeader() - Method in class org.rostore.v2.container.ContainerListOperations
 
getContainerListOperations() - Method in class org.rostore.v2.container.Container
This is the major (parent) class that manages the list of containers
getContainerListProperties() - Method in class org.rostore.entity.media.RoStoreProperties
 
getContainerListProperties() - Method in class org.rostore.v2.container.async.AsyncContainerMediaProperties
 
getContainerListProperties() - Method in class org.rostore.v2.container.ContainerListHeader
The list container's list properties defined at the creation phase, which steers the container's list properties
getContainerMeta() - Method in class org.rostore.v2.container.ContainerDescriptor
The metadata provided at the container creation
getContainerMeta(String) - Method in class org.rostore.service.ContainerAdminService
 
getContainerPermissions() - Method in class org.rostore.entity.apikey.ApiKeyPermissions
 
getContainerPermissions(String) - Method in class org.rostore.entity.apikey.ApiKeyPermissions
 
getContainerSpace(String) - Method in class org.rostore.service.ContainerAdminService
 
getContentType() - Method in class org.rostore.client.mapper.JsonMapper
The content type of the input stream
getContentType() - Method in interface org.rostore.client.mapper.Mapper
The content type of the input stream
getContentType() - Method in class org.rostore.client.mapper.NativeMapper
The content type of the input stream
getContentType() - Method in class org.rostore.client.RequestProperties
Content type of the request (header).
getContinuationKey() - Method in class org.rostore.client.StringKeyList
Provides a continuation key for the next call
getCreationTime() - Method in class org.rostore.entity.media.ContainerMeta
 
getCreationTime() - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
getData() - Method in class org.rostore.v2.container.DataWithRecord
Provides the value data
getDataCapacity() - Method in class org.rostore.v2.keys.VarSizeBlock
Gets the total capacity in bytes of this block
getDataCapacity() - Method in class org.rostore.v2.keys.VarSizeEntry
Gets the total capacity of the block
getDataCapacity() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Provides a total size of space within the current block
getDataLength() - Method in class org.rostore.v2.keys.VarSizeEntry
Gets the total size of payload stored in the block.
getDataSize() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Provides the total size of the data stored in the multi block
getDescription() - Method in enum class org.rostore.cli.Operation
 
getDescriptor() - Method in class org.rostore.v2.container.Container
The container descriptor defines the persistence model of the container.
getDescriptor() - Method in class org.rostore.v2.container.ContainerShard
 
getEntriesNumber() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Get the number of entries that exist in the block.
getEntriesNumber() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Provides a number of entries added to the block
getEntriesNumber() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Get the number of entries that exist in the block.
getEntry() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Provides an associated entry (which contain the real business logic)
getEntry() - Method in class org.rostore.v2.keys.VarSizeBlock
Get the entries in the block
getEntryCapacity() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Provides a total entry capacity of the block
getEntryLocation() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Provides a pointer of the start of the entry within the block in bytes
getEntrySize() - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Provides an entry size in bytes
getEntrySize() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Provides an entry size in bytes
getEntrySize() - Method in class org.rostore.v2.keys.KeyBlockEntry
Provides an entry size in bytes
getEntrySize() - Method in class org.rostore.v2.keys.VarSizeEntry
Gets the currently selected entry's size
getEntryStart() - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Provides the start block in the entry
getEntryStop() - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Provides the stop block in the entry
getEol() - Method in class org.rostore.entity.Record
Returns end of life as it stored in the record
getEOL() - Method in class org.rostore.client.RequestProperties
The Unix End of Live - used to set the expiration of the key.
getEOLHeader(CloseableHttpResponse) - Method in class org.rostore.client.RoStoreClient
Extracts eol header from the server response
getEolLength() - Method in class org.rostore.v2.keys.RecordLengths
The length of the end of life element for every key entry
getErrorRepresentation() - Method in class org.rostore.service.RestError
 
getException() - Method in class org.rostore.service.RestError
 
getException() - Method in class org.rostore.v2.container.async.AsyncStream
 
getException() - Method in class org.rostore.v2.container.async.Operation
 
getExecutorService() - Method in class org.rostore.v2.container.async.AsyncContainers
 
getFirst() - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
getFirstFreeIndex() - Method in class org.rostore.v2.seq.BlockIndexSequence
 
getFirstHeaderSize() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Provides the header's size of the first block
getFixSizeEntryBlock() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Provides the block abstraction this entry is created with
getFreeBlockNumber() - Method in class org.rostore.v2.seq.BlockIndexSequence
 
getFreeBlocks() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
 
getFreeBlocks() - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
 
getFreeSpace() - Method in class org.rostore.v2.keys.VarSizeEntry
Gets the free space within the current block
getGeneralContainer(String) - Method in class org.rostore.client.RoStoreClient
Creates object GeneralContainer.
getGeneralContainer(String, KeySerializer<K>) - Method in class org.rostore.client.RoStoreClient
Creates object GeneralContainer.
getGroup(int) - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
getGroupNumber() - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
getHash() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Returns a hash of the current location of the entry, which encompasses with the index of the block and the index of the entry.
getHeaderSize() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Provides a current header's size
getHeaderSize() - Method in class org.rostore.v2.keys.VarSizeBlock
Get the header size of the current block
getHeaderSize() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Provides a header size in bytes.
getHeaderSize() - Method in class org.rostore.v2.seq.SequenceBlock
The size of the header of the current block
getId() - Method in class org.rostore.entity.Record
The Id associated with the key-value pair.
getId() - Method in class org.rostore.v2.keys.KeyBlockEntry
Reads an id associated with the current entry
getIdLength() - Method in class org.rostore.v2.keys.RecordLengths
The length of the id element for every key entry
getIncorrectEOL() - Method in exception class org.rostore.entity.EOLIncorrectException
 
getIndex() - Method in class org.rostore.v2.container.ContainerShard
 
getIndex() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Get current index of the entry
getIndex() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
The index of the block in the ro-store.
getIndex() - Method in class org.rostore.v2.seq.SequenceBlock
Provides the current pointer where it points
getInputStream(CloseableHttpResponse) - Static method in class org.rostore.client.RoStoreClient
 
getInt() - Method in class org.rostore.v2.media.block.Block
Reads an int at the current position and increment the current position by 4
getJsonMapper() - Method in class org.rostore.client.RoStoreClient
 
getKey() - Method in class org.rostore.client.VersionedObject
Returns the key's object
getKey() - Method in class org.rostore.entity.apikey.ApiKeyDefinition
 
getKey(byte[]) - Method in class org.rostore.v2.container.ContainerShardKeyOperations
Executes an operation to find a key
getKeyBlockIndex() - Method in class org.rostore.v2.keys.KeyBlockEntry
Reads the key block index from the current entry
getKeyBlockOffset() - Method in class org.rostore.v2.keys.KeyBlockEntry
Provides an offset of the key in the key block
getKeyPath(K) - Method in class org.rostore.client.GeneralContainer
 
getKeys() - Method in class org.rostore.client.StringKeyList
List of keys.
getKeys() - Method in class org.rostore.entity.StringKeyList
 
getKeys() - Method in class org.rostore.v2.keys.KeyList
Provides the list of keys
getKeys(String, String, String) - Method in class org.rostore.service.KeyValueService
 
getKeysStartIndex() - Method in class org.rostore.v2.container.ContainerShardDescriptor
The first block index of the of key catalog's sequence of the shard
getKeyStartIndex() - Method in class org.rostore.v2.container.ContainerListHeader
The start block index, the index where the container key sequence is stored.
getLastUpdate() - Method in class org.rostore.entity.apikey.ApiKeyDefinition
 
getLastUsageTimestampMillis() - Method in class org.rostore.v2.seq.BlockIndexSequence
 
getLength() - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
getLevel() - Method in class org.rostore.service.RestError
 
getLockedFreeSize() - Method in interface org.rostore.entity.BlockAllocation
Get number of bytes that have been free from the allocated data.
getLockedFreeSize() - Method in class org.rostore.entity.BlockAllocationState
Get number of bytes that have been free from the allocated data.
getLong() - Method in class org.rostore.v2.media.block.Block
Reads a long at the current position and increment the current position by 8
getLong(int) - Method in class org.rostore.v2.media.block.Block
Reads the given number of bytes from the current position and increment the current position by this number of bytes.
getMagic() - Method in class org.rostore.v2.media.MediaHeader
Provides a magic byte that is used for verification
getMappedContainer(String, Mapper) - Method in class org.rostore.client.RoStoreClient
Creates a new light-weight object that represents access to the container.
getMappedContainer(String, Mapper, KeySerializer<K>) - Method in class org.rostore.client.RoStoreClient
Creates a new light-weight object that represents access to the container.
getMappedPhysicalBlocks() - Method in class org.rostore.v2.media.Media
Provides the set of currently mapped physical blocks
getMapperProperties() - Method in class org.rostore.client.mapper.NativeMapper
 
getMapperProperties() - Method in class org.rostore.v2.media.MediaProperties
The mapper properties that are calculated based on the storage properties
getMaxCleanupsPerCycle() - Method in class org.rostore.entity.media.ContainerListProperties
 
getMaxConnectionsPerRoute() - Method in class org.rostore.client.RoStoreClientProperties
 
getMaxContainersListSize() - Method in class org.rostore.entity.media.ContainerListProperties
The maximum size in bytes of all container names in the list
getMaxContainersPerList() - Method in class org.rostore.entity.media.ContainerListProperties
The maximum number of containers in the storage
getMaxKeyOperationsPerShard() - Method in class org.rostore.entity.media.ContainerListProperties
The maximum number of key operations that the shard would support in parallel.
getMaxSize() - Method in class org.rostore.entity.media.ContainerMeta
The maximum size of the container.
getMaxSize() - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
getMaxTotalConnections() - Method in class org.rostore.client.RoStoreClientProperties
 
getMaxTotalSize() - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Provides the total maximum size of the storage
getMaxTotalSize() - Method in class org.rostore.v2.media.MediaHeader
getMaxTotalSize() - Method in class org.rostore.v2.media.MediaProperties
Provides the total maximum size of the storage
getMaxTTL() - Method in class org.rostore.entity.media.ContainerMeta
The maximum TTL in seconds that the keys can have in the container.
getMaxTTL() - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
getMedia() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Provides the parent media
getMedia() - Method in class org.rostore.v2.container.async.AsyncContainerMedia
 
getMedia() - Method in class org.rostore.v2.container.ContainerListOperations
 
getMedia() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Provides parent media
getMedia() - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
The parent media
getMedia() - Method in interface org.rostore.v2.media.block.BlockProvider
Provides an associated Media object
getMedia() - Method in class org.rostore.v2.media.block.container.BlockContainer
A media object this container belongs to
getMedia() - Method in class org.rostore.v2.media.block.InternalBlockProvider
Provides an associated Media object
getMediaProperties() - Method in class org.rostore.entity.media.RoStoreProperties
 
getMediaProperties() - Method in class org.rostore.v2.container.async.AsyncContainerMediaProperties
 
getMediaProperties() - Method in class org.rostore.v2.media.Media
Provides the properties that has been used for the creation of the media
getMediaType() - Method in enum class org.rostore.client.ContentType
 
getMemoryConsumption() - Method in class org.rostore.v2.media.Media
Provides information about the objects this Media holds.
getMemoryManagement() - Method in class org.rostore.v2.container.ContainerListOperations
 
getMessage() - Method in class org.rostore.service.ErrorRepresentation
 
getMeta() - Method in class org.rostore.client.GeneralContainer
Returns the container's metadata
getMultiBlock() - Method in class org.rostore.v2.keys.VarSizeBlock
Get the multi block.
getMultiEntryHeaderSize() - Method in class org.rostore.v2.keys.VarSizeBlock
 
getName() - Method in class org.rostore.client.GeneralContainer
 
getName() - Method in class org.rostore.client.MappedContainer
 
getName() - Method in class org.rostore.v2.container.Container
The name of the container.
getName() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Used to identify the allocator, e.g.
getName() - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
The name of the allocator
getNativeMapper() - Method in class org.rostore.client.RoStoreClient
 
getNextBlockIndex() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Provides the index of the next block
getObjectClass() - Method in class org.rostore.client.VersionedObject
Get the Class of the object
getOffset() - Method in class org.rostore.v2.keys.VarSizeEntry
Gets the current offset within a block.
getPath() - Method in class org.rostore.client.RequestProperties
The REST path to execute.
getPayloadSize() - Method in interface org.rostore.entity.BlockAllocation
Get number of bytes used by the data.
getPayloadSize() - Method in class org.rostore.entity.BlockAllocationState
Get number of bytes used by the data.
getPreamble() - Method in class org.rostore.v2.keys.VarSizeBlock
Get a byte of preamble that defines a type of the block and encode a number of bytes needed to store the length of data in case of multi-block
getProperties() - Method in class org.rostore.client.RoStoreClient
Returns the rostore connection properties
getRecord() - Method in exception class org.rostore.entity.OptionMismatchException
Record caused an exception (as provided when operation is executed)
getRecord() - Method in class org.rostore.v2.container.DataWithRecord
Provides a metadata of the entry
getRecord() - Method in class org.rostore.v2.keys.KeyBlockEntry
Reads the record from the current position
getRecord(byte[]) - Method in class org.rostore.v2.keys.KeyBlockOperations
Searches for the provided key and return the Record associated with it.
getRecordLengths() - Method in class org.rostore.v2.keys.KeyBlockEntry
A class with length in bytes of key-entry elements
getRecordOptions() - Method in class org.rostore.client.RequestProperties
 
getRegularHeaderSize() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Provides the size of all block's headers except of the first one
getRequestProperties() - Method in exception class org.rostore.client.ClientException
 
getRequestTimeout() - Method in class org.rostore.client.RoStoreClientProperties
 
getRequiredOptions() - Method in enum class org.rostore.cli.Operation
 
getRootBlockAllocator() - Method in class org.rostore.v2.media.Media
Provides the root block allocator.
getRootCause() - Method in exception class org.rostore.v2.container.async.OperationExecutionRuntimeException
 
getRoStoreClientProperties() - Method in class org.rostore.client.RequestProperties
Properties of the RoStoreClient to be used in the request.
getSegmentNumber() - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
getSequenceBlock() - Method in class org.rostore.v2.seq.BlockSequence
 
getSequenceIndexFreeBlockNumber() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Provides a number of free blocks in the underlying BlockIndexSequence.
getSequenceIndexFreeBlockNumber() - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Provides a number of free blocks in the underlying BlockIndexSequence.
getServerMessage() - Method in exception class org.rostore.client.ClientException
 
getSessionId() - Method in class org.rostore.v2.container.async.Operation
 
getShard() - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
getShard(int) - Method in class org.rostore.v2.container.Container
Requests the shard by index.
getShardAllocator() - Method in class org.rostore.v2.container.ContainerShard
 
getShardDescriptors() - Method in class org.rostore.v2.container.ContainerDescriptor
A list of shard descriptors, containing initialization data for every shard
getShardExecutorByIndex(int) - Method in class org.rostore.v2.container.async.AsyncContainer
 
getShardExecutorByKey(byte[]) - Method in class org.rostore.v2.container.async.AsyncContainer
 
getShardNumber() - Method in class org.rostore.entity.media.ContainerMeta
The number of shards the container will have.
getShardNumber() - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
getSize() - Method in class org.rostore.v2.keys.KeyList
Provides the size of all keys
getStart() - Method in class org.rostore.v2.catalog.CatalogBlockEntryInstance
 
getStartIndex() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Gives the index of the first block of the sequence where the data associated with catalog is stored.
getStartIndex() - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Gives the index of the first block of the sequence where the data associated with catalog is stored.
getStartIndex() - Method in class org.rostore.v2.data.DataWriter
Provides the first block of the stored data
getStartIndex() - Method in class org.rostore.v2.keys.KeyBlockOperations
This is first block's index.
getStartIndex() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Provides the first block index of the allocator itself
getStartIndex() - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
Return the first block of the allocator
getState() - Method in class org.rostore.service.RoStoreAccessor
 
getStatus() - Method in class org.rostore.service.RestError
 
getStatus() - Method in exception class org.rostore.service.RoStoreServiceException
 
getStatus() - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Provides a status of this entity
getStatus() - Method in class org.rostore.v2.catalog.CatalogBlockOperations
 
getStatus() - Method in class org.rostore.v2.container.async.AsyncContainer
 
getStatus() - Method in class org.rostore.v2.container.async.AsyncContainerMedia
 
getStatus() - Method in class org.rostore.v2.container.Container
 
getStatus() - Method in class org.rostore.v2.container.ContainerShard
 
getStatus() - Method in class org.rostore.v2.container.ContainerShardKeyOperations
Provides a status of this entity
getStatus() - Method in class org.rostore.v2.data.DataReader
 
getStatus() - Method in class org.rostore.v2.data.DataWriter
 
getStatus() - Method in class org.rostore.v2.keys.KeyBlockOperations
 
getStatus() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Provides a status of this entity
getStatus() - Method in class org.rostore.v2.media.block.Block
 
getStatus() - Method in class org.rostore.v2.media.block.container.BlockContainer
 
getStatus() - Method in interface org.rostore.v2.media.Closeable
Provides a status of this entity
getStatus() - Method in class org.rostore.v2.media.RootClosableImpl
 
getStatus() - Method in class org.rostore.v2.seq.SequenceBlock
Provides a status of the block sequence
getStop() - Method in class org.rostore.v2.catalog.CatalogBlockEntryInstance
 
getStorePermissions() - Method in class org.rostore.entity.apikey.ApiKeyPermissions
 
getString(RequestProperties) - Method in class org.rostore.client.RoStoreClient
Executes the request on rostore and return the response as string (UTF-8)
getTarget() - Method in class org.rostore.v2.container.async.Operation
 
getTotalBlockNumber() - Method in class org.rostore.v2.media.MediaProperties
Provides the total number of blocks that the storage supports
getTotalDataSize() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Provides the total size stored in the multi block as stored in the header
getTotalLength() - Method in class org.rostore.v2.keys.RecordLengths
The length of all elements of record
getTotalLockedSize() - Method in interface org.rostore.entity.BlockAllocation
Get number of bytes allocated for the data.
getTotalLockedSize() - Method in class org.rostore.entity.BlockAllocationState
Get number of bytes allocated for the data.
getTotalSize() - Method in class org.rostore.v2.keys.VarSizeEntry
Returns the total size of all elements stored in the block, including entries and header.
getTrackingId() - Method in exception class org.rostore.client.ClientException
 
getTrackingId() - Method in class org.rostore.service.ErrorRepresentation
 
getTtl() - Method in class org.rostore.entity.Record
Gets ttl is seconds
getType() - Method in class org.rostore.v2.container.async.Operation
 
getUnixEol() - Method in class org.rostore.entity.Record
Calculates the end of life in terms of unix epoc
getUnixEOL() - Method in class org.rostore.client.VersionedObject
 
getUnusedSince() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
Provides a timestamp when this block become unused.
getUpdateRetries() - Method in class org.rostore.client.RoStoreClientProperties
 
getUpdateTimeoutMax() - Method in class org.rostore.client.RoStoreClientProperties
 
getValue() - Method in class org.rostore.client.VersionedObject
Get the value
getValue(Record, T) - Method in class org.rostore.v2.container.ContainerShard
Function to store the body of the value, using the shard's allocator
getValueId() - Method in class org.rostore.v2.container.async.Operation
 
getVersion() - Method in class org.rostore.client.VersionedObject
Get the object's version.
getVersion() - Method in class org.rostore.entity.Record
Provides a version as set to record
getVersionHeader(CloseableHttpResponse) - Static method in class org.rostore.client.RoStoreClient
Extracts version header from the server response
getVersionLength() - Method in class org.rostore.v2.keys.RecordLengths
The length of the version element for every key element
getWrapped(K, EnumSet<RecordOption>, Function<VersionedObject<K, InputStream>, VersionedObject<K, V>>) - Method in class org.rostore.client.GeneralContainer
 
GRANT - Enum constant in enum class org.rostore.entity.apikey.Permission
Permission to grant permissions

H

hasBlock(long) - Method in class org.rostore.v2.media.block.container.BlockContainer
Checks if the block with the given index is in this container
hasFreeSpace() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Provides an indication if the current block has free space
hasMore() - Method in class org.rostore.v2.data.DataReader
 
hasOption(RecordOption) - Method in class org.rostore.entity.Record
Checks if the record contains a provided option
HEADER_API_KEY - Static variable in class org.rostore.client.RoStoreClient
 
HEADER_CONTENT_TYPE - Static variable in class org.rostore.client.RoStoreClient
 
HEADER_EOL - Static variable in class org.rostore.client.RoStoreClient
 
HEADER_OPTIONS - Static variable in class org.rostore.client.RoStoreClient
 
HEADER_TRACKING_ID - Static variable in class org.rostore.client.RoStoreClient
 
HEADER_VERSION - Static variable in class org.rostore.client.RoStoreClient
 
Headers - Class in org.rostore.service
 
Headers() - Constructor for class org.rostore.service.Headers
 
help(Options) - Static method in class org.rostore.cli.Cli
 
HELP - Enum constant in enum class org.rostore.cli.Operation
 

I

id(long) - Method in class org.rostore.entity.Record
Sets the id to be stored with the record.
ID_UNDEFINED - Static variable in class org.rostore.Utils
 
IDLE - Enum constant in enum class org.rostore.v2.container.async.KeyExecutionState
 
incAddedNumber(long) - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Increments the total number of blocks added to the catalog, stored in the first block of the sequence.
incDataLength(long) - Method in class org.rostore.v2.keys.VarSizeEntry
Increments the current data length within the current block
incKeyBlockOffset(long) - Method in class org.rostore.v2.keys.KeyBlockEntry
Increments the offset associated with the key by provided increment
incrementVersion(int) - Method in class org.rostore.entity.Record
Increment version
init() - Static method in class org.rostore.entity.BlockAllocationState
 
init(long, long, long) - Static method in class org.rostore.entity.BlockAllocationState
Initializes the state object
init(String) - Method in class org.rostore.service.apikey.ApiKeyRequestContext
 
init(RoStoreState) - Method in class org.rostore.service.apikey.ApiKeyManager
 
init(Block) - Method in class org.rostore.v2.keys.VarSizeEntry
Initializes a new entry-based block at the provided block.
INITIALIZED - Enum constant in enum class org.rostore.service.RoStoreState
 
initStore(RoStoreProperties) - Method in class org.rostore.service.StoreAdminService
 
insert() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Allocates an entry at the current index.
insert(byte[]) - Method in class org.rostore.v2.keys.VarSizeEntry
Inserts the data provided to the currently selected offset.
insertWindows(int, int) - Method in class org.rostore.v2.media.block.Block
To shift all the data in the block that starts at current position and move it to the location shifted at the windowSize to the front (insert operation)
INSTANCE - Static variable in class org.rostore.client.DefaultKeySerializer
 
InternalBlockProvider - Class in org.rostore.v2.media.block
This instance manages a low-level block operation and creates a new BlockContainer.
INTERRUPTED_SHARD_OPERATION - Static variable in class org.rostore.v2.container.async.InterruptedShardOperation
 
InterruptedShardOperation<R> - Class in org.rostore.v2.container.async
 
InterruptedShardOperation() - Constructor for class org.rostore.v2.container.async.InterruptedShardOperation
 
inUse() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
Provides an indication if this block is used in at least one active process
invalid() - Method in class org.rostore.v2.catalog.CatalogBlockEntryInstance
 
invalid() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Checks if current entry has been marked as invalid.
invalid() - Method in class org.rostore.v2.keys.VarSizeBlock
 
invalid() - Method in class org.rostore.v2.seq.SequenceBlock
Checks if the pointer points to invalid block
invalidate() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Moves the pointer to invalid index, marks the block as invalid.
invalidate() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Marks this entry as invalid
invalidate() - Method in class org.rostore.v2.seq.SequenceBlock
Moves the pointer to invalid index, marks the block as invalid.
isAutonomous() - Method in class org.rostore.v2.container.async.Operation
 
isCancelled() - Method in class org.rostore.v2.container.async.AsyncStream
 
isCancelled() - Method in class org.rostore.v2.container.async.InterruptedShardOperation
 
isCancelled() - Method in class org.rostore.v2.container.async.Operation
 
isDefaultApiKeyUsed() - Method in class org.rostore.service.apikey.ApiKeyRequestContext
 
isDirty() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
Provides an indication if this block has been modified in memory, but has not been explicitly flushed to the persistence layer.
isDone() - Method in class org.rostore.v2.container.async.AsyncStream
 
isDone() - Method in class org.rostore.v2.container.async.InterruptedShardOperation
 
isDone() - Method in class org.rostore.v2.container.async.Operation
 
isEmpty() - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
isEmpty() - Method in class org.rostore.v2.catalog.CatalogBlockIndicesIterator
 
isEmpty() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
 
isEnabled() - Method in class org.rostore.v2.media.block.allocator.BlockAllocatorListeners
Enabled if at least one listener is added
isExpired() - Method in class org.rostore.v2.keys.KeyBlockEntry
Checks if current entry is expired (according to EOL)
isExpired(long) - Method in class org.rostore.v2.keys.KeyBlockEntry
Checks if current entry is expired (according to EOL)
isExpiredEOL(long) - Static method in class org.rostore.Utils
 
isExpiredEOL(long, long) - Static method in class org.rostore.Utils
 
isFinished() - Method in enum class org.rostore.v2.container.async.AsyncStatus
 
isFirst() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Checks if currently selected entry is the first one in the block
isFirst() - Method in class org.rostore.v2.keys.VarSizeEntry
Checks if currently selected entry is the first one
isIdle() - Method in class org.rostore.v2.container.async.AsyncContainer
 
isIdle() - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
isLast() - Method in class org.rostore.v2.keys.VarSizeEntry
Checks if currently selected entry is the last one
isMore() - Method in class org.rostore.client.StringKeyList
 
isMore() - Method in class org.rostore.entity.StringKeyList
 
isMore() - Method in class org.rostore.v2.keys.KeyList
Provides a flag if more keys are available in the storage
isMultiBlock() - Method in class org.rostore.v2.keys.VarSizeBlock
If it is a multi-block block.
isMultiEntry() - Method in class org.rostore.v2.keys.VarSizeBlock
If it is a multi-entry block (several entries in one block)
isQueued() - Method in class org.rostore.v2.container.async.CleanupManager
 
isRoot() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Identifies if this is the first block in the sequence
isRoot() - Method in class org.rostore.v2.seq.SequenceBlock
Checks if the current block is the first block of the sequence
isRootApiKey() - Method in class org.rostore.service.apikey.ApiKeyManager
 
isSequenceInUse() - Method in class org.rostore.v2.seq.BlockIndexSequence
 
isUnused() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Provides an indication if current block does not contain any data
isUnused() - Method in class org.rostore.v2.seq.SequenceBlock
Provides an indication if current block does not contain any data
isValid() - Method in class org.rostore.v2.catalog.CatalogBlockIndicesIterator
 
isVersioned() - Method in class org.rostore.client.VersionedObject
Gets is the object versioned or not
iterateAll(Consumer<CatalogBlockIndices>) - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
Iterates all blocks in the catalog, inclusive those from the cache
iterateAll(Consumer<CatalogBlockIndices>) - Method in class org.rostore.v2.catalog.CatalogBlockOperations
A function will iteratively provide all block indices in the catalog
iterateIndices(Consumer<CatalogBlockIndices>) - Method in class org.rostore.v2.data.DataReader
Executed block by block with its content.
iterator() - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 

J

JSON - Enum constant in enum class org.rostore.client.ContentType
 
JsonMapper - Class in org.rostore.client.mapper
This one uses the ObjectMapper to serialize / deserialize the content of the store
JsonMapper(ObjectMapper) - Constructor for class org.rostore.client.mapper.JsonMapper
 

K

key(int, OperationType, Supplier<R>) - Static method in class org.rostore.v2.container.async.Operation
 
KEY - Enum constant in enum class org.rostore.v2.container.async.OperationTarget
 
KEY - Enum constant in enum class org.rostore.v2.media.block.BlockType
Block belongs to the key catalog and used for block accounting (e.g.
KeyBlockEntry - Class in org.rostore.v2.keys
Represents an entry with exactly one key.
KeyBlockEntry(FixSizeEntryBlock<KeyBlockEntry>, VarSizeBlock, RecordLengths) - Constructor for class org.rostore.v2.keys.KeyBlockEntry
 
KeyBlockOperations - Class in org.rostore.v2.keys
This is a class to manage keys.
KeyExecutionState - Enum Class in org.rostore.v2.container.async
 
KeyExpirationUpdateFunction - Interface in org.rostore.client
This interface (function) provides a flexible way to define a new expiration policy for the given object
keyFunction(Function<ContainerShardKeyOperations, T>) - Method in class org.rostore.v2.container.ContainerShard
Executes an operation on the shard's keys catalog.
KeyList - Class in org.rostore.v2.keys
A list of keys loaded by the KeyBlockOperations.
KeyList() - Constructor for class org.rostore.v2.keys.KeyList
 
KeySerializer<K> - Interface in org.rostore.client
Interface specifies the logic for key object serialization
KeyValueService - Class in org.rostore.service
 
KeyValueService() - Constructor for class org.rostore.service.KeyValueService
 

L

last() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Moves the current index to the last available entry in the block
last() - Method in class org.rostore.v2.seq.SequenceBlock
Moves the pointer to the last used block in the sequence.
left() - Method in class org.rostore.v2.catalog.CatalogBlockIndicesIterator
 
left() - Method in class org.rostore.v2.media.block.Block
The size left in the block starting from current position
length() - Method in class org.rostore.v2.data.DataReader
 
length() - Method in class org.rostore.v2.media.block.Block
The total size of the block
length() - Method in class org.rostore.v2.seq.BlockIndexSequence
 
length() - Method in class org.rostore.v2.seq.BlockSequence
 
list(byte[], byte[], long, long) - Method in class org.rostore.v2.keys.KeyBlockOperations
List the keys managed by this instance.
list(int, byte[], byte[], int, int) - Method in class org.rostore.v2.container.async.AsyncContainer
List the keys in the container
list(int, String, String, int, int) - Method in class org.rostore.v2.container.async.AsyncContainer
List the keys in the container
list(String) - Method in class org.rostore.service.apikey.ApiKeyManager
 
LIST - Enum constant in enum class org.rostore.entity.apikey.Permission
Permission to list entries, e.g.
LIST_CONTAINER_KEYS - Enum constant in enum class org.rostore.cli.Operation
 
LIST_CONTAINERS - Enum constant in enum class org.rostore.cli.Operation
 
LIST_MAX_CONTAINERS_DEFAULT - Static variable in class org.rostore.entity.media.ContainerListProperties
 
LIST_MAX_SIZE_DEFAULT - Static variable in class org.rostore.entity.media.ContainerListProperties
 
listAllContainers() - Method in class org.rostore.service.RoStoreAccessor
 
listAllContainers() - Method in class org.rostore.v2.container.async.AsyncContainers
 
listAllContainers() - Method in class org.rostore.v2.container.ContainerListOperations
 
listApiKey(String) - Method in class org.rostore.service.ApiKeyService
 
listApiKeys(String) - Method in class org.rostore.client.ApiKeys
Lists all api keys.
listAsync(int, byte[], byte[], int, int) - Method in class org.rostore.v2.container.async.AsyncContainer
List the keys in the container
listContainers() - Method in class org.rostore.client.RoStoreClient
Get the list of all container names on the remote service
listKeys(byte[], byte[], int, int) - Method in class org.rostore.v2.container.ContainerShardKeyOperations
 
listKeys(String, String) - Method in class org.rostore.client.GeneralContainer
Lists the keys within the container.
load(File) - Static method in class org.rostore.v2.container.async.AsyncContainerMedia
 
load(File, ExecutorService) - Static method in class org.rostore.v2.container.async.AsyncContainerMedia
 
load(String, BlockAllocator, long, long) - Static method in class org.rostore.v2.media.block.allocator.SecondaryBlockAllocator
Loads the secondary block allocator by providing the first block of the allocator
load(BlockAllocator, long, RecordLengths) - Static method in class org.rostore.v2.keys.KeyBlockOperations
Loads the key operations
load(BlockProvider, long) - Static method in class org.rostore.v2.catalog.CatalogBlockOperations
Loads an instance of the catalog based on the index of the first block (given by CatalogBlockOperations.getStartIndex()).
load(BlockProvider, long, Function<BlockSequence<T>, T>, BlockType) - Static method in class org.rostore.v2.seq.SequenceBlock
Loads block sequence and initialize a specific kind of sequence block on its basis.
load(Media) - Static method in class org.rostore.v2.media.block.allocator.RootBlockAllocator
 
load(Media, ExecutorService, ContainerListHeader) - Static method in class org.rostore.v2.container.async.AsyncContainers
 
load(Media, ContainerListHeader) - Static method in class org.rostore.v2.container.async.AsyncContainers
 
loadSecondaryBlockAllocator(String, long, long) - Method in class org.rostore.v2.media.Media
Loads SecondaryBlockAllocator based on the internal root allocator.

M

MAGIC - Static variable in class org.rostore.v2.media.Media
 
main(String[]) - Static method in class org.rostore.cli.Cli
 
mainWithException(Operation, CommandLine) - Static method in class org.rostore.cli.Cli
 
map(long) - Method in class org.rostore.v2.media.Media
A low-level operation of mapping of the block referenced by its index to the mapped byte buffer.
MappedContainer<K> - Class in org.rostore.client
Encapsulates access to the container that uses specific serializer / deserializer.
MappedContainer(RoStoreClient, String, Mapper, KeySerializer<K>) - Constructor for class org.rostore.client.MappedContainer
 
MappedPhysicalBlock - Class in org.rostore.v2.media.block
Represents the mapped to the memory the physical block of the storage.
MappedPhysicalBlock(long, BlockType) - Constructor for class org.rostore.v2.media.block.MappedPhysicalBlock
 
MappedPhysicalBlocks - Class in org.rostore.v2.media.block
This is a container of all active physical blocks in the ro-store.
MappedPhysicalBlocks(Media) - Constructor for class org.rostore.v2.media.block.MappedPhysicalBlocks
Creates an object
Mapper - Interface in org.rostore.client.mapper
Provides serialization / deserialization for mapping of the underlying objects
mapperProperties() - Method in class org.rostore.service.StoreAdminService
 
MapperProperties - Class in org.rostore.mapper
Class defines the properties of the BinaryMapper that specify the length of the fields depending on the storage internal properties.
MapperProperties() - Constructor for class org.rostore.mapper.MapperProperties
 
markAsUsed(BlockContainer) - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
This marks the block as used (inUse = true)
markDirty() - Method in class org.rostore.v2.media.block.Block
 
markSequenceUsed() - Method in class org.rostore.v2.seq.BlockIndexSequence
 
MAX_CLEANS_PER_CYCLE_DEFAULT - Static variable in class org.rostore.entity.media.ContainerListProperties
 
MAX_FREE_BLOCK_NUMBER - Static variable in class org.rostore.v2.seq.Properties
Maximum number of free blocks that the sequence should keep for the internal purposes of on-the-fly allocation.
MAX_KEY_OPERATIONS_PER_SHARD_DEFAULT - Static variable in class org.rostore.entity.media.ContainerListProperties
Number of opened KeyOperations object for every opened shard
MAX_STRING_KEY_REPRESENTATION - Static variable in class org.rostore.v2.keys.Properties
Specifies the maximum length of the key representation for internal logging.
maxTotalSize(long) - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Sets the maximum total size of the storage
Media - Class in org.rostore.v2.media
A major class representing the ro-store storage.
Media(File, BiConsumer<Media, DataReader>) - Constructor for class org.rostore.v2.media.Media
Load an existing media
Media(File, MediaProperties, BiConsumer<Media, DataWriter>) - Constructor for class org.rostore.v2.media.Media
Create a new media
MediaHeader - Class in org.rostore.v2.media
This object is stored in the first block of ro-store Media.
MediaHeader() - Constructor for class org.rostore.v2.media.MediaHeader
 
MediaProperties - Class in org.rostore.v2.media
Properties of the media that defines its major parameters.
MediaProperties() - Constructor for class org.rostore.v2.media.MediaProperties
 
MediaPropertiesBuilder - Class in org.rostore.entity.media
This one is needed to create MediaProperties.
MediaPropertiesBuilder() - Constructor for class org.rostore.entity.media.MediaPropertiesBuilder
 
MemoryConsumption - Class in org.rostore.v2.media
Provides information about the objects the ro-store Media instance is currently keeping in memory.
MemoryConsumption(int, int, int) - Constructor for class org.rostore.v2.media.MemoryConsumption
 
MIN_FREE_BLOCK_NUMBER - Static variable in class org.rostore.v2.seq.Properties
Minimum number of free blocks that the sequence should keep for the internal purposes of on-the-fly allocation.
minus(BlockAllocation) - Method in class org.rostore.entity.BlockAllocationState
Subtracts the sizes from the provided object to this object
moveEntriesFrom(int, int) - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Moves (appends) all entries starting from the given source block index / source entry index to the last entry in the source block to the end of this block.
moveTo(int) - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
Sets the current location of block to the specified sequence index.
moveTo(int) - Method in class org.rostore.v2.fixsize.ValidatingEntry
Sets the current index to the value as provided.
moveTo(int) - Method in class org.rostore.v2.keys.KeyBlockEntry
Sets the current index to the value as provided.
moveTo(int) - Method in class org.rostore.v2.seq.SequenceBlock
Moves the pointer to the specific block in the sequence
moveTo(long) - Method in class org.rostore.v2.keys.VarSizeBlock
Selects the current memory block.
moveToHash(long) - Method in class org.rostore.v2.fixsize.FixSizeEntry
Moves the location of the current entry to the previously stored hash (see FixSizeEntry.getHash()).
MULTIPLE - Enum constant in enum class org.rostore.v2.container.async.KeyExecutionState
 

N

NativeMapper - Class in org.rostore.client.mapper
This one uses the native serializer of the ro-store
NativeMapper(MapperProperties) - Constructor for class org.rostore.client.mapper.NativeMapper
 
needsTargetConnection() - Method in enum class org.rostore.cli.Operation
 
newBlockContainer() - Method in class org.rostore.v2.media.Media
Creates a new Block container, which represents a transactional boundary in ro-store, which must be closed after usage.
next() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Moves current index one step forward: index=index+1
next() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Moves to the next block
next() - Method in class org.rostore.v2.seq.SequenceBlock
Moves the pointer to the next block in the sequence.
noExpiration - Static variable in interface org.rostore.client.KeyExpirationUpdateFunction
 
NotFoundException - Exception Class in org.rostore.service
 
NotFoundException(String) - Constructor for exception class org.rostore.service.NotFoundException
 
notifyAllocated(String, BlockType, CatalogBlockIndices, boolean) - Method in class org.rostore.v2.media.block.allocator.BlockAllocatorListeners
Notify all listeners in the collection that a set of new blocks has just been allocated
notifyFreed(String, CatalogBlockIndices, boolean) - Method in class org.rostore.v2.media.block.allocator.BlockAllocatorListeners
Notify all listeners in the collection that a set of blocks has just been freed
notifyIdle(ContainerShardExecutor) - Method in class org.rostore.v2.container.async.AsyncContainer
 
notifyRecord(Record) - Method in class org.rostore.v2.container.async.AsyncStream
 

O

ONLY_INSERT - Enum constant in enum class org.rostore.entity.media.RecordOption
Should check on the key creation if the key already exist, and if not it should not allow an operation
ONLY_REPLACE - Enum constant in enum class org.rostore.entity.media.RecordOption
Should check if the update operation is executed on the existing key, and if not it should fail
open() - Method in class org.rostore.service.RoStoreAccessor
 
open(File) - Static method in class org.rostore.v2.media.Media
Opens the media object from the existing file
open(File, Class<T>, BiConsumer<Media, T>) - Static method in class org.rostore.v2.media.Media
Opens a media, reads the header and provides it for further initialization
open(File, BiConsumer<Media, DataReader>) - Static method in class org.rostore.v2.media.Media
Opens a media, allows to read the header from a binary stream
open(Container, int, ContainerShardDescriptor) - Static method in class org.rostore.v2.container.ContainerShard
Opens a shard of the container
open(BlockAllocator, long) - Static method in class org.rostore.v2.data.DataReader
Opens the data reader to start reading from the given block.
open(BlockAllocator, long) - Static method in class org.rostore.v2.data.DataWriter
Opens the data writer at the specific starting block index
open(Media, long) - Static method in class org.rostore.v2.data.DataReader
Opens the data reader to start reading from the given block.
OPENED - Enum constant in enum class org.rostore.service.RoStoreState
 
OPENED - Enum constant in enum class org.rostore.v2.container.async.AsyncStatus
 
OPENED - Enum constant in enum class org.rostore.v2.media.block.container.Status
 
Operation<R> - Class in org.rostore.v2.container.async
 
Operation - Enum Class in org.rostore.cli
 
OperationExecutionException - Exception Class in org.rostore.v2.container.async
 
OperationExecutionException(Throwable) - Constructor for exception class org.rostore.v2.container.async.OperationExecutionException
 
OperationExecutionRuntimeException - Exception Class in org.rostore.v2.container.async
 
OperationExecutionRuntimeException(OperationExecutionException) - Constructor for exception class org.rostore.v2.container.async.OperationExecutionRuntimeException
 
OperationTarget - Enum Class in org.rostore.v2.container.async
 
OperationType - Enum Class in org.rostore.v2.container.async
 
OptionMismatchException - Exception Class in org.rostore.entity
Exception thrown when an operation on a key can't be executed as requested
options(EnumSet<RecordOption>) - Method in class org.rostore.client.RequestProperties
 
OPTIONS_HEADER - Static variable in class org.rostore.service.Headers
 
org.rostore - package org.rostore
RoStore base package
org.rostore.cli - package org.rostore.cli
RoStore Command Line Interface
org.rostore.client - package org.rostore.client
RoStore java client classes
org.rostore.client.mapper - package org.rostore.client.mapper
Serializer/Deserializer used in the client.
org.rostore.entity - package org.rostore.entity
RoStore core entities
org.rostore.entity.apikey - package org.rostore.entity.apikey
General classes used in service and client for api key management.
org.rostore.entity.media - package org.rostore.entity.media
General classes used in service and client for media management
org.rostore.mapper - package org.rostore.mapper
Binary mapper that allows to serialize/deserialize data specific for the instance of rostore.
org.rostore.service - package org.rostore.service
RoStore REST service classes
org.rostore.service.apikey - package org.rostore.service.apikey
REST-related APIKey management classes
org.rostore.v2.catalog - package org.rostore.v2.catalog
All operation related to the catalog of blocks
org.rostore.v2.container - package org.rostore.v2.container
Classes related to the containers, shards
org.rostore.v2.container.async - package org.rostore.v2.container.async
RoStore async classes for high-frequency massive concurrency
org.rostore.v2.data - package org.rostore.v2.data
Classes related to value read/write safe operations
org.rostore.v2.fixsize - package org.rostore.v2.fixsize
General low-level functionality to read/write block content with entries of fixed size
org.rostore.v2.keys - package org.rostore.v2.keys
Low-level operation to read/write key entries
org.rostore.v2.media - package org.rostore.v2.media
Major classes that manage basic access to the ro-store
org.rostore.v2.media.block - package org.rostore.v2.media.block
Core Block-related functionalities
org.rostore.v2.media.block.allocator - package org.rostore.v2.media.block.allocator
Allocators root and secondary
org.rostore.v2.media.block.container - package org.rostore.v2.media.block.container
Transactional boundary
org.rostore.v2.seq - package org.rostore.v2.seq
Major classes that manage basic block sequence operations
OVERRIDE_VERSION - Enum constant in enum class org.rostore.entity.media.RecordOption
This one if provided should circumvent the version-check and rewrite the version even if not correct

P

pad(int) - Static method in class org.rostore.cli.Cli
 
parse(String) - Static method in enum class org.rostore.entity.media.RecordOption
Parses the comma-separated set of RecordOption
path(String) - Method in class org.rostore.client.RequestProperties
 
PATH__MAPPER_PROPERTIES - Static variable in class org.rostore.client.RoStoreClient
 
PATH__PING - Static variable in class org.rostore.client.RoStoreClient
 
PATH__SHUTDOWN - Static variable in class org.rostore.client.RoStoreClient
 
PATH__VERSION - Static variable in class org.rostore.client.RoStoreClient
 
Permission - Enum Class in org.rostore.entity.apikey
A permission
PermissionDeniedException - Exception Class in org.rostore.service.apikey
Exception is thrown when the client tries to execute an operation that it has no sufficient permissions for.
PermissionDeniedException(String) - Constructor for exception class org.rostore.service.apikey.PermissionDeniedException
 
ping() - Method in class org.rostore.client.RoStoreClient
Checks that the server is up and running
PING - Enum constant in enum class org.rostore.cli.Operation
 
pingStore() - Method in class org.rostore.service.StoreAdminService
 
plus(BlockAllocation) - Method in class org.rostore.entity.BlockAllocationState
Adds the sizes from the provided object to this object
position() - Method in class org.rostore.v2.catalog.CatalogBlockIndicesIterator
 
position() - Method in class org.rostore.v2.data.DataReader
 
position() - Method in class org.rostore.v2.media.block.Block
Provides current position in the block
position(int) - Method in class org.rostore.v2.media.block.Block
Sets current position in the block
post(RequestProperties, InputStream, Function<CloseableHttpResponse, T>) - Method in class org.rostore.client.RoStoreClient
Executes a post request on the rostore
post(VersionedObject<String, ApiKeyPermissions>) - Method in class org.rostore.client.ApiKeys
Creates a new api-key and associate the permissions with it
post(VersionedObject<K, InputStream>) - Method in class org.rostore.client.GeneralContainer
 
post(VersionedObject<K, InputStream>, EnumSet<RecordOption>) - Method in class org.rostore.client.GeneralContainer
 
post(VersionedObject<K, V>) - Method in class org.rostore.client.MappedContainer
Creates a new key-value pair.
post(VersionedObject<K, V>, EnumSet<RecordOption>) - Method in class org.rostore.client.MappedContainer
Creates a new key-value pair.
post(VersionedObject<K, V>, EnumSet<RecordOption>, Function<V, InputStream>) - Method in class org.rostore.client.GeneralContainer
 
post(VersionedObject<K, V>, Function<V, InputStream>) - Method in class org.rostore.client.GeneralContainer
 
previous() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Moves current index one step back: index=index-1
previous() - Method in class org.rostore.v2.seq.SequenceBlock
Moves the pointer to the previous block in the sequence.
print(String) - Static method in class org.rostore.cli.Cli
 
process(I) - Method in interface org.rostore.v2.container.async.AsyncFunction
 
processFunction(AsyncFunction<S>) - Method in class org.rostore.v2.container.async.AsyncStream
This function is called from the async process to process the entity.
Properties - Class in org.rostore.v2.container
 
Properties - Class in org.rostore.v2.data
Properties of the data transfer operations
Properties - Class in org.rostore.v2.keys
 
Properties - Class in org.rostore.v2.media.block.allocator
 
Properties - Class in org.rostore.v2.seq
 
Properties() - Constructor for class org.rostore.v2.container.Properties
 
Properties() - Constructor for class org.rostore.v2.data.Properties
 
Properties() - Constructor for class org.rostore.v2.keys.Properties
 
Properties() - Constructor for class org.rostore.v2.media.block.allocator.Properties
 
Properties() - Constructor for class org.rostore.v2.seq.Properties
 
put(byte[]) - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Stores the key data to the multi block sequence.
put(byte[], int, int) - Method in class org.rostore.v2.media.block.Block
Writes a subset of bytes from byte array
put(byte[], Record) - Method in class org.rostore.v2.keys.KeyBlockOperations
Store the record for specified key
put(int, byte[], Consumer<OutputStream>) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to container.
put(int, byte[], Consumer<OutputStream>, Record) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to container.
put(int, byte[], AsyncStream<T>, Record) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to the container
put(int, byte[], T, Record) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to container
put(int, String, Consumer<OutputStream>) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to container.
put(int, String, T) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to container.
put(int, String, T, Record) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to container.
put(String, String, String, Long, Long, Long, HttpServletResponse, HttpServletRequest) - Method in class org.rostore.service.KeyValueService
 
put(RequestProperties, InputStream, Function<CloseableHttpResponse, T>) - Method in class org.rostore.client.RoStoreClient
Executes a put request on the rostore
put(VersionedObject<String, ApiKeyPermissions>) - Method in class org.rostore.client.ApiKeys
Updates given api-key
put(Block, int) - Method in class org.rostore.v2.media.block.Block
Puts a given number of bytes from the given block to this one
PUT_KEY - Enum constant in enum class org.rostore.cli.Operation
 
putAsync(int, byte[], AsyncStream<T>) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to container.
putAsync(int, byte[], AsyncStream<T>, Record) - Method in class org.rostore.v2.container.async.AsyncContainer
Puts a key-value pair to container.
putByte(byte) - Method in class org.rostore.v2.media.block.Block
Writes a byte in the current position and increment current position by 1
putInt(int) - Method in class org.rostore.v2.media.block.Block
Writes an int in the current position and increment current position by 4
putKey(byte[], Record) - Method in class org.rostore.v2.container.ContainerShardKeyOperations
Create or update the provided key with the parameter from the provided record.
putLong(long) - Method in class org.rostore.v2.media.block.Block
Writes a long in the current position and increment current position by 8
putLong(long, int) - Method in class org.rostore.v2.media.block.Block
Writes a provided number of bytes from the provided long in the current position and increment current position by the provided number of bytes.
putValue(T) - Method in class org.rostore.v2.container.ContainerShard
Function to store the body of the value, using the shard's allocator

Q

queue(ContainerShardKeyOperations) - Method in class org.rostore.v2.container.async.ContainerShardCleanupManager
 
QuotaExceededException - Exception Class in org.rostore.entity
Exception is thrown by BlockAllocator when the request has to be rejected because the size that has to be allocated is greater than the allowed size of the underlying storage object, e.g.
QuotaExceededException(String) - Constructor for exception class org.rostore.entity.QuotaExceededException
 
QuotaExceededException(String, Throwable) - Constructor for exception class org.rostore.entity.QuotaExceededException
 

R

read() - Method in class org.rostore.v2.data.DataReader
 
READ - Enum constant in enum class org.rostore.entity.apikey.Permission
Permission to read value
READ - Enum constant in enum class org.rostore.v2.container.async.OperationType
 
readBlockIndex() - Method in class org.rostore.v2.media.block.Block
Reads a block index from the block at current position, and increment position with the size of block index.
readLength(InputStream) - Static method in class org.rostore.mapper.BinaryMapper
 
readObject(Class<T>) - Method in class org.rostore.v2.data.DataReader
Reads the java object from the data reader.
readObject(Media, long, Class<T>) - Static method in class org.rostore.v2.data.DataReader
 
readString(InputStream) - Static method in class org.rostore.mapper.BinaryMapper
 
rebalance() - Method in class org.rostore.v2.seq.BlockSequence
Because the sequences can be used in the allocators, it can't rely all the time on the external allocators, as they might use the same sequence as this one, which would lead to a concurrent operation caused by the allocator.
record(Record) - Method in interface org.rostore.v2.container.async.AsyncListener
 
Record - Class in org.rostore.entity
Record describes the payload associated with the key in the storage.
Record() - Constructor for class org.rostore.entity.Record
 
RecordLengths - Class in org.rostore.v2.keys
Defines the lengths of the key record components in bytes
RecordLengths(int, int, int) - Constructor for class org.rostore.v2.keys.RecordLengths
Initializes the record lengths manually
RecordOption - Enum Class in org.rostore.entity.media
Specify behaviour of the system when update or creation of key-value happens.
remove() - Method in class org.rostore.client.GeneralContainer
Removes container from rostore
remove() - Method in class org.rostore.client.MappedContainer
 
remove() - Method in class org.rostore.v2.container.async.AsyncContainer
 
remove() - Method in class org.rostore.v2.container.Container
 
remove() - Method in class org.rostore.v2.container.ContainerShard
Removes all the data associated with the shard
remove() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Removes current entry and collapses the space it used.
remove() - Method in class org.rostore.v2.keys.KeyBlockOperations
Function removes all the keys from the sequence and remove the sequence itself, freeing all the resources
remove() - Method in class org.rostore.v2.keys.VarSizeEntry
Removes the currently selected entry from the block
remove() - Method in class org.rostore.v2.media.block.allocator.BlockAllocator
Frees all the blocks managed by the allocator.
remove() - Method in interface org.rostore.v2.media.block.allocator.BlockAllocatorInternal
Remove all blocks managed by this block allocator
remove(byte[], Record) - Method in class org.rostore.v2.keys.KeyBlockOperations
Searches a key and removes the key if found.
remove(int) - Method in class org.rostore.v2.seq.BlockIndexSequence
 
remove(int, byte[], Record) - Method in class org.rostore.v2.container.async.AsyncContainer
Delete a key if one exists
remove(int, String) - Method in class org.rostore.v2.container.async.AsyncContainer
Delete a key if one exists
remove(int, String, Record) - Method in class org.rostore.v2.container.async.AsyncContainer
Delete a key if one exists
remove(long, long) - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
remove(long, long, boolean) - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Removes a set of blocks from the range - from the catalog.
remove(String) - Method in class org.rostore.v2.container.async.AsyncContainers
 
remove(String) - Method in class org.rostore.v2.container.ContainerListOperations
 
remove(String, Record) - Method in class org.rostore.service.apikey.ApiKeyManager
 
remove(CatalogBlockIndices) - Method in class org.rostore.v2.catalog.CatalogBlockIndices
Removes what is included in this catalog
remove(CatalogBlockIndices, boolean) - Method in class org.rostore.v2.catalog.CachedCatalogBlockOperations
remove(CatalogBlockIndices, boolean) - Method in class org.rostore.v2.catalog.CatalogBlockOperations
Removes a set of blocks from the catalog.
remove(BlockContainer) - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
 
remove(BlockContainer, long) - Method in class org.rostore.v2.media.block.MappedPhysicalBlocks
 
REMOVE_CONTAINER - Enum constant in enum class org.rostore.cli.Operation
 
REMOVE_KEY - Enum constant in enum class org.rostore.cli.Operation
 
removeAsync(int, byte[], Record) - Method in class org.rostore.v2.container.async.AsyncContainer
Delete a key if one exists
removeAtEnd(int) - Method in class org.rostore.v2.seq.BlockIndexSequence
 
removeFreeBlock(int) - Method in class org.rostore.v2.seq.BlockSequence
Operation marks the block with the given index as a free one, assuming previously it was used by the data.
removeIfExpired(int) - Method in class org.rostore.v2.keys.KeyBlockOperations
This function is to look up the expired entries and remove them
removeKey(byte[], Record) - Method in class org.rostore.v2.container.ContainerShardKeyOperations
Removes a key from the shard
removeKey(K) - Method in class org.rostore.client.MappedContainer
Remove a key from the storage
removeKey(K, long) - Method in class org.rostore.client.MappedContainer
Remove a key from the storage
removeKey(K, long, EnumSet<RecordOption>) - Method in class org.rostore.client.GeneralContainer
 
removeKey(K, long, EnumSet<RecordOption>) - Method in class org.rostore.client.MappedContainer
Remove a key from the storage
removeKeyIfExpired(int) - Method in class org.rostore.v2.container.ContainerShardKeyOperations
The operation is executed in the clean-up cycle.
removeListener(BlockAllocatorListener) - Method in class org.rostore.v2.media.block.allocator.BlockAllocatorListeners
Remove the listener, and stop receiving notifications
removeSecondaryBlockAllocator(BlockAllocator) - Method in class org.rostore.v2.media.Media
Call to this function will free all the blocks allocated in the secondary allocator.
removeValue(long) - Method in class org.rostore.v2.container.ContainerShard
Function to remove the value from the shard's allocator and free the blocks used by it
repairRoot() - Method in class org.rostore.service.ApiKeyService
 
repairRootApiKeyEntry() - Method in class org.rostore.service.apikey.ApiKeyManager
 
RequestFilter - Class in org.rostore.service
 
RequestFilter() - Constructor for class org.rostore.service.RequestFilter
 
RequestProperties - Class in org.rostore.client
This is a backbone class that contains all the data needed to execute a REST request against the remote rostore instance.
RequestProperties(RoStoreClientProperties) - Constructor for class org.rostore.client.RequestProperties
 
RestError - Class in org.rostore.service
 
restore() - Method in class org.rostore.v2.catalog.CatalogBlockEntryInstance
 
rethrowExceptionIfOccurred() - Method in class org.rostore.v2.container.async.Operation
 
root() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
Resets the currently selected block to the first block
root() - Method in class org.rostore.v2.seq.SequenceBlock
Moves the pointer to the root block in the sequence.
ROOT_ALLOCATOR_CACHE_MAX_SIZE - Static variable in class org.rostore.v2.media.block.allocator.Properties
The maximum number of blocks that is allocated in advance in the root allocator's cache
ROOT_ALLOCATOR_CACHE_MIN_SIZE - Static variable in class org.rostore.v2.media.block.allocator.Properties
The minimum number of blocks that is allocated in advance in the root allocator's cache
ROOT_ALLOCATOR_MIN_BUFFER - Static variable in class org.rostore.v2.media.block.allocator.Properties
The minimum number of blocks that the root allocator should maintain.
ROOT_ALLOCATOR_NAME - Static variable in class org.rostore.v2.media.block.allocator.Properties
Name of the root allocator
RootBlockAllocator - Class in org.rostore.v2.media.block.allocator
Major allocator for the Media.
RootBlockAllocator() - Constructor for class org.rostore.v2.media.block.allocator.RootBlockAllocator
 
RootClosableImpl - Class in org.rostore.v2.media
A basic class that has the status and can be closed.
RootClosableImpl() - Constructor for class org.rostore.v2.media.RootClosableImpl
 
RoStoreAccessor - Class in org.rostore.service
 
RoStoreAccessor() - Constructor for class org.rostore.service.RoStoreAccessor
 
RoStoreClient - Class in org.rostore.client
The major object to access the remote rostore service.
RoStoreClient(TrustManager[], RoStoreClientProperties) - Constructor for class org.rostore.client.RoStoreClient
Creates a new rostore client
RoStoreClient(RoStoreClientProperties) - Constructor for class org.rostore.client.RoStoreClient
 
RoStoreClientProperties - Class in org.rostore.client
Properties that define connection to the remote rostore service
RoStoreClientProperties(String, String) - Constructor for class org.rostore.client.RoStoreClientProperties
 
RoStoreException - Exception Class in org.rostore.entity
Base class for all exceptions generated by the RoStore core
RoStoreException(String) - Constructor for exception class org.rostore.entity.RoStoreException
Create a RoStore expection
RoStoreException(String, Throwable) - Constructor for exception class org.rostore.entity.RoStoreException
Creates a RiStore exception
RoStoreProperties - Class in org.rostore.entity.media
RoStore storage properties.
RoStoreProperties() - Constructor for class org.rostore.entity.media.RoStoreProperties
 
RoStorePropertiesLoader - Class in org.rostore.cli
 
RoStorePropertiesLoader() - Constructor for class org.rostore.cli.RoStorePropertiesLoader
 
RoStoreServiceException - Exception Class in org.rostore.service
 
RoStoreServiceException(Response.Status, String) - Constructor for exception class org.rostore.service.RoStoreServiceException
 
RoStoreServiceException(Response.Status, String, Throwable) - Constructor for exception class org.rostore.service.RoStoreServiceException
 
RoStoreState - Enum Class in org.rostore.service
 

S

safeReader(Media, long, Consumer<DataReader>) - Static method in class org.rostore.v2.data.DataReader
 
safeWriter(BlockAllocator, long, Consumer<DataWriter>) - Static method in class org.rostore.v2.data.DataWriter
Write the data from the unknown source to the storage in a safe mode.
safeWriter(BlockAllocator, Consumer<DataWriter>) - Static method in class org.rostore.v2.data.DataWriter
Write the data from the unknown source to the storage in a safe mode.
scheduleCleanup() - Method in class org.rostore.v2.container.async.CleanupManager
 
SECONDARY_ALLOCATOR_CACHE_MAX_SIZE - Static variable in class org.rostore.v2.media.block.allocator.Properties
The maximum number of blocks that is allocated in advance in the secondary allocator's cache
SECONDARY_ALLOCATOR_CACHE_MIN_SIZE - Static variable in class org.rostore.v2.media.block.allocator.Properties
The minimum number of blocks that is allocated in advance in the secondary allocator's cache.
SECONDARY_ALLOCATOR_MIN_BUFFER - Static variable in class org.rostore.v2.media.block.allocator.Properties
The minimum number of blocks that the secondary allocator should maintain.
SecondaryBlockAllocator - Class in org.rostore.v2.media.block.allocator
This class creates BlockAllocator that allows to control a set of blocks.
SecondaryBlockAllocator() - Constructor for class org.rostore.v2.media.block.allocator.SecondaryBlockAllocator
 
SequenceBlock - Class in org.rostore.v2.seq
Represents a block that is embedded in BlockSequence.
SequenceBlock(BlockSequence) - Constructor for class org.rostore.v2.seq.SequenceBlock
 
serialize(MapperProperties, T, OutputStream) - Static method in class org.rostore.mapper.BinaryMapper
 
serialize(MapperProperties, T, Type, OutputStream) - Static method in class org.rostore.mapper.BinaryMapper
 
setApiVersion(String) - Method in class org.rostore.entity.media.Version
 
setAsyncContainers(AsyncContainers) - Method in class org.rostore.v2.container.async.AsyncContainerMedia
 
setAutoCloseContainersAfterMillis(long) - Method in class org.rostore.entity.media.ContainerListProperties
 
setBlockSize(int) - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Sets the block size that will be used by the storage
setBlockSize(int) - Method in class org.rostore.v2.media.MediaHeader
setBlockType(BlockType) - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
 
setBytesPerBlockIndex(int) - Method in class org.rostore.mapper.MapperProperties
 
setBytesPerBlockOffset(int) - Method in class org.rostore.mapper.MapperProperties
 
setCleanupIntervalMillis(long) - Method in class org.rostore.entity.media.ContainerListProperties
 
setCloseUnusedBlocksAfterMillis(long) - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Sets the time interval in milliseconds after each the unused blocks will be removed from the memory.
setCloseUnusedBlocksAfterMillis(long) - Method in class org.rostore.v2.media.MediaHeader
setCloseUnusedSequencesAfterMillis(long) - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Sets the time interval in milliseconds after each the unused block sequences will be removed from the memory.
setCloseUnusedSequencesAfterMillis(long) - Method in class org.rostore.v2.media.MediaHeader
setConnectTimeout(Duration) - Method in class org.rostore.client.RoStoreClientProperties
 
setContainerListProperties(ContainerListProperties) - Method in class org.rostore.entity.media.RoStoreProperties
 
setContainerListProperties(ContainerListProperties) - Method in class org.rostore.v2.container.async.AsyncContainerMediaProperties
 
setContainerMeta(ContainerMeta) - Method in class org.rostore.v2.container.ContainerDescriptor
 
setContainerPermissions(String, Set<Permission>) - Method in class org.rostore.entity.apikey.ApiKeyPermissions
 
setContainerPermissions(Map<String, Set<Permission>>) - Method in class org.rostore.entity.apikey.ApiKeyPermissions
 
setCreationTime(long) - Method in class org.rostore.entity.media.ContainerMeta
 
setCreationTime(long) - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
setDirty() - Method in class org.rostore.v2.media.block.MappedPhysicalBlock
 
setEntrySize(int) - Method in class org.rostore.v2.keys.VarSizeEntry
Sets the size of the currently selected entry
setEntryStart(long) - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Sets the start block index in the current entry
setEntryStartStop(long, long) - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Sets both start and stop block indices in the current entry
setEntryStop(long) - Method in class org.rostore.v2.catalog.CatalogBlockEntry
Sets the stop block in the entry
setException(Exception) - Method in class org.rostore.v2.container.async.Operation
 
setFirstFreeIndex(int) - Method in class org.rostore.v2.seq.BlockIndexSequence
 
setKeyBlockIndex(long) - Method in class org.rostore.v2.keys.KeyBlockEntry
Sets the key block to the provided index
setKeyBlockOffset(long) - Method in class org.rostore.v2.keys.KeyBlockEntry
Sets offset of the key in the key block
setKeys(List<byte[]>) - Method in class org.rostore.v2.keys.KeyList
Sets the list of keys
setKeys(List<String>) - Method in class org.rostore.client.StringKeyList
 
setKeys(List<String>) - Method in class org.rostore.entity.StringKeyList
 
setKeyStartIndex(long) - Method in class org.rostore.v2.container.ContainerListHeader
Assigned at the media creation.
setMagic(byte) - Method in class org.rostore.v2.media.MediaHeader
Sets the magic byte to the header, which will be used for verification
setMaxCleanupsPerCycle(int) - Method in class org.rostore.entity.media.ContainerListProperties
 
setMaxConnectionsPerRoute(int) - Method in class org.rostore.client.RoStoreClientProperties
 
setMaxContainersListSize(long) - Method in class org.rostore.entity.media.ContainerListProperties
Sets the maximum size in bytes of all container names in the list
setMaxContainersPerList(int) - Method in class org.rostore.entity.media.ContainerListProperties
Sets the maximum number of containers in the storage.
setMaxKeyOperationsPerShard(int) - Method in class org.rostore.entity.media.ContainerListProperties
Sets the number of parallel operations per shard.
setMaxSize(long) - Method in class org.rostore.entity.media.ContainerMeta
Sets the maximum size of the container.
setMaxSize(long) - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
setMaxTotalConnections(int) - Method in class org.rostore.client.RoStoreClientProperties
 
setMaxTotalSize(long) - Method in class org.rostore.entity.media.MediaPropertiesBuilder
Sets the maximum total size of the storage
setMaxTotalSize(long) - Method in class org.rostore.v2.media.MediaHeader
setMaxTTL(long) - Method in class org.rostore.entity.media.ContainerMeta
Sets maximum TTL of the container key
setMaxTTL(long) - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
setMedia(Media) - Method in class org.rostore.v2.container.async.AsyncContainerMedia
 
setMediaProperties(MediaPropertiesBuilder) - Method in class org.rostore.entity.media.RoStoreProperties
 
setMediaProperties(MediaProperties) - Method in class org.rostore.v2.container.async.AsyncContainerMediaProperties
 
setMore(boolean) - Method in class org.rostore.client.StringKeyList
 
setMore(boolean) - Method in class org.rostore.entity.StringKeyList
 
setMore(boolean) - Method in class org.rostore.v2.keys.KeyList
Sets the more flag
setOffset(int) - Method in class org.rostore.v2.keys.VarSizeEntry
Sets the current offset within a block
setRecord(Record) - Method in class org.rostore.v2.keys.KeyBlockEntry
Put record to the current position / entry
setRequestTimeout(Duration) - Method in class org.rostore.client.RoStoreClientProperties
 
setSegmentNumber(int) - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
setShardNumber(int) - Method in class org.rostore.entity.media.ContainerMeta
Sets the number of shards the container will have.
setShardNumber(int) - Method in class org.rostore.entity.media.ContainerMetaCompatibility
 
setSize(long) - Method in class org.rostore.v2.keys.KeyList
Sets the size of all keys
setStorePermissions(Set<Permission>) - Method in class org.rostore.entity.apikey.ApiKeyPermissions
 
setUpdateRetries(int) - Method in class org.rostore.client.RoStoreClientProperties
 
setUpdateTimeoutMax(Duration) - Method in class org.rostore.client.RoStoreClientProperties
 
shutdown() - Method in class org.rostore.client.RoStoreClient
Stops the server
shutdown() - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
SHUTDOWN - Enum constant in enum class org.rostore.cli.Operation
 
shutdownAndWait() - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
shutdownIfHasTo() - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
shutdownStore() - Method in class org.rostore.service.StoreAdminService
 
SHUTTING_DOWN - Enum constant in enum class org.rostore.service.RoStoreState
 
size() - Method in class org.rostore.v2.media.block.container.BlockContainer
The number of blocks in the container
size() - Method in class org.rostore.v2.media.block.MappedPhysicalBlocks
The total size of passively cached blocks and the actively used that are currently managed by this instance.
size() - Method in class org.rostore.v2.seq.BlockIndexSequences
 
skip(int) - Method in class org.rostore.v2.media.block.Block
Moves current position by the provided number of bytes forward.
snapshot() - Method in class org.rostore.v2.media.block.allocator.BlockVerifierListener
 
split(Block) - Method in class org.rostore.v2.keys.VarSizeEntry
Splits the current block into two at the point of offset.
split(Block, byte[]) - Method in class org.rostore.v2.keys.VarSizeEntry
Splits the current block into two at the point of offset, adds the provided data at the beginning of the new block and move the rest from the original block afterwards.
standardRecordLengths(MediaProperties) - Static method in class org.rostore.v2.keys.RecordLengths
Initializes the record length with the standard
STARTED - Enum constant in enum class org.rostore.v2.container.async.AsyncStatus
 
STARTING - Enum constant in enum class org.rostore.service.RoStoreState
 
startTimestamp() - Method in class org.rostore.service.apikey.ApiKeyRequestContext
 
status(AsyncStatus) - Method in interface org.rostore.v2.container.async.AsyncListener
 
Status - Enum Class in org.rostore.v2.media.block.container
 
store(BlockAllocation) - Static method in class org.rostore.entity.BlockAllocationState
Creates a static copy of the provided BlockAllocation
StoreAdminService - Class in org.rostore.service
 
StoreAdminService() - Constructor for class org.rostore.service.StoreAdminService
 
storeSpace() - Method in class org.rostore.service.StoreAdminService
 
StreamProcessingException - Exception Class in org.rostore.entity
Used in async stream processing function
StreamProcessingException(Exception) - Constructor for exception class org.rostore.entity.StreamProcessingException
Creates an exception by wrapping another one
StringKeyList - Class in org.rostore.client
The class represents the result of key listing operation.
StringKeyList - Class in org.rostore.entity
 
StringKeyList() - Constructor for class org.rostore.client.StringKeyList
 
StringKeyList() - Constructor for class org.rostore.entity.StringKeyList
 
StringKeyList(KeyList) - Constructor for class org.rostore.entity.StringKeyList
 
SUCCESS - Enum constant in enum class org.rostore.v2.container.async.AsyncStatus
Finished successfully
SUPER - Enum constant in enum class org.rostore.entity.apikey.Permission
Permission to manage rostore instance in any form
sync(boolean) - Method in class org.rostore.v2.keys.KeyBlockEntry
Manages if the var size block should be initialized when the entry is selected
systemWide() - Static method in class org.rostore.cli.RoStorePropertiesLoader
 

T

throwExceptionIfInvalid(String) - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
 
throwExceptionIfInvalid(String) - Method in class org.rostore.v2.fixsize.ValidatingEntry
This should be executed if an unexpected operation is executed on the invalid entry
toHeaders(HttpServletResponse, Record) - Static method in class org.rostore.service.Headers
 
toHeaders(Response.ResponseBuilder, Record) - Static method in class org.rostore.service.Headers
 
toObject(InputStream, Class<V>, K) - Method in class org.rostore.client.mapper.JsonMapper
Deserialization function
toObject(InputStream, Class<V>, K) - Method in interface org.rostore.client.mapper.Mapper
Deserialization function
toObject(InputStream, Class<V>, K) - Method in class org.rostore.client.mapper.NativeMapper
Deserialization function
toOutputStream(Media, long, T) - Static method in class org.rostore.v2.data.DataReader
Reads the data from the sequence starting at start index and writes it to the output stream.
toResponse(Exception) - Method in class org.rostore.service.ErrorHandler
 
toString() - Method in class org.rostore.client.VersionedObject
 
toString() - Method in class org.rostore.entity.apikey.ApiKeyDefinition
 
toString() - Method in class org.rostore.entity.apikey.ApiKeyPermissions
 
toString() - Method in class org.rostore.entity.BlockAllocationState
 
toString() - Method in class org.rostore.v2.catalog.CatalogBlockEntryInstance
 
toString() - Method in class org.rostore.v2.catalog.CatalogBlockIndices
 
toString() - Method in class org.rostore.v2.container.async.Operation
 
toString() - Method in class org.rostore.v2.container.ContainerShard
 
toString() - Method in class org.rostore.v2.fixsize.FixSizeEntry
Provides an explicit string representation of the entry location
toString() - Method in class org.rostore.v2.fixsize.FixSizeEntryBlock
 
toString() - Method in class org.rostore.v2.fixsize.ValidatingEntry
 
toString() - Method in class org.rostore.v2.keys.KeyBlockEntry
 
toString() - Method in class org.rostore.v2.keys.VarSizeBlock
 
toString() - Method in class org.rostore.v2.keys.VarSizeEntry
 
toString() - Method in class org.rostore.v2.keys.VarSizeMultiBlock
 
toString() - Method in class org.rostore.v2.media.block.Block
 
toString(K) - Method in class org.rostore.client.DefaultKeySerializer
 
toString(K) - Method in interface org.rostore.client.KeySerializer
Transforms the key object to the string
TRACKING_ID_HEADER - Static variable in class org.rostore.service.Headers
 
trackingId() - Method in class org.rostore.client.RequestProperties
 
trackingId(String) - Method in class org.rostore.client.RequestProperties
 
trimByBytes(long, int) - Static method in class org.rostore.Utils
 
ttl(long) - Method in class org.rostore.entity.Record
 
TTL_EXPIRED - Static variable in class org.rostore.Utils
 
TTL_FOREVER - Static variable in class org.rostore.Utils
 
TTL_HEADER - Static variable in class org.rostore.service.Headers
 
ttl2eol(long) - Static method in class org.rostore.Utils
Converts the time-to-live to end-of-live time
ttl2unixEol(long) - Static method in class org.rostore.Utils
 
ttlOrUnitEol(Long, Long) - Method in class org.rostore.entity.Record
Creates a record based on ttl or unixEol provided.

U

unixEol(Long) - Method in class org.rostore.client.RequestProperties
 
unixEol(VersionedObject<K, V>) - Method in interface org.rostore.client.KeyExpirationUpdateFunction
 
unixEol2eol(long) - Static method in class org.rostore.Utils
 
unwind() - Method in class org.rostore.v2.data.DataWriter
This should be called if operation has been aborted and must be set back.
update(VersionedObject<K, V>, Function<V, V>) - Method in class org.rostore.client.MappedContainer
Updates a versioned key-value pair.
update(VersionedObject<K, V>, Function<V, V>, Function<V, InputStream>, Function<InputStream, V>) - Method in class org.rostore.client.GeneralContainer
Updates the given entity
update(VersionedObject<K, V>, Function<V, V>, KeyExpirationUpdateFunction) - Method in class org.rostore.client.MappedContainer
Updates a versioned key-value pair.
update(VersionedObject<K, V>, KeyExpirationUpdateFunction, Function<V, V>, Function<V, InputStream>, Function<InputStream, V>) - Method in class org.rostore.client.GeneralContainer
Updates the given entity
update(ApiKeyDefinition, Record) - Method in class org.rostore.service.apikey.ApiKeyManager
 
updateApiKey(String, String, Long, Long, Long, ApiKeyPermissions) - Method in class org.rostore.service.ApiKeyService
 
userProfile(String, boolean) - Static method in class org.rostore.cli.RoStorePropertiesLoader
 
UTF_8 - Static variable in class org.rostore.Utils
 
Utils - Class in org.rostore
General functions and constants used in rostore modules.
Utils() - Constructor for class org.rostore.Utils
 

V

valid() - Method in class org.rostore.v2.catalog.CatalogBlockEntryInstance
 
valid() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Checks if current entry has been marked as valid.
valid() - Method in class org.rostore.v2.keys.VarSizeBlock
 
valid() - Method in class org.rostore.v2.seq.SequenceBlock
Checks if the pointer points to valid block
validate() - Method in class org.rostore.v2.fixsize.ValidatingEntry
Checks if the current index is valid (the index should be strictly below the ValidatingEntry.getEntriesNumber() and if it is not correct, marks this entry as invalid.
ValidatingEntry - Class in org.rostore.v2.fixsize
An entry of the block that validates the index to be valid.
ValidatingEntry() - Constructor for class org.rostore.v2.fixsize.ValidatingEntry
 
value(int, OperationType, long, Supplier<R>) - Static method in class org.rostore.v2.container.async.Operation
 
VALUE - Enum constant in enum class org.rostore.v2.container.async.OperationTarget
 
valueOf(String) - Static method in enum class org.rostore.cli.Operation
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.client.ContentType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.entity.apikey.Permission
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.entity.media.RecordOption
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.service.RoStoreState
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.v2.container.async.AsyncStatus
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.v2.container.async.KeyExecutionState
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.v2.container.async.OperationTarget
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.v2.container.async.OperationType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.v2.media.block.BlockType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.rostore.v2.media.block.container.Status
Returns the enum constant of this class with the specified name.
values() - Static method in enum class org.rostore.cli.Operation
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.client.ContentType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.entity.apikey.Permission
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.entity.media.RecordOption
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.service.RoStoreState
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.v2.container.async.AsyncStatus
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.v2.container.async.KeyExecutionState
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.v2.container.async.OperationTarget
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.v2.container.async.OperationType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.v2.media.block.BlockType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.rostore.v2.media.block.container.Status
Returns an array containing the constants of this enum class, in the order they are declared.
VarSizeBlock - Class in org.rostore.v2.keys
This class refer the sequence of entries of variable size, that are stored in the memory blocks.
VarSizeBlock(BlockProvider) - Constructor for class org.rostore.v2.keys.VarSizeBlock
 
VarSizeEntry - Class in org.rostore.v2.keys
Manages several variable-sized entries in one block.
VarSizeEntry(VarSizeBlock) - Constructor for class org.rostore.v2.keys.VarSizeEntry
Creates the instance of entry
VarSizeMultiBlock - Class in org.rostore.v2.keys
This class is used when the key data exceeds the size of block.
VarSizeMultiBlock(VarSizeBlock) - Constructor for class org.rostore.v2.keys.VarSizeMultiBlock
Creates a multi block
version() - Method in class org.rostore.client.RequestProperties
 
version() - Method in class org.rostore.service.StoreAdminService
 
version(long) - Method in class org.rostore.entity.Record
Sets a version to the record
version(Long) - Method in class org.rostore.client.RequestProperties
 
Version - Class in org.rostore.entity.media
Represents information about the version of the rostore instance.
Version() - Constructor for class org.rostore.entity.media.Version
 
Version(String) - Constructor for class org.rostore.entity.media.Version
 
VERSION_HEADER - Static variable in class org.rostore.service.Headers
 
VERSION_START - Static variable in class org.rostore.Utils
 
VERSION_UNDEFINED - Static variable in class org.rostore.Utils
 
VersionConflictException - Exception Class in org.rostore.client
Exception is thrown on post/put when the version in e input is not as expected by the server.
VersionConflictException(String, RequestProperties) - Constructor for exception class org.rostore.client.VersionConflictException
 
VersionedObject<K,V> - Class in org.rostore.client
Versioned object, containing the object itself, and metadata: ttl information and version
VersionMismatchException - Exception Class in org.rostore.entity
Exception thrown when the version of the record in the store is not the one as requested.
VersionMismatchInitException - Exception Class in org.rostore.entity
Thrown when the version of the entry is set incorrectly on the entry initialization.

W

waitForShutdown() - Method in class org.rostore.v2.container.async.AsyncContainer
 
waitForShutdown() - Method in class org.rostore.v2.container.async.ContainerShardExecutor
 
wrap(BlockAllocatorInternal) - Static method in class org.rostore.v2.media.block.allocator.BlockAllocator
Wraps BlockAllocatorInternal to create an allocator.
wrap(S) - Static method in class org.rostore.v2.container.async.AsyncStream
 
wrap(S, AsyncListener) - Static method in class org.rostore.v2.container.async.AsyncStream
 
wrapBlocking(S) - Static method in class org.rostore.v2.container.async.AsyncStream
 
wrapBlocking(S, AsyncListener) - Static method in class org.rostore.v2.container.async.AsyncStream
 
WrappedClientException - Exception Class in org.rostore.client
 
WrappedClientException(String, Exception) - Constructor for exception class org.rostore.client.WrappedClientException
 
write(byte[]) - Method in class org.rostore.v2.data.DataWriter
 
write(int) - Method in class org.rostore.v2.data.DataWriter
Writes one byte of the data
write(OutputStream, String) - Static method in class org.rostore.mapper.BinaryMapper
 
WRITE - Enum constant in enum class org.rostore.entity.apikey.Permission
Permission to write data to the container or storage
WRITE - Enum constant in enum class org.rostore.v2.container.async.OperationType
 
writeBlockIndex(long) - Method in class org.rostore.v2.media.block.Block
Writes a block index to the block at current position, and increment position with the size of block index.
writeLength(OutputStream, int) - Static method in class org.rostore.mapper.BinaryMapper
 
writeObject(BlockAllocator, T) - Static method in class org.rostore.v2.data.DataWriter
Writes the serialized java object to the store in the safe manner.
writeObject(T) - Method in class org.rostore.v2.data.DataWriter
Writes a java object to the storage
A B C D E F G H I J K L M N O P Q R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form