Index

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

A

absorb(KeyWatchTracker) - Method in class io.permazen.kv.util.KeyWatchTracker
Absorb all of the watches from the given instance into this one.
AbstractCachingConfig - Class in io.permazen.kv.caching
Support superclass for CachingConfig implementations.
AbstractCachingConfig() - Constructor for class io.permazen.kv.caching.AbstractCachingConfig
Constructor.
AbstractCommand - Class in io.permazen.cli.cmd
Support superclass for CLI Command implementations.
AbstractCommand(String) - Constructor for class io.permazen.cli.cmd.AbstractCommand
Constructor.
AbstractCoreIndex<T> - Class in io.permazen.core
Support superclass for the various core index classes.
AbstractEncoding<T> - Class in io.permazen.encoding
Support superclass for Encoding implementations.
AbstractEncoding(TypeToken<T>) - Constructor for class io.permazen.encoding.AbstractEncoding
Constructor for anonymous encodings with no default value.
AbstractEncoding(EncodingId, TypeToken<T>, Supplier<? extends T>) - Constructor for class io.permazen.encoding.AbstractEncoding
Constructor.
AbstractEncoding(EncodingId, Class<T>, Supplier<? extends T>) - Constructor for class io.permazen.encoding.AbstractEncoding
Constructor.
AbstractEncoding(Class<T>) - Constructor for class io.permazen.encoding.AbstractEncoding
Constructor for anonymous encodings with no default value.
AbstractEnumSchemaField - Class in io.permazen.schema
Superclass of SimpleSchemaField types involving EnumValues representing Enum types.
AbstractEnumSchemaField() - Constructor for class io.permazen.schema.AbstractEnumSchemaField
 
AbstractIterationSet<E> - Class in io.permazen.util
Support superclass for Set implementations based on database entries.
AbstractIterationSet() - Constructor for class io.permazen.util.AbstractIterationSet
 
AbstractKVCommand - Class in io.permazen.cli.cmd
 
AbstractKVCommand(String) - Constructor for class io.permazen.cli.cmd.AbstractKVCommand
 
AbstractKVCommand.BytesParser - Class in io.permazen.cli.cmd
Parses a byte[] array as hexadecimal or doubly-quoted "C" style string.
AbstractKVCommand.KVAction - Interface in io.permazen.cli.cmd
 
AbstractKVIterator<E> - Class in io.permazen.kv.util
Iterator implementation whose values derive from key/value byte[] pairs in a KVStore.
AbstractKVIterator(KVStore, boolean, boolean) - Constructor for class io.permazen.kv.util.AbstractKVIterator
Convenience constructor for when there are no range restrictions.
AbstractKVIterator(KVStore, boolean, boolean, byte[]) - Constructor for class io.permazen.kv.util.AbstractKVIterator
Convenience constructor for when the range of visible KVStore keys is all keys sharing a given byte[] prefix.
AbstractKVIterator(KVStore, boolean, boolean, KeyRange, KeyFilter) - Constructor for class io.permazen.kv.util.AbstractKVIterator
Primary constructor.
AbstractKVNavigableMap<K,V> - Class in io.permazen.kv.util
NavigableMap support superclass for maps backed by keys and values encoded as byte[] arrays in a KVStore, and whose key sort order is consistent with the byte[] key encoding.
AbstractKVNavigableMap(KVStore, boolean) - Constructor for class io.permazen.kv.util.AbstractKVNavigableMap
Convenience constructor for when there are no range restrictions.
AbstractKVNavigableMap(KVStore, boolean, boolean, KeyRange, KeyFilter, Bounds<K>) - Constructor for class io.permazen.kv.util.AbstractKVNavigableMap
Internal constructor.
AbstractKVNavigableMap(KVStore, boolean, byte[]) - Constructor for class io.permazen.kv.util.AbstractKVNavigableMap
Convenience constructor for when the range of visible KVStore keys is all keys sharing a given byte[] prefix.
AbstractKVNavigableMap(KVStore, boolean, KeyRange) - Constructor for class io.permazen.kv.util.AbstractKVNavigableMap
Primary constructor.
AbstractKVNavigableSet<E> - Class in io.permazen.kv.util
NavigableSet support superclass for sets backed by elements encoded as byte[] keys in a KVStore and whose sort order is consistent with their byte[] key encoding.
AbstractKVNavigableSet(KVStore, boolean) - Constructor for class io.permazen.kv.util.AbstractKVNavigableSet
Convenience constructor for when there are no range restrictions.
AbstractKVNavigableSet(KVStore, boolean, boolean, KeyRange, KeyFilter, Bounds<E>) - Constructor for class io.permazen.kv.util.AbstractKVNavigableSet
Internal constructor.
AbstractKVNavigableSet(KVStore, boolean, byte[]) - Constructor for class io.permazen.kv.util.AbstractKVNavigableSet
Convenience constructor for when the range of visible KVStore keys is all keys sharing a given byte[] prefix.
AbstractKVNavigableSet(KVStore, boolean, KeyRange) - Constructor for class io.permazen.kv.util.AbstractKVNavigableSet
Primary constructor.
AbstractKVStore - Class in io.permazen.kv
Support superclass for KVStore implementations.
AbstractKVStore() - Constructor for class io.permazen.kv.AbstractKVStore
 
AbstractNavigableMap<K,V> - Class in io.permazen.util
Support superclass for NavigableMap implementations based on database entries.
AbstractNavigableMap() - Constructor for class io.permazen.util.AbstractNavigableMap
Convenience constructor for the case where there are no lower or upper key bounds.
AbstractNavigableMap(Bounds<K>) - Constructor for class io.permazen.util.AbstractNavigableMap
Primary constructor.
AbstractNavigableSet<E> - Class in io.permazen.util
Support superclass for NavigableSet implementations based on database entries.
AbstractNavigableSet() - Constructor for class io.permazen.util.AbstractNavigableSet
Convenience constructor for the case where there are no lower or upper bounds.
AbstractNavigableSet(Bounds<E>) - Constructor for class io.permazen.util.AbstractNavigableSet
Primary constructor.
AbstractRaftCommand - Class in io.permazen.kv.raft.cmd
 
AbstractRaftCommand(String) - Constructor for class io.permazen.kv.raft.cmd.AbstractRaftCommand
 
AbstractRaftCommand.RaftAction - Class in io.permazen.kv.raft.cmd
 
AbstractTransactionRaftCommand - Class in io.permazen.kv.raft.cmd
 
AbstractTransactionRaftCommand(String) - Constructor for class io.permazen.kv.raft.cmd.AbstractTransactionRaftCommand
 
AbstractTransactionRaftCommand.RaftTransactionAction - Class in io.permazen.kv.raft.cmd
 
AbstractXMLStreaming - Class in io.permazen.util
Support superclass for classes that serialize and deserialize via XML.
AbstractXMLStreaming() - Constructor for class io.permazen.util.AbstractXMLStreaming
 
ACCESSED_UNREADABLE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Read or wrote an unreadable key.
add(double) - Method in class io.permazen.util.MovingAverage
Add a value to the moving average.
add(int, E) - Method in class io.permazen.util.ConvertedList
 
add(E) - Method in class io.permazen.util.ConvertedNavigableSet
 
add(E) - Method in class io.permazen.util.ConvertedSet
 
add(ObjId) - Method in interface io.permazen.core.util.ObjIdQueue
Add an ObjId to this queue.
add(ObjId) - Method in class io.permazen.core.util.ObjIdSet
 
add(ObjId, ObjId) - Method in class io.permazen.core.util.ObjIdBiMultiMap
Add an association.
add(Encoding<?>) - Method in class io.permazen.encoding.SimpleEncodingRegistry
Add a new Encoding to this registry.
add(KeyRange) - Method in class io.permazen.kv.KeyRanges
Add all the keys in the given KeyRange to this instance.
add(KeyRanges) - Method in class io.permazen.kv.KeyRanges
Add all the key ranges in the given KeyRanges to this instance.
add(Object, Closeable) - Method in class io.permazen.util.CloseableTracker
Add an item to the set of items being tracked by this instance.
add(String) - Method in class io.permazen.util.Diffs
Add a difference without any sub-differences.
add(String, Diffs) - Method in class io.permazen.util.Diffs
Add a difference with optional sub-differences.
addAll(int, Collection<? extends E>) - Method in class io.permazen.util.ConvertedList
 
addAll(ObjId, Iterable<? extends ObjId>) - Method in class io.permazen.core.util.ObjIdBiMultiMap
Add multiple associations with a given source.
addAtomicKVStores(File, List<AtomicKVStore>) - Method in class io.permazen.kv.test.AtomicKVStoreTest
 
addBuiltinEncodings() - Method in class io.permazen.encoding.DefaultEncodingRegistry
Register Permazen's built-in encodings.
addCallback(Transaction.Callback) - Method in class io.permazen.core.DetachedTransaction
Register a transaction callback to be invoked when this transaction completes.
addCallback(Transaction.Callback) - Method in class io.permazen.core.Transaction
Register a transaction Transaction.Callback to be invoked when this transaction completes.
addCompletion(String) - Method in exception io.permazen.util.ParseException
 
addCompletions(Iterable<String>) - Method in exception io.permazen.util.ParseException
 
addCompletions(String...) - Method in exception io.permazen.util.ParseException
 
addCompletions(Stream<String>) - Method in exception io.permazen.util.ParseException
 
addCoreApiOptions(OptionParser) - Method in class io.permazen.cli.config.CoreApiCliConfig
Add Core API layer command line flags to the given option parser.
addCreateListener(int, CreateListener) - Method in class io.permazen.core.Transaction
Add a CreateListener to this transaction.
addDeleteListener(int[], KeyRanges[], DeleteListener) - Method in class io.permazen.core.Transaction
Add a DeleteListener to this transaction.
addFieldChangeListener(int, int[], KeyRanges[], Object) - Method in class io.permazen.core.Transaction
Monitor for changes within this transaction to the specified Field as seen through a path of references.
addFile(File) - Method in class io.permazen.util.ApplicationClassLoader
Append the specified file to the search classpath.
addGenericOptions(OptionParser) - Method in class io.permazen.cli.config.CliConfig
Add generic command line flags to the given option parser.
addJdbcUriOption(OptionParser) - Method in class io.permazen.kv.cockroach.CockroachKVImplementation
 
addJdbcUriOption(OptionParser) - Method in class io.permazen.kv.mssql.MSSQLKVImplementation
 
addJdbcUriOption(OptionParser) - Method in class io.permazen.kv.mysql.MySQLKVImplementation
 
addJdbcUriOption(OptionParser) - Method in class io.permazen.kv.sql.SQLDriverKVImplementation
 
addJdbcUriOption(OptionParser, String, String) - Method in class io.permazen.kv.sql.SQLDriverKVImplementation
 
addKeyValueImplementationOptions(OptionParser) - Method in class io.permazen.cli.config.KeyValueCliConfig
Add key/value database implementation command line options.
addListFieldChangeListener(int, int[], KeyRanges[], ListFieldChangeListener) - Method in class io.permazen.core.Transaction
Monitor for changes within this transaction to the specified ListField as seen through a path of references.
addMapFieldChangeListener(int, int[], KeyRanges[], MapFieldChangeListener) - Method in class io.permazen.core.Transaction
Monitor for changes within this transaction to the specified MapField as seen through a path of references.
addNullSafe(EncodingId, Encoding<T>) - Method in class io.permazen.encoding.SimpleEncodingRegistry
Add a null-safe version of the given non-null supporting Encoding to this registry.
addOldSchemas(FileSet) - Method in class io.permazen.ant.SchemaGeneratorTask
 
addOptionalBuiltinEncoding(String, Function<EncodingId, ? extends Encoding<?>>) - Method in class io.permazen.encoding.DefaultEncodingRegistry
Register a built-in encoding, but only if its target class is found on the classpath.
addOptionalBuiltinEncodings() - Method in class io.permazen.encoding.DefaultEncodingRegistry
Register Permazen's optional built-in encodings.
addOptions(OptionParser) - Method in class io.permazen.cli.config.CliConfig
Configure an OptionParser with the comand line flags supported by this instance.
addOptions(OptionParser) - Method in class io.permazen.cli.config.CoreApiCliConfig
Configure an OptionParser with the comand line flags supported by this instance.
addOptions(OptionParser) - Method in class io.permazen.cli.config.KeyValueCliConfig
Configure an OptionParser with the comand line flags supported by this instance.
addOptions(OptionParser) - Method in class io.permazen.cli.config.PermazenCliConfig
 
addOptions(OptionParser) - Method in class io.permazen.kv.array.ArrayKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.bdb.BerkeleyKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.fdb.FoundationKVImplementation
 
addOptions(OptionParser) - Method in interface io.permazen.kv.KVImplementation
Add implementation-specific command line options.
addOptions(OptionParser) - Method in class io.permazen.kv.leveldb.LevelDBKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.lmdb.LMDBKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.mvstore.MVStoreKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.raft.RaftKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.simple.MemoryKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.simple.SimpleKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.simple.XMLKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.spanner.SpannerKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.sql.SQLDriverKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.sqlite.SQLiteKVImplementation
 
addOptions(OptionParser) - Method in class io.permazen.kv.xodus.XodusKVImplementation
 
addPermazenCommand(Command) - Method in class io.permazen.cli.cmd.Bundle
 
addPermazenOptions(OptionParser) - Method in class io.permazen.cli.config.PermazenCliConfig
Add Permazen layer command line flags to the given option parser.
ADDRESS_IN_USE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Local address in use.
addSchema(SchemaModel) - Method in class io.permazen.core.Transaction
Manually record the given non-empty schema in the database.
addSchemaChangeListener(int, SchemaChangeListener) - Method in class io.permazen.core.Transaction
Add a SchemaChangeListener to this transaction that listens for schema migrations of the specified object type.
addSessionModeOption(OptionParser) - Method in class io.permazen.cli.config.CoreApiCliConfig
Add the --session-mode command line option.
addSetFieldChangeListener(int, int[], KeyRanges[], SetFieldChangeListener) - Method in class io.permazen.core.Transaction
Monitor for changes within this transaction to the specified SetField as seen through a path of references.
addSimpleFieldChangeListener(int, int[], KeyRanges[], SimpleFieldChangeListener) - Method in class io.permazen.core.Transaction
Monitor for changes within this transaction of the value of the given field, as seen through a path of references.
addSimpleOptions(OptionParser, OptionSpec<?>, String) - Method in class io.permazen.kv.simple.XMLKVImplementation
 
addStandardBuiltinEncodings() - Method in class io.permazen.encoding.DefaultEncodingRegistry
Register Permazen's standard built-in encodings.
addURL(URL) - Method in class io.permazen.util.ApplicationClassLoader
adjust(long) - Method in class io.permazen.Counter
Adjust this counter's value by the specified amount.
adjustCounter(byte[], long) - Method in class io.permazen.kv.AbstractKVStore
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.caching.CachingKVTransaction
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.fdb.FoundationKVStore
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
adjustCounter(byte[], long) - Method in interface io.permazen.kv.KVStore
Adjust the counter at the given key by the given amount.
adjustCounter(byte[], long) - Method in class io.permazen.kv.leveldb.SnapshotLevelDBKVStore
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.mvcc.AtomicKVDatabase
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.mvcc.MutableView
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.raft.RaftKVTransaction
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.util.ForwardingKVStore
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.util.PrefixKVStore
 
adjustCounter(byte[], long) - Method in class io.permazen.kv.util.UnmodifiableKVStore
 
adjustCounterField(ObjId, String, long, boolean) - Method in class io.permazen.core.Transaction
Adjust the value of a CounterField in an object by some amount, optionally updating the object's schema.
afterCommit() - Method in interface io.permazen.core.Transaction.Callback
Invoked after successful transaction commit (and before afterCompletion()).
afterCommit() - Method in class io.permazen.core.Transaction.CallbackAdapter
 
afterCommit() - Method in class io.permazen.spring.PermazenTransactionManager.TransactionSynchronizationCallback
 
afterCompletion(boolean) - Method in interface io.permazen.core.Transaction.Callback
Invoked after transaction completion (but after any Transaction.Callback.afterCommit()).
afterCompletion(boolean) - Method in class io.permazen.core.Transaction.CallbackAdapter
 
afterCompletion(boolean) - Method in class io.permazen.spring.PermazenTransactionManager.TransactionSynchronizationCallback
 
afterPropertiesSet() - Method in class io.permazen.spring.PermazenTransactionManager
 
aliasForId(EncodingId) - Method in class io.permazen.encoding.DefaultEncodingRegistry
 
aliasForId(EncodingId) - Static method in class io.permazen.encoding.EncodingIds
Get the alias (or "nickname") for the given encoding ID in this registry, if any, for a Permazen built-in encoding.
aliasForId(EncodingId) - Method in interface io.permazen.encoding.EncodingRegistry
Get the alias (or "nickname") for the given encoding ID in this registry, if any.
ALL_ALTERNATIVES_FAILED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
All alternatives failed.
ALLOW_DELETED_ATTRIBUTE - Static variable in class io.permazen.schema.XMLConstants
 
allowBothTransactionsToFail() - Method in class io.permazen.kv.test.KVDatabaseTest
 
allowDeleted() - Element in annotation interface io.permazen.annotation.PermazenField
Allow the field to reference non-existent objects in normal transactions.
allowNewSchema(boolean) - Method in class io.permazen.core.TransactionConfig.Builder
Configure whether, if the configured schema is not already registered in the database when new transactions are created, it is allowed to register it.
allowsWriteSkewAnomaly() - Method in class io.permazen.kv.test.KVDatabaseTest
 
ALWAYS - Enum constant in enum class io.permazen.core.TransactionConfig.SchemaRemoval
Perform automatic schema removal at the start of every transaction.
AnnotatedClassScanner - Class in io.permazen.spring
Scans the classpath for classes having one or more configured type annotations.
AnnotatedClassScanner(ClassLoader, boolean, Environment, Class<?>...) - Constructor for class io.permazen.spring.AnnotatedClassScanner
Constructor.
AnnotatedClassScanner(ClassLoader, Class<?>...) - Constructor for class io.permazen.spring.AnnotatedClassScanner
Constructor.
API_VERSION - Static variable in class io.permazen.kv.fdb.FoundationKVDatabase
The API version used by this class.
API_VERSION_ALREADY_SET - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
API version may be set only once.
API_VERSION_INVALID - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
API version not valid.
API_VERSION_NOT_SUPPORTED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
API version not supported.
API_VERSION_UNSET - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
API version is not set.
AppendRequest - Class in io.permazen.kv.raft.msg
Sent from leaders to followers to probe the follower's log state and/or append an entry to their log.
AppendRequest(int, String, String, long, Timestamp, Timestamp, long, long, long) - Constructor for class io.permazen.kv.raft.msg.AppendRequest
Constructor for a "probe" that does not contain a log entry.
AppendRequest(int, String, String, long, Timestamp, Timestamp, long, long, long, long, ByteBuffer) - Constructor for class io.permazen.kv.raft.msg.AppendRequest
Constructor for a request that contains an actual log entry.
AppendResponse - Class in io.permazen.kv.raft.msg
Sent from a follower to a leader in response to an AppendRequest.
AppendResponse(int, String, String, long, Timestamp, boolean, long, long) - Constructor for class io.permazen.kv.raft.msg.AppendResponse
Constructor.
ApplicationClassLoader - Class in io.permazen.util
An URLClassLoader whose classpath can be modified at runtime.
apply() - Method in class io.permazen.change.Change
Apply this change to the transaction associated with the current thread.
apply(KVStore) - Method in class io.permazen.jsck.Issue
Apply the fix for this issue to the given KVStore.
apply(Mutations) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
apply(Mutations) - Method in class io.permazen.kv.caching.CachingKVTransaction
 
apply(Mutations) - Method in interface io.permazen.kv.KVStore
Apply all the given Mutations to this instance.
apply(Mutations) - Method in interface io.permazen.kv.mvcc.AtomicKVStore
Apply all the given Mutations to this instance.
apply(Mutations) - Method in class io.permazen.kv.mvcc.MutableView
 
apply(Mutations) - Method in class io.permazen.kv.raft.RaftKVTransaction
 
apply(Mutations) - Method in class io.permazen.kv.sql.SQLKVTransaction
 
apply(Mutations) - Method in class io.permazen.kv.util.ForwardingKVStore
 
apply(Mutations, boolean) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
apply(Mutations, boolean) - Method in class io.permazen.kv.leveldb.LevelDBAtomicKVStore
 
apply(Mutations, boolean) - Method in class io.permazen.kv.mvcc.AtomicKVDatabase
 
apply(Mutations, boolean) - Method in interface io.permazen.kv.mvcc.AtomicKVStore
Apply a set of mutations to this instance atomically.
apply(Mutations, boolean) - Method in class io.permazen.kv.mvcc.MemoryAtomicKVStore
 
apply(Mutations, boolean) - Method in class io.permazen.kv.mvstore.MVStoreAtomicKVStore
 
apply(Mutations, KVStore) - Static method in class io.permazen.kv.mvcc.Writes
apply(PermazenObject) - Method in class io.permazen.change.Change
Apply this change to the specified object.
apply(PermazenTransaction) - Method in class io.permazen.change.Change
Apply this change to the object associated with this instance in the given transaction.
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.Change
Apply this change to the given object in the given transaction.
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.ListFieldAdd
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.ListFieldClear
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.ListFieldRemove
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.ListFieldReplace
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.MapFieldAdd
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.MapFieldClear
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.MapFieldRemove
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.MapFieldReplace
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.ObjectCreate
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.ObjectDelete
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.SetFieldAdd
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.SetFieldClear
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.SetFieldRemove
 
apply(PermazenTransaction, PermazenObject) - Method in class io.permazen.change.SimpleFieldChange
 
apply(Environment) - Method in enum class io.permazen.kv.xodus.TransactionType
 
applySimpleOptions(OptionSet, XMLKVImplementation.Config) - Method in class io.permazen.kv.simple.XMLKVImplementation
 
applyTo(KVStore) - Method in class io.permazen.kv.mvcc.Writes
Apply all mutations contained in this instance to the given KVStore.
applyWritesBeforeCommitIfNotReadOnly(Writes) - Method in class io.permazen.kv.caching.CachingKVTransaction
Apply accumulated mutations just prior to commit()'ing the transaction.
ARRAY_SUFFIX - Static variable in class io.permazen.encoding.EncodingId
Encoding ID array suffix.
ArrayEncoding<T,E> - Class in io.permazen.encoding
Support superclass for non-null built-in array Encodings.
ArrayEncoding(Encoding<E>, TypeToken<T>) - Constructor for class io.permazen.encoding.ArrayEncoding
Constructor.
ArrayKVDatabase - Class in io.permazen.kv.array
KVDatabase implementation based on a AtomicArrayKVStore, providing concurrent transactions and linearizable ACID semantics.
ArrayKVDatabase() - Constructor for class io.permazen.kv.array.ArrayKVDatabase
 
ArrayKVException - Exception in io.permazen.kv.array
Superclass of all unchecked exceptions thrown by a ArrayKVStore.
ArrayKVException() - Constructor for exception io.permazen.kv.array.ArrayKVException
 
ArrayKVException(String) - Constructor for exception io.permazen.kv.array.ArrayKVException
 
ArrayKVException(String, Throwable) - Constructor for exception io.permazen.kv.array.ArrayKVException
 
ArrayKVException(Throwable) - Constructor for exception io.permazen.kv.array.ArrayKVException
 
ArrayKVImplementation - Class in io.permazen.kv.array
 
ArrayKVImplementation() - Constructor for class io.permazen.kv.array.ArrayKVImplementation
 
ArrayKVStore - Class in io.permazen.kv.array
A simple read-only KVStore based on a sorted array of key/value pairs.
ArrayKVStore(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class io.permazen.kv.array.ArrayKVStore
Constructor.
ArrayKVTransaction - Class in io.permazen.kv.array
ArrayKVDatabase transaction.
ArrayKVWriter - Class in io.permazen.kv.array
Writes ArrayKVStore index, key, and value data, given a sorted sequence of key/value pairs.
ArrayKVWriter(OutputStream, OutputStream, OutputStream) - Constructor for class io.permazen.kv.array.ArrayKVWriter
Constructor.
asIndex1() - Method in class io.permazen.core.CoreIndex2
 
asIndex1() - Method in class io.permazen.core.CoreIndex3
 
asIndex1() - Method in class io.permazen.core.CoreIndex4
 
asIndex1() - Method in interface io.permazen.index.Index2
Get the prefix of this instance that only includes the first two indexed fields.
asIndex1() - Method in interface io.permazen.index.Index3
Get the prefix of this instance that only includes the first two indexed fields.
asIndex1() - Method in interface io.permazen.index.Index4
Get the prefix of this instance that only includes the first two indexed fields.
asIndex2() - Method in class io.permazen.core.CoreIndex3
 
asIndex2() - Method in class io.permazen.core.CoreIndex4
 
asIndex2() - Method in interface io.permazen.index.Index3
Get the prefix of this instance that only includes the first three indexed fields.
asIndex2() - Method in interface io.permazen.index.Index4
Get the prefix of this instance that only includes the first three indexed fields.
asIndex3() - Method in class io.permazen.core.CoreIndex4
 
asIndex3() - Method in interface io.permazen.index.Index4
Get the prefix of this instance that only includes the first four indexed fields.
asInputStream() - Method in class io.permazen.util.ByteReader
Return a view of this instance as an InputStream.
asList() - Method in class io.permazen.kv.KeyRanges
Get the KeyRanges underlying with this instance as a list.
asList() - Method in class io.permazen.tuple.Tuple1
 
asList() - Method in class io.permazen.tuple.Tuple2
 
asList() - Method in class io.permazen.tuple.Tuple3
 
asList() - Method in class io.permazen.tuple.Tuple4
 
asList() - Method in class io.permazen.tuple.Tuple5
 
asList() - Method in interface io.permazen.tuple.Tuple
View this instance as a list.
asLong() - Method in class io.permazen.core.ObjId
Get this instance encoded as a long value.
asMap() - Method in class io.permazen.core.CoreIndex1
 
asMap() - Method in class io.permazen.core.CoreIndex2
 
asMap() - Method in class io.permazen.core.CoreIndex3
 
asMap() - Method in class io.permazen.core.CoreIndex4
 
asMap() - Method in interface io.permazen.index.Index
View this index as a NavigableMap of target values keyed by indexed value(s).
asMap() - Method in interface io.permazen.index.Index1
View this index as a NavigableMap of target values keyed by indexed value.
asMap() - Method in interface io.permazen.index.Index2
View this index as a NavigableMap of target values keyed by indexed value tuples.
asMap() - Method in interface io.permazen.index.Index3
View this index as a NavigableMap of target values keyed by indexed value tuples.
asMap() - Method in interface io.permazen.index.Index4
View this index as a NavigableMap of target values keyed by indexed value tuples.
asMapOfIndex1() - Method in class io.permazen.core.CoreIndex2
 
asMapOfIndex1() - Method in class io.permazen.core.CoreIndex3
 
asMapOfIndex1() - Method in class io.permazen.core.CoreIndex4
 
asMapOfIndex1() - Method in interface io.permazen.index.Index2
View this index as a NavigableMap of Index1s keyed by the first value.
asMapOfIndex1() - Method in interface io.permazen.index.Index3
View this index as a NavigableMap of Index1s keyed by the first two values.
asMapOfIndex1() - Method in interface io.permazen.index.Index4
View this index as a NavigableMap of Index1s keyed by the first three values.
asMapOfIndex2() - Method in class io.permazen.core.CoreIndex3
 
asMapOfIndex2() - Method in class io.permazen.core.CoreIndex4
 
asMapOfIndex2() - Method in interface io.permazen.index.Index3
View this index as a NavigableMap of Index2s keyed by the first value.
asMapOfIndex2() - Method in interface io.permazen.index.Index4
View this index as a NavigableMap of Index2s keyed by the first two values.
asMapOfIndex3() - Method in class io.permazen.core.CoreIndex4
 
asMapOfIndex3() - Method in interface io.permazen.index.Index4
View this index as a NavigableMap of Index3s keyed by the first value.
asOutputStream() - Method in class io.permazen.util.ByteWriter
Return a view of this instance as an OutputStream.
assertEquals(double[], double[], String) - Static method in class io.permazen.test.TestSupport
 
assertEquals(float[], float[], String) - Static method in class io.permazen.test.TestSupport
 
assertSameOrDiff(String, String) - Method in class io.permazen.test.TestSupport
 
asSet() - Method in class io.permazen.core.CoreIndex1
 
asSet() - Method in class io.permazen.core.CoreIndex2
 
asSet() - Method in class io.permazen.core.CoreIndex3
 
asSet() - Method in class io.permazen.core.CoreIndex4
 
asSet() - Method in interface io.permazen.index.Index
View this index as a NavigableSet of tuples.
asSet() - Method in interface io.permazen.index.Index1
View this index as a NavigableSet of tuples.
asSet() - Method in interface io.permazen.index.Index2
View this index as a NavigableSet of tuples.
asSet() - Method in interface io.permazen.index.Index3
View this index as a NavigableSet of tuples.
asSet() - Method in interface io.permazen.index.Index4
View this index as a NavigableSet of tuples.
asSet() - Method in class io.permazen.kv.KeyRanges
Get a view of the KeyRanges underlying with this instance as a sorted set.
AtomicArrayKVStore - Class in io.permazen.kv.array
AtomicKVStore based on ArrayKVStore plus a write-ahead log and background compaction.
AtomicArrayKVStore() - Constructor for class io.permazen.kv.array.AtomicArrayKVStore
 
AtomicKVDatabase - Class in io.permazen.kv.mvcc
Wrapper class that presents an AtomicKVStore view of a KVDatabase, using individual transactions for each operation.
AtomicKVDatabase(KVDatabase) - Constructor for class io.permazen.kv.mvcc.AtomicKVDatabase
Constructor.
AtomicKVStore - Interface in io.permazen.kv.mvcc
Extension of the KVStore interface for implementations that support atomic, batched reads and writes.
AtomicKVStoreTest - Class in io.permazen.kv.test
 
AtomicKVStoreTest() - Constructor for class io.permazen.kv.test.AtomicKVStoreTest
 
ATTEMPT - Enum constant in enum class io.permazen.UpgradeConversionPolicy
Attempt automatic conversion of field values to the new type, and if automatic conversion fails, set the value to the new type's default value as would UpgradeConversionPolicy.RESET.
ATTRIBUTE_NOT_FOUND - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Attribute not found in string.
ATTRIBUTE_TOO_LARGE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Attribute too large for type int.
autogenAllowDeleted() - Element in annotation interface io.permazen.annotation.PermazenType
Configure the default for the @PermazenField.allowDeleted() property for auto-generated reference fields.
autogenFields() - Element in annotation interface io.permazen.annotation.PermazenType
Whether to automatically generate database fields from un-annotated abstract Java bean methods.
autogenNonAbstract() - Element in annotation interface io.permazen.annotation.PermazenType
Whether to automatically generate database fields even from non-abstract Java bean methods.
autogenUpgradeConversion() - Element in annotation interface io.permazen.annotation.PermazenType
Configure the default for the @PermazenField.upgradeConversion() property for auto-generated reference fields.
AUTOMATIC - Enum constant in enum class io.permazen.ValidationMode
Objects are enqueued for validation automatically (if necessary) when they are modified.

B

b(String) - Static method in class io.permazen.test.TestSupport
 
ba(String...) - Static method in class io.permazen.test.TestSupport
 
BACKUP_AUTH_MISSING - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Cannot find authentication details (such as a password or secret key) for the specified Backup Container URL.
BACKUP_AUTH_UNREADABLE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Cannot read or parse one or more sources of authentication information for Backup Container URLs.
BACKUP_BAD_BLOCK_SIZE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Backup file block size too small.
BACKUP_CANNOT_EXPIRE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Cannot expire requested data from backup without violating minimum restorability.
BACKUP_DUPLICATE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Backup duplicate request.
BACKUP_ERROR - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Backup error.
BACKUP_INVALID_INFO - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Backup Container URL invalid.
BACKUP_INVALID_URL - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Backup Container URL invalid.
BACKUP_UNNEEDED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Backup unneeded request.
Base64ArrayEncoding<T,E> - Class in io.permazen.encoding
Adds support for an alternate Base-64 String encoding for non-null primitive array types.
Base64ArrayEncoding(PrimitiveEncoding<E>, TypeToken<T>) - Constructor for class io.permazen.encoding.Base64ArrayEncoding
 
BasicCliMain - Class in io.permazen.cli.main
A "main" class for Permazen CLI applications.
BasicCliMain() - Constructor for class io.permazen.cli.main.BasicCliMain
 
beforeCommit(boolean) - Method in interface io.permazen.core.Transaction.Callback
Invoked before transaction commit (and before Transaction.Callback.beforeCompletion()).
beforeCommit(boolean) - Method in class io.permazen.core.Transaction.CallbackAdapter
 
beforeCommit(boolean) - Method in class io.permazen.spring.PermazenTransactionManager.TransactionSynchronizationCallback
 
beforeCompletion() - Method in interface io.permazen.core.Transaction.Callback
Invoked before transaction completion in any case (but after any beforeCommit()).
beforeCompletion() - Method in class io.permazen.core.Transaction.CallbackAdapter
 
beforeCompletion() - Method in class io.permazen.spring.PermazenTransactionManager.TransactionSynchronizationCallback
 
begin() - Method in class io.permazen.cli.jshell.PermazenJShellShellSession
Convert the current snippet transaction into an extended transaction.
beginTransaction(Connection) - Method in class io.permazen.kv.cockroach.CockroachKVDatabase
 
beginTransaction(Connection) - Method in class io.permazen.kv.sql.SQLKVDatabase
Open a new SQL transaction on the given Connection.
BerkeleyKVDatabase - Class in io.permazen.kv.bdb
Oracle Berkeley DB Java Edition KVDatabase implementation.
BerkeleyKVDatabase() - Constructor for class io.permazen.kv.bdb.BerkeleyKVDatabase
Constructor.
BerkeleyKVImplementation - Class in io.permazen.kv.bdb
 
BerkeleyKVImplementation() - Constructor for class io.permazen.kv.bdb.BerkeleyKVImplementation
 
BerkeleyKVImplementation.Config - Class in io.permazen.kv.bdb
 
BerkeleyKVTransaction - Class in io.permazen.kv.bdb
Oracle Berkeley DB Java Edition KVTransaction implementation.
BerkeleyKVTransaction.CursorIterator - Class in io.permazen.kv.bdb
BigDecimalEncoding - Class in io.permazen.encoding
Non-null BigDecimal type.
BigDecimalEncoding() - Constructor for class io.permazen.encoding.BigDecimalEncoding
 
BigIntegerEncoding - Class in io.permazen.encoding
Non-null BigInteger type.
BigIntegerEncoding() - Constructor for class io.permazen.encoding.BigIntegerEncoding
 
binarySearch(byte[], Object, int, int) - Method in class io.permazen.kv.mvstore.ByteArrayDataType
 
binarySearch(E) - Method in class io.permazen.util.ImmutableNavigableSet
Search for the given element in the underlying array.
binarySearch(K) - Method in class io.permazen.util.ImmutableNavigableMap
Search for the given element in the underlying array.
BIND_FAILED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Unable to bind to network.
BitSetEncoding - Class in io.permazen.encoding
Non-null BitSet type.
BitSetEncoding() - Constructor for class io.permazen.encoding.BitSetEncoding
 
BooleanArrayEncoding - Class in io.permazen.encoding
Non-null boolean[] array type.
BooleanArrayEncoding() - Constructor for class io.permazen.encoding.BooleanArrayEncoding
 
BooleanEncoding - Class in io.permazen.encoding
 
BooleanEncoding(EncodingId) - Constructor for class io.permazen.encoding.BooleanEncoding
 
bounds - Variable in class io.permazen.util.AbstractNavigableMap
Key range bounds associated with this instance.
bounds - Variable in class io.permazen.util.AbstractNavigableSet
Element range bounds associated with this instance.
Bounds<T> - Class in io.permazen.util
Utility class used by AbstractNavigableSet and AbstractNavigableMap to define the (optional) upper and lower bounds of a restricted range.
Bounds() - Constructor for class io.permazen.util.Bounds
Convenience constructor to create an unbounded instance, i.e., having neither upper nor lower bounds.
Bounds(T, boolean, T, boolean) - Constructor for class io.permazen.util.Bounds
Create two-sided bounds.
Bounds(T, BoundType, boolean) - Constructor for class io.permazen.util.Bounds
Create a one-sided bound.
Bounds(T, BoundType, T, BoundType) - Constructor for class io.permazen.util.Bounds
Primary constructor.
Bounds(T, T) - Constructor for class io.permazen.util.Bounds
Create two-sided bounds with inclusive lower bound and exclusive upper bound.
BoundType - Enum Class in io.permazen.util
Upper and lower bound types.
branch() - Method in class io.permazen.cli.jshell.PermazenJShellShellSession
Commit the current snippet transaction and create a new branched extended transaction.
branch(Map<String, ?>, Map<String, ?>) - Method in class io.permazen.cli.jshell.PermazenJShellShellSession
Commit the current snippet transaction and create a new branched extended transaction with options.
BranchedKVTransaction - Class in io.permazen.kv.mvcc
A KVTransaction that is based on a snapshot from an original KVTransaction and that can, at some arbitrary later time, be merged back into a new KVTransaction from the same database, assuming no conflicting changes have occurred in the meantime.
BranchedKVTransaction(KVDatabase) - Constructor for class io.permazen.kv.mvcc.BranchedKVTransaction
Constructor.
BranchedKVTransaction(KVDatabase, Map<String, ?>, Map<String, ?>) - Constructor for class io.permazen.kv.mvcc.BranchedKVTransaction
Constructor.
BROKEN_PROMISE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Broken promise.
bufferMutations(TransactionContext) - Method in class io.permazen.kv.spanner.ReadWriteSpannerView
Atomically transfer all of the outstanding mutations associated with this instance into the given transaction context, and then clear them.
build() - Method in class io.permazen.core.TransactionConfig.Builder
Create a new TransactionConfig from this instance.
build() - Method in class io.permazen.core.util.XMLObjectSerializer.OutputOptions.Builder
Create a new XMLObjectSerializer.OutputOptions from this instance.
build() - Method in class io.permazen.PermazenConfig.Builder
Create a new PermazenConfig from this instance.
buildArrayEncoding(Encoding<E>) - Static method in class io.permazen.encoding.SimpleEncodingRegistry
Build an array encoding for the given element encoding using Permazen's default array encoding.
buildCliConfig() - Method in class io.permazen.cli.app.CliMain
 
buildCliConfig() - Method in class io.permazen.cli.main.BasicCliMain
Build a CliConfig to use.
buildConfig(OptionSet) - Method in class io.permazen.kv.array.ArrayKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.bdb.BerkeleyKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.fdb.FoundationKVImplementation
 
buildConfig(OptionSet) - Method in interface io.permazen.kv.KVImplementation
Build a configuration from implementation-specific command line options, if any were given.
buildConfig(OptionSet) - Method in class io.permazen.kv.leveldb.LevelDBKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.lmdb.LMDBKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.mvstore.MVStoreKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.raft.RaftKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.simple.MemoryKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.simple.SimpleKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.simple.XMLKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.spanner.SpannerKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.sql.SQLDriverKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.sqlite.SQLiteKVImplementation
 
buildConfig(OptionSet) - Method in class io.permazen.kv.xodus.XodusKVImplementation
 
buildConfig(OptionSet, URI) - Method in class io.permazen.kv.cockroach.CockroachKVImplementation
 
buildConfig(OptionSet, URI) - Method in class io.permazen.kv.mssql.MSSQLKVImplementation
 
buildConfig(OptionSet, URI) - Method in class io.permazen.kv.mysql.MySQLKVImplementation
 
buildConfig(OptionSet, URI) - Method in class io.permazen.kv.sql.SQLDriverKVImplementation
 
builder() - Static method in class io.permazen.core.TransactionConfig
builder() - Static method in class io.permazen.core.util.XMLObjectSerializer.OutputOptions
 
builder() - Static method in class io.permazen.PermazenConfig
buildException() - Method in class io.permazen.util.ParseContext
Create a generic exception for rejecting the current input.
buildException(String) - Method in class io.permazen.util.ParseContext
Create an exception for rejecting the current input.
buildJShellCommand() - Method in class io.permazen.cli.main.BasicCliMain
Build a JShellCommand to use as the "jshell" command implementation.
buildList(Object...) - Static method in class io.permazen.test.TestSupport
 
buildMap(Object...) - Static method in class io.permazen.test.TestSupport
 
buildSchemaIndexKey(ObjId, int) - Static method in class io.permazen.core.Layout
Build the key for an object schema index entry.
buildSet(Object...) - Static method in class io.permazen.test.TestSupport
 
buildShellRequest(PermazenShellSession, String, List<String>) - Method in class io.permazen.cli.jshell.PermazenJShellCommand
 
buildShellRequest(ShellSession, String, List<String>) - Method in class io.permazen.cli.jshell.PermazenJShellCommand
 
buildSortedMap(Object...) - Static method in class io.permazen.test.TestSupport
 
buildSortedSet(Object...) - Static method in class io.permazen.test.TestSupport
 
buildSpliterator(Iterator<E>) - Method in class io.permazen.util.AbstractIterationSet
Build a Spliterator appropriate for this set from the given instance iterator.
buildSpliterator(Iterator<E>) - Method in class io.permazen.util.AbstractNavigableSet
 
buildSpliterator(Iterator<E>) - Method in class io.permazen.util.ImmutableNavigableSet
 
buildTableKey(byte[], int) - Static method in class io.permazen.core.Layout
Get the key corresponding to an entry in an indexed table (e.g., schema table or storage ID table).
buildTransactionConfig(Map<String, ?>) - Method in class io.permazen.Permazen
Build the TransactionConfig for a new core API transaction.
builtin(String) - Static method in class io.permazen.encoding.EncodingIds
Build an encoding ID for a built-in Permazen encoding, using the given suffix.
Bundle - Class in io.permazen.cli.cmd
 
Bundle() - Constructor for class io.permazen.cli.cmd.Bundle
 
ByteArrayDataType - Class in io.permazen.kv.mvstore
MVStore DataType implementation encoding byte[] arrays sorted lexicographically.
ByteArrayEncoding - Class in io.permazen.encoding
byte[] primitive array type.
ByteArrayEncoding() - Constructor for class io.permazen.encoding.ByteArrayEncoding
 
ByteArrayLMDBKVDatabase - Class in io.permazen.kv.lmdb
LMDBKVDatabase using byte[] arrays buffers.
ByteArrayLMDBKVDatabase() - Constructor for class io.permazen.kv.lmdb.ByteArrayLMDBKVDatabase
 
ByteArrayLMDBKVStore - Class in io.permazen.kv.lmdb
KVStore view of a LMDB transaction using byte[] array buffers.
ByteArrayLMDBKVStore(Dbi<byte[]>, Txn<byte[]>) - Constructor for class io.permazen.kv.lmdb.ByteArrayLMDBKVStore
Constructor.
ByteArrayLMDBKVTransaction - Class in io.permazen.kv.lmdb
LMDBKVTransaction using byte[] arrays buffers.
ByteArrayLMDBKVTransaction(LMDBKVDatabase<byte[]>, Env<byte[]>, Dbi<byte[]>) - Constructor for class io.permazen.kv.lmdb.ByteArrayLMDBKVTransaction
Constructor.
ByteEncoding - Class in io.permazen.encoding
byte primitive type.
ByteEncoding(EncodingId) - Constructor for class io.permazen.encoding.ByteEncoding
 
ByteReader - Class in io.permazen.util
Reads bytes from a buffer.
ByteReader(byte[]) - Constructor for class io.permazen.util.ByteReader
Constructor.
ByteReader(byte[], int) - Constructor for class io.permazen.util.ByteReader
Constructor.
ByteReader(byte[], int, int) - Constructor for class io.permazen.util.ByteReader
Constructor.
ByteReader(ByteWriter) - Constructor for class io.permazen.util.ByteReader
Constructor.
ByteReader(ByteWriter, int) - Constructor for class io.permazen.util.ByteReader
Constructor.
BytesParser() - Constructor for class io.permazen.cli.cmd.AbstractKVCommand.BytesParser
 
ByteUtil - Class in io.permazen.util
Byte manipulation utilities.
ByteWriter - Class in io.permazen.util
Writes bytes to a buffer.
ByteWriter() - Constructor for class io.permazen.util.ByteWriter
Default constructor.
ByteWriter(int) - Constructor for class io.permazen.util.ByteWriter
Constructor.

C

CachingConfig - Interface in io.permazen.kv.caching
API for configuring caching behavior.
cachingKV - Variable in class io.permazen.kv.caching.CachingKVTransaction
The caching layer for the transaction.
CachingKVDatabase - Class in io.permazen.kv.caching
A wrapper around an inner KVDatabase that adds a caching layer to transactions by wrapping them in a CachingKVStore.
CachingKVDatabase() - Constructor for class io.permazen.kv.caching.CachingKVDatabase
Default constructor.
CachingKVDatabase(KVDatabase) - Constructor for class io.permazen.kv.caching.CachingKVDatabase
Primary constructor.
CachingKVStore - Class in io.permazen.kv.caching
A caching layer for read-only KVStore's that have high latency for individual reads but low latency for consecutive key/value pairs in a KVStore.getRange() range read.
CachingKVStore(CloseableKVStore, ExecutorService, long) - Constructor for class io.permazen.kv.caching.CachingKVStore
Constructor for when the underlying KVStore should be closed when this instance is closed.
CachingKVStore(KVStore, ExecutorService, long) - Constructor for class io.permazen.kv.caching.CachingKVStore
Constructor.
CachingKVTransaction - Class in io.permazen.kv.caching
A transaction associated with a CachingKVDatabase.
calculateCompactionPressureDelay(float) - Method in class io.permazen.kv.array.AtomicArrayKVStore
Calculate the maximum amount of time that a thread attempting to apply() mutations must wait for a background compaction to complete as we start nearing the high water mark.
calculateSize(int) - Method in class io.permazen.kv.raft.msg.PingRequest
 
calculateSize(int) - Method in class io.permazen.kv.raft.msg.AppendRequest
 
calculateSize(int) - Method in class io.permazen.kv.raft.msg.AppendResponse
 
calculateSize(int) - Method in class io.permazen.kv.raft.msg.CommitRequest
 
calculateSize(int) - Method in class io.permazen.kv.raft.msg.CommitResponse
 
calculateSize(int) - Method in class io.permazen.kv.raft.msg.InstallSnapshot
 
calculateSize(int) - Method in class io.permazen.kv.raft.msg.Message
Calculate the number of bytes required by writeTo().
calculateSize(int) - Method in class io.permazen.kv.raft.msg.RequestVote
 
calculateSize(Timestamp, int) - Static method in class io.permazen.kv.raft.msg.Message
 
calculateSize(String) - Static method in class io.permazen.kv.raft.msg.Message
 
calculateSize(ByteBuffer) - Static method in class io.permazen.kv.raft.msg.Message
 
call() - Method in class io.permazen.kv.test.KVDatabaseTest.Reader
 
CallbackAdapter() - Constructor for class io.permazen.core.Transaction.CallbackAdapter
 
CandidateRole - Class in io.permazen.kv.raft
Raft candidate role.
CANNOT_MODIFY_ROOT_DIRECTORY - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Root directory cannot be modified.
CANNOT_MOVE_DIRECTORY_BETWEEN_PARTITIONS - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Directory cannot be moved between partitions.
CANNOT_OPEN_ROOT_DIRECTORY - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Root directory cannot be opened.
CANNOT_USE_PARTITION_AS_SUBSPACE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Directory partition cannot be used as subspace.
canRead(Class<?>, MediaType) - Method in class io.permazen.spring.PermazenObjectHttpMessageConverter
 
cascade(int, String...) - Method in interface io.permazen.PermazenObject
Find all objects reachable through the specified reference cascade(s).
cascade(ObjId, int, ObjIdSet, String...) - Method in class io.permazen.PermazenTransaction
Find all objects reachable through the specified reference cascades.
caseAppendRequest(AppendRequest) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle an AppendRequest.
caseAppendResponse(AppendResponse) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle an AppendResponse.
caseChange(Change<T>) - Method in interface io.permazen.change.ChangeSwitch
Visitor pattern roll-up method.
caseCollectionElementIndex(CollectionElementIndex<C, E>) - Method in interface io.permazen.core.IndexSwitch
Visitor pattern roll-up method.
caseCollectionField(CollectionField<C, E>) - Method in interface io.permazen.core.FieldSwitch
Visitor pattern roll-up method.
caseCollectionSchemaField(CollectionSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
Visitor pattern roll-up method.
caseCommitRequest(CommitRequest) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle a CommitRequest.
caseCommitResponse(CommitResponse) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle a CommitResponse.
caseComplexField(ComplexField<T>) - Method in interface io.permazen.core.FieldSwitch
Visitor pattern roll-up method.
caseComplexSchemaField(ComplexSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
Visitor pattern roll-up method.
caseComplexSubFieldIndex(ComplexSubFieldIndex<C, T>) - Method in interface io.permazen.core.IndexSwitch
Visitor pattern roll-up method.
caseCompositeIndex(CompositeIndex) - Method in interface io.permazen.core.IndexSwitch
Handle a CompositeIndex.
caseCounterField(CounterField) - Method in interface io.permazen.core.FieldSwitch
Handle a CounterField.
caseCounterSchemaField(CounterSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
caseDefault(SchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
Visitor pattern roll-up method.
caseEnumArrayField(EnumArrayField) - Method in interface io.permazen.core.FieldSwitch
Handle an EnumArrayField.
caseEnumArraySchemaField(EnumArraySchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
caseEnumField(EnumField) - Method in interface io.permazen.core.FieldSwitch
Handle an EnumField.
caseEnumSchemaField(EnumSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
Handle a EnumSchemaField.
caseField(Field<T>) - Method in interface io.permazen.core.FieldSwitch
Visitor pattern roll-up method.
caseFieldChange(FieldChange<T>) - Method in interface io.permazen.change.ChangeSwitch
Visitor pattern roll-up method.
caseGrantVote(GrantVote) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle an GrantVote.
caseIndex(Index) - Method in interface io.permazen.core.IndexSwitch
Visitor pattern roll-up method.
caseInstallSnapshot(InstallSnapshot) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle a InstallSnapshot.
caseListElementIndex(ListElementIndex<E>) - Method in interface io.permazen.core.IndexSwitch
caseListField(ListField<E>) - Method in interface io.permazen.core.FieldSwitch
Handle a ListField.
caseListFieldAdd(ListFieldAdd<T, E>) - Method in interface io.permazen.change.ChangeSwitch
Handle a ListFieldAdd event.
caseListFieldChange(ListFieldChange<T>) - Method in interface io.permazen.change.ChangeSwitch
Visitor pattern roll-up method.
caseListFieldClear(ListFieldClear<T>) - Method in interface io.permazen.change.ChangeSwitch
Handle a ListFieldClear event.
caseListFieldRemove(ListFieldRemove<T, E>) - Method in interface io.permazen.change.ChangeSwitch
Handle a ListFieldRemove event.
caseListFieldReplace(ListFieldReplace<T, E>) - Method in interface io.permazen.change.ChangeSwitch
Handle a ListFieldReplace event.
caseListSchemaField(ListSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
Handle a ListSchemaField.
caseMapField(MapField<K, V>) - Method in interface io.permazen.core.FieldSwitch
Handle a MapField.
caseMapFieldAdd(MapFieldAdd<T, K, V>) - Method in interface io.permazen.change.ChangeSwitch
Handle a MapFieldAdd event.
caseMapFieldChange(MapFieldChange<T>) - Method in interface io.permazen.change.ChangeSwitch
Visitor pattern roll-up method.
caseMapFieldClear(MapFieldClear<T>) - Method in interface io.permazen.change.ChangeSwitch
Handle a MapFieldClear event.
caseMapFieldRemove(MapFieldRemove<T, K, V>) - Method in interface io.permazen.change.ChangeSwitch
Handle a MapFieldRemove event.
caseMapFieldReplace(MapFieldReplace<T, K, V>) - Method in interface io.permazen.change.ChangeSwitch
Handle a MapFieldReplace event.
caseMapKeyIndex(MapKeyIndex<K, V>) - Method in interface io.permazen.core.IndexSwitch
Handle a MapKeyIndex.
caseMapSchemaField(MapSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
Handle a MapSchemaField.
caseMapValueIndex(MapValueIndex<K, V>) - Method in interface io.permazen.core.IndexSwitch
Handle a MapValueIndex.
caseObjectCreate(ObjectCreate<T>) - Method in interface io.permazen.change.ChangeSwitch
Handle an ObjectCreate event.
caseObjectDelete(ObjectDelete<T>) - Method in interface io.permazen.change.ChangeSwitch
Handle an ObjectDelete event.
casePermazenCollectionField(PermazenCollectionField) - Method in interface io.permazen.PermazenFieldSwitch
Visitor pattern roll-up method.
casePermazenComplexField(PermazenComplexField) - Method in interface io.permazen.PermazenFieldSwitch
Visitor pattern roll-up method.
casePermazenCounterField(PermazenCounterField) - Method in interface io.permazen.PermazenFieldSwitch
casePermazenEnumArrayField(PermazenEnumArrayField) - Method in interface io.permazen.PermazenFieldSwitch
casePermazenEnumField(PermazenEnumField) - Method in interface io.permazen.PermazenFieldSwitch
casePermazenField(PermazenField) - Method in interface io.permazen.PermazenFieldSwitch
Visitor pattern roll-up method.
casePermazenListField(PermazenListField) - Method in interface io.permazen.PermazenFieldSwitch
casePermazenMapField(PermazenMapField) - Method in interface io.permazen.PermazenFieldSwitch
casePermazenReferenceField(PermazenReferenceField) - Method in interface io.permazen.PermazenFieldSwitch
casePermazenSetField(PermazenSetField) - Method in interface io.permazen.PermazenFieldSwitch
casePermazenSimpleField(PermazenSimpleField) - Method in interface io.permazen.PermazenFieldSwitch
casePingRequest(PingRequest) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle a PingRequest.
casePingResponse(PingResponse) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle a PingResponse.
caseReferenceField(ReferenceField) - Method in interface io.permazen.core.FieldSwitch
Handle a ReferenceField.
caseReferenceSchemaField(ReferenceSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
caseRequestVote(RequestVote) - Method in interface io.permazen.kv.raft.msg.MessageSwitch
Handle an RequestVote.
caseSetElementIndex(SetElementIndex<E>) - Method in interface io.permazen.core.IndexSwitch
Handle a SetElementIndex.
caseSetField(SetField<E>) - Method in interface io.permazen.core.FieldSwitch
Handle a SetField.
caseSetFieldAdd(SetFieldAdd<T, E>) - Method in interface io.permazen.change.ChangeSwitch
Handle a SetFieldAdd event.
caseSetFieldChange(SetFieldChange<T>) - Method in interface io.permazen.change.ChangeSwitch
Visitor pattern roll-up method.
caseSetFieldClear(SetFieldClear<T>) - Method in interface io.permazen.change.ChangeSwitch
Handle a SetFieldClear event.
caseSetFieldRemove(SetFieldRemove<T, E>) - Method in interface io.permazen.change.ChangeSwitch
Handle a SetFieldRemove event.
caseSetSchemaField(SetSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
Handle a SetSchemaField.
caseSimpleField(SimpleField<T>) - Method in interface io.permazen.core.FieldSwitch
Handle a SimpleField.
caseSimpleFieldChange(SimpleFieldChange<T, V>) - Method in interface io.permazen.change.ChangeSwitch
Handle a SimpleFieldChange event.
caseSimpleFieldIndex(SimpleFieldIndex<T>) - Method in interface io.permazen.core.IndexSwitch
caseSimpleIndex(SimpleIndex<T>) - Method in interface io.permazen.core.IndexSwitch
Visitor pattern roll-up method.
caseSimpleSchemaField(SimpleSchemaField) - Method in interface io.permazen.schema.SchemaFieldSwitch
ceiling(E) - Method in class io.permazen.util.AbstractNavigableSet
 
ceiling(E) - Method in class io.permazen.util.ImmutableNavigableSet
 
ceilingEntry(K) - Method in class io.permazen.util.AbstractNavigableMap
 
ceilingEntry(K) - Method in class io.permazen.util.ImmutableNavigableMap
 
ceilingKey(K) - Method in class io.permazen.util.AbstractNavigableMap
 
ceilingKey(K) - Method in class io.permazen.util.ImmutableNavigableMap
 
Change<T> - Class in io.permazen.change
Object change notification.
Change(T) - Constructor for class io.permazen.change.Change
Constructor.
ChangeSwitch<R> - Interface in io.permazen.change
Visitor pattern interface for the Change class hierarchy.
CharacterArrayEncoding - Class in io.permazen.encoding
Non-null char[] array type.
CharacterArrayEncoding() - Constructor for class io.permazen.encoding.CharacterArrayEncoding
 
CharacterEncoding - Class in io.permazen.encoding
Character type.
CharacterEncoding(EncodingId) - Constructor for class io.permazen.encoding.CharacterEncoding
 
characteristics() - Method in class io.permazen.util.ConvertedSpliterator
 
check(KVStore, Consumer<? super Issue>) - Method in class io.permazen.jsck.Jsck
Perform check.
checkAllowed(ObjId) - Method in class io.permazen.core.ReferenceEncoding
Verify the reference target is permitted by this instance.
checkAvailability(FallbackKVDatabase) - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Perform an availability assessment of the underlying RaftKVDatabase associated with this instance.
checkDecodeLength(int) - Method in class io.permazen.encoding.Base64ArrayEncoding
 
checkForConflicts() - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
Check for conflicts between this transaction and the current database contents.
checkForOutOfBandUpdate() - Method in class io.permazen.kv.simple.XMLKVDatabase
Check the XML file's timestamp and reload it if it has been modified since the most recent read or write by this instance.
checkHoldTimeout(LockOwner) - Method in class io.permazen.kv.simple.LockManager
Check whether the hold timeout has expired for the given lock owner and if not return the amount of time remaining.
checkMap(Map, Map) - Static method in class io.permazen.test.TestSupport
 
checkSet(Set, Set) - Static method in class io.permazen.test.TestSupport
 
checkState(SimpleKVTransaction) - Method in class io.permazen.kv.simple.SimpleKVDatabase
Verify that the given transaction is still usable.
checkState(SimpleKVTransaction) - Method in class io.permazen.kv.simple.XMLKVDatabase
 
CHECKSUM_FAILED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
A data checksum failed.
checkValid(T, boolean) - Method in class io.permazen.test.TestSupport
 
classPathOption - Variable in class io.permazen.cli.config.PermazenCliConfig
 
cleanup() - Method in class io.permazen.kv.test.AtomicKVStoreTest
 
clear() - Method in class io.permazen.core.util.GeneratedIdCache
Clear this instance.
clear() - Method in class io.permazen.core.util.ObjIdBiMultiMap
Clear this instance.
clear() - Method in class io.permazen.core.util.ObjIdMap
 
clear() - Method in class io.permazen.core.util.ObjIdSet
 
clear() - Method in class io.permazen.kv.KeyRanges
Remove all keys from this instance.
clear() - Method in class io.permazen.kv.mvcc.Writes
Clear all mutations.
clear() - Method in class io.permazen.kv.util.KVNavigableMap
 
clear() - Method in class io.permazen.kv.util.KVNavigableSet
 
clear() - Method in class io.permazen.util.ConvertedList
 
clear() - Method in class io.permazen.util.ConvertedNavigableMap
 
clear() - Method in class io.permazen.util.ConvertedNavigableSet
 
clear() - Method in class io.permazen.util.ConvertedSet
 
CliConfig - Class in io.permazen.cli.config
Configuration for a CLI application.
CliConfig() - Constructor for class io.permazen.cli.config.CliConfig
 
client - Variable in class io.permazen.kv.spanner.SpannerKVTransaction
 
CLIENT_INVALID_OPERATION - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Invalid API call.
CliMain - Class in io.permazen.cli.app
 
CliMain() - Constructor for class io.permazen.cli.app.CliMain
 
clone() - Method in class io.permazen.core.TransactionConfig.Builder
Clone this instance.
clone() - Method in class io.permazen.core.util.ObjIdBiMultiMap
Clone this instance.
clone() - Method in class io.permazen.core.util.ObjIdMap
 
clone() - Method in class io.permazen.core.util.ObjIdSet
 
clone() - Method in class io.permazen.core.util.XMLObjectSerializer.OutputOptions.Builder
Clone this instance.
clone() - Method in class io.permazen.kv.KeyRanges
Clone this instance.
clone() - Method in exception io.permazen.kv.KVException
Create a clone of this instance.
clone() - Method in class io.permazen.kv.KVPair
Deep-clone this instance.
clone() - Method in class io.permazen.kv.mvcc.MutableView
Clone this instance.
clone() - Method in class io.permazen.kv.mvcc.Reads
 
clone() - Method in class io.permazen.kv.mvcc.Writes
Clone this instance.
clone() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
 
clone() - Method in class io.permazen.kv.spanner.ReadWriteSpannerView
 
clone() - Method in class io.permazen.kv.util.MemoryKVStore
 
clone() - Method in class io.permazen.PermazenConfig.Builder
Clone this instance.
clone() - Method in class io.permazen.schema.AbstractEnumSchemaField
 
clone() - Method in class io.permazen.schema.CollectionSchemaField
 
clone() - Method in class io.permazen.schema.ComplexSchemaField
 
clone() - Method in class io.permazen.schema.CounterSchemaField
 
clone() - Method in class io.permazen.schema.EnumArraySchemaField
 
clone() - Method in class io.permazen.schema.EnumSchemaField
 
clone() - Method in class io.permazen.schema.ListSchemaField
 
clone() - Method in class io.permazen.schema.MapSchemaField
 
clone() - Method in class io.permazen.schema.ReferenceSchemaField
 
clone() - Method in class io.permazen.schema.SchemaCompositeIndex
 
clone() - Method in class io.permazen.schema.SchemaField
 
clone() - Method in class io.permazen.schema.SchemaItem
 
clone() - Method in class io.permazen.schema.SchemaModel
Deep-clone this instance.
clone() - Method in class io.permazen.schema.SchemaObjectType
 
clone() - Method in class io.permazen.schema.SetSchemaField
 
clone() - Method in class io.permazen.schema.SimpleSchemaField
 
clone() - Method in class io.permazen.util.ParseContext
Clone this instance.
close() - Method in class io.permazen.core.DetachedTransaction
Close this instance and release any resources associated with it.
close() - Method in class io.permazen.DetachedPermazenTransaction
Close this instance and release any resources associated with it.
close() - Method in class io.permazen.kv.array.ArrayKVWriter
Close all three outputs.
close() - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
 
close() - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction.CursorIterator
 
close() - Method in class io.permazen.kv.caching.CachingKVStore
Close this instance and release any resources associated with it.
close() - Method in class io.permazen.kv.caching.CachingKVTransaction
 
close() - Method in interface io.permazen.kv.CloseableKVStore
Close this KVStore and release any resources associated with it.
close() - Method in class io.permazen.kv.KVPairIterator
 
close() - Method in class io.permazen.kv.leveldb.LevelDBKVStore
Close this instance.
close() - Method in class io.permazen.kv.leveldb.SnapshotLevelDBKVStore
 
close() - Method in class io.permazen.kv.lmdb.LMDBKVStore
Close this instance.
close() - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
Close this transaction.
close() - Method in class io.permazen.kv.mvcc.SnapshotKVTransaction
Close this instance.
close() - Method in class io.permazen.kv.mvstore.CursorIterator
 
close() - Method in class io.permazen.kv.mvstore.MVMapSnapshot
 
close() - Method in class io.permazen.kv.spanner.ReadOnlySpannerView
Closes the associated ReadContext.
close() - Method in class io.permazen.kv.spanner.ReadWriteSpannerView
Close the associated ReadContext.
close() - Method in class io.permazen.kv.util.AbstractKVIterator
 
close() - Method in class io.permazen.kv.util.CloseableForwardingKVStore
 
close() - Method in class io.permazen.kv.util.KeyWatchTracker
Close this instance.
close() - Method in class io.permazen.kv.xodus.XodusKVStore
Close this instance, discarding any changes.
close() - Method in interface io.permazen.util.CloseableIterator
 
close() - Method in class io.permazen.util.CloseableTracker
Close all unclosed items associated with this instance.
close() - Method in class io.permazen.util.UniqueIterator
 
close(boolean) - Method in class io.permazen.kv.xodus.XodusKVStore
Close this instance, optionally comitting any changes.
CloseableForwardingKVStore - Class in io.permazen.kv.util
A ForwardingKVStore also implementing CloseableKVStore, with some associated underlying Closeable resource to close when CloseableForwardingKVStore.close()'d.
CloseableForwardingKVStore(KVStore, Runnable) - Constructor for class io.permazen.kv.util.CloseableForwardingKVStore
Constructor.
CloseableIterator<E> - Interface in io.permazen.util
An Iterator that is Closeable and can be close()'d without throwing any exceptions.
CloseableKVStore - Interface in io.permazen.kv
Implemented by KVStores that must be CloseableKVStore.close()ed when no longer in use.
CloseableRefs<C extends Closeable> - Class in io.permazen.util
Holds a count of references to a Closeable resource and only close()'s it when the reference count reaches zero.
CloseableRefs(C) - Constructor for class io.permazen.util.CloseableRefs
Constructor.
CloseableTracker - Class in io.permazen.util
Keeps track of Closeable objects (termed items) that must be reliably closed prior to shutting down some associated context, but that also must not be closed prior to becoming unreachable, when the straightforward strategy of just storing them until context shutdown would require too much memory.
CloseableTracker() - Constructor for class io.permazen.util.CloseableTracker
Constructor.
closeConnection() - Method in class io.permazen.kv.sql.SQLKVTransaction
Close the Connection associated with this instance, if it's not already closed.
CLOSED - Enum constant in enum class io.permazen.kv.raft.TxState
The transaction is closed.
closeTransaction(boolean) - Method in class io.permazen.cli.Session
Closed the transaction previously opened and associated with this instance by openTransaction().
closeTransactions() - Method in class io.permazen.kv.mvcc.SnapshotKVDatabase
Forcibly fail all outstanding transactions due to SnapshotKVDatabase.stop() being invoked.
CLUSTER_VERSION_CHANGED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
The protocol version of the cluster has changed.
CockroachKVDatabase - Class in io.permazen.kv.cockroach
KVDatabase implementation based on CockroachDB.
CockroachKVDatabase() - Constructor for class io.permazen.kv.cockroach.CockroachKVDatabase
 
CockroachKVImplementation - Class in io.permazen.kv.cockroach
 
CockroachKVImplementation() - Constructor for class io.permazen.kv.cockroach.CockroachKVImplementation
Default constructor.
CockroachKVImplementation(String) - Constructor for class io.permazen.kv.cockroach.CockroachKVImplementation
Constructor allowing alternative driver.
CollectionElementIndex<C extends Collection<E>,E> - Class in io.permazen.core
A simple index on the elements of a CollectionField.
CollectionField<C extends Collection<E>,E> - Class in io.permazen.core
Superclass of fields with types assignable to Collection.
CollectionSchemaField - Class in io.permazen.schema
A collection field in one version of a SchemaObjectType.
CollectionSchemaField() - Constructor for class io.permazen.schema.CollectionSchemaField
 
Command - Interface in io.permazen.cli.cmd
Session command.
commit() - Method in class io.permazen.cli.jshell.PermazenJShellShellSession
Commit the current snippet transaction and open a new non-extended transaction.
commit() - Method in class io.permazen.core.DetachedTransaction
Commit this transaction.
commit() - Method in class io.permazen.core.Transaction
Commit this transaction.
commit() - Method in class io.permazen.DetachedPermazenTransaction
Commit this transaction.
commit() - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
 
commit() - Method in class io.permazen.kv.caching.CachingKVTransaction
 
commit() - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
commit() - Method in interface io.permazen.kv.KVTransaction
Commit this transaction.
commit() - Method in class io.permazen.kv.lmdb.LMDBKVTransaction
 
commit() - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
commit() - Method in class io.permazen.kv.mvcc.SnapshotKVTransaction
 
commit() - Method in class io.permazen.kv.raft.fallback.FallbackKVTransaction
 
commit() - Method in class io.permazen.kv.raft.RaftKVTransaction
 
commit() - Method in class io.permazen.kv.simple.SimpleKVTransaction
 
commit() - Method in class io.permazen.kv.spanner.SpannerKVTransaction
 
commit() - Method in class io.permazen.kv.sql.SQLKVTransaction
 
commit() - Method in class io.permazen.kv.util.PrefixKVTransaction
 
commit() - Method in class io.permazen.kv.xodus.XodusKVTransaction
 
commit() - Method in class io.permazen.PermazenTransaction
Commit this transaction.
COMMIT_READ_INCOMPLETE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Commit with incomplete read.
COMMIT_READY - Enum constant in enum class io.permazen.kv.raft.TxState
The transaction is ready for commit.
COMMIT_UNKNOWN_RESULT - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Transaction may or may not have committed.
COMMIT_WAITING - Enum constant in enum class io.permazen.kv.raft.TxState
The transaction is waiting for the corresponding Raft log entry to be committed.
commitOrRollback() - Method in class io.permazen.kv.mvstore.MVStoreAtomicKVStore
Commit outstanding changes, unless there is an exception when doing so, in which case rollback changes.
CommitRequest - Class in io.permazen.kv.raft.msg
Sent from followers to leaders to start the commit of a transaction.
CommitRequest(int, String, String, long, long, long, long, ByteBuffer, ByteBuffer) - Constructor for class io.permazen.kv.raft.msg.CommitRequest
Constructor.
CommitResponse - Class in io.permazen.kv.raft.msg
Response to a CommitRequest.
CommitResponse(int, String, String, long, long, long, long) - Constructor for class io.permazen.kv.raft.msg.CommitResponse
Constructor for success case, when there is no minimum leader lease timeout required for commit (read-write transaction, or read-only transaction occurring within the current leader lease timeout).
CommitResponse(int, String, String, long, long, long, long, Timestamp) - Constructor for class io.permazen.kv.raft.msg.CommitResponse
Constructor for success case when a minimum leader lease timeout is required for commit (read-only transaction when leader has not heard from a majority of followers in at least a minimum election timeout.
CommitResponse(int, String, String, long, long, String) - Constructor for class io.permazen.kv.raft.msg.CommitResponse
Constructor for error case.
Committer(KVTransaction) - Constructor for class io.permazen.kv.test.KVDatabaseTest.Committer
 
compact(AtomicKVStore) - Method in class io.permazen.kv.test.AtomicKVStoreTest
 
comparator() - Method in class io.permazen.kv.util.KVNavigableMap
 
comparator() - Method in class io.permazen.kv.util.KVNavigableSet
 
comparator() - Method in class io.permazen.util.ConvertedNavigableMap
 
comparator() - Method in class io.permazen.util.ConvertedNavigableSet
 
comparator() - Method in class io.permazen.util.ImmutableNavigableMap
 
comparator() - Method in class io.permazen.util.ImmutableNavigableSet
 
COMPARATOR - Static variable in class io.permazen.util.ByteUtil
Comparator that compares two byte arrays lexicographically using unsigned values.
compare(byte[], byte[]) - Static method in class io.permazen.kv.KeyRange
Compare two byte[] keys using unsigned lexical ordering, while also accepting null values that represent "positive infinity".
compare(byte[], byte[]) - Method in class io.permazen.kv.mvstore.ByteArrayDataType
 
compare(byte[], byte[]) - Static method in class io.permazen.util.ByteUtil
Compare two byte arrays lexicographically using unsigned values.
compare(ObjId, ObjId) - Method in class io.permazen.core.ObjIdEncoding
 
compare(Tuple, Tuple) - Method in class io.permazen.encoding.TupleEncoding
 
compare(Integer, Integer) - Method in class io.permazen.encoding.UnsignedIntEncoding
 
compare(String, String) - Method in class io.permazen.encoding.StringEncoding
 
compare(BigDecimal, BigDecimal) - Method in class io.permazen.encoding.BigDecimalEncoding
 
compare(BigInteger, BigInteger) - Method in class io.permazen.encoding.BigIntegerEncoding
 
compare(Duration, Duration) - Method in class io.permazen.encoding.DurationEncoding
 
compare(Instant, Instant) - Method in class io.permazen.encoding.InstantEncoding
 
compare(LocalDate, LocalDate) - Method in class io.permazen.encoding.LocalDateEncoding
 
compare(LocalDateTime, LocalDateTime) - Method in class io.permazen.encoding.LocalDateTimeEncoding
 
compare(LocalTime, LocalTime) - Method in class io.permazen.encoding.LocalTimeEncoding
 
compare(MonthDay, MonthDay) - Method in class io.permazen.encoding.MonthDayEncoding
 
compare(Period, Period) - Method in class io.permazen.encoding.PeriodEncoding
 
compare(YearMonth, YearMonth) - Method in class io.permazen.encoding.YearMonthEncoding
 
compare(Year, Year) - Method in class io.permazen.encoding.YearEncoding
 
compare(ZoneOffset, ZoneOffset) - Method in class io.permazen.encoding.ZoneOffsetEncoding
 
compare(BitSet, BitSet) - Method in class io.permazen.encoding.BitSetEncoding
 
compare(Date, Date) - Method in class io.permazen.encoding.DateEncoding
 
compare(UUID, UUID) - Method in class io.permazen.encoding.UUIDEncoding
 
compare(Inet6Address, Inet6Address) - Method in class io.permazen.encoding.Inet6AddressEncoding
 
compare(T, T) - Method in class io.permazen.encoding.ArrayEncoding
 
compare(T, T) - Method in class io.permazen.encoding.ConvertedEncoding
 
compare(T, T) - Method in interface io.permazen.encoding.Encoding
Order two values.
compare(T, T) - Method in class io.permazen.encoding.NullSafeEncoding
 
compare(T, T) - Method in class io.permazen.encoding.PrimitiveEncoding
 
CompareSchemasCommand - Class in io.permazen.cli.cmd
 
CompareSchemasCommand() - Constructor for class io.permazen.cli.cmd.CompareSchemasCommand
 
compareTo(byte[]) - Method in class io.permazen.kv.KeyRange
Determine if this range is left of, contains, or is right of the given key.
compareTo(ObjId) - Method in class io.permazen.core.ObjId
 
compareTo(EncodingId) - Method in class io.permazen.encoding.EncodingId
 
compareTo(Timestamp) - Method in class io.permazen.kv.raft.Timestamp
Compare two instances, where "smaller" means earlier in time.
complete(Collection<String>, String) - Static method in class io.permazen.cli.parse.ParseUtil
Generate completions based on a set of possibilities and the provided input prefix.
complete(Stream<String>, String) - Static method in class io.permazen.cli.parse.ParseUtil
Generate completions based on a set of possibilities and the provided input prefix.
COMPLETED - Enum constant in enum class io.permazen.kv.raft.TxState
The transaction has committed successfully or failed, and is waiting to be cleaned up.
ComplexField<T> - Class in io.permazen.core
A complex Field, such as a collection or map field.
ComplexSchemaField - Class in io.permazen.schema
A complex field in one version of a SchemaObjectType.
ComplexSchemaField() - Constructor for class io.permazen.schema.ComplexSchemaField
 
ComplexSubFieldIndex<C,T> - Class in io.permazen.core
A simple index on a ComplexField sub-field.
COMPOSITE_INDEX - Enum constant in enum class io.permazen.schema.ItemType
 
COMPOSITE_INDEX_TAG - Static variable in class io.permazen.schema.XMLConstants
 
CompositeIndex - Class in io.permazen.core
A composite index on two or more fields in an ObjType.
computeNext() - Method in class io.permazen.kv.mvstore.MVCursorIterator
 
Concat2Encoding<T,V1,V2> - Class in io.permazen.encoding
Support superclass for non-null Encodings of values that can be decomposed into two component values.
Concat2Encoding(Class<T>, Encoding<V1>, Encoding<V2>, Function<? super T, ? extends V1>, Function<? super T, ? extends V2>, BiFunction<? super V1, ? super V2, ? extends T>) - Constructor for class io.permazen.encoding.Concat2Encoding
Constructor.
Concat3Encoding<T,V1,V2,V3> - Class in io.permazen.encoding
Support superclass for non-null Encodings of values that can be decomposed into three component values.
Concat3Encoding(Class<T>, Encoding<V1>, Encoding<V2>, Encoding<V3>, Function<? super T, ? extends V1>, Function<? super T, ? extends V2>, Function<? super T, ? extends V3>, Function<? super Tuple3<V1, V2, V3>, ? extends T>) - Constructor for class io.permazen.encoding.Concat3Encoding
Constructor.
Concat4Encoding<T,V1,V2,V3,V4> - Class in io.permazen.encoding
Support superclass for non-null Encodings of values that can be decomposed into four component values.
Concat4Encoding(Class<T>, Encoding<V1>, Encoding<V2>, Encoding<V3>, Encoding<V4>, Function<? super T, ? extends V1>, Function<? super T, ? extends V2>, Function<? super T, ? extends V3>, Function<? super T, ? extends V4>, Function<? super Tuple4<V1, V2, V3, V4>, ? extends T>) - Constructor for class io.permazen.encoding.Concat4Encoding
Constructor.
Concat5Encoding<T,V1,V2,V3,V4,V5> - Class in io.permazen.encoding
Support superclass for non-null Encodings of values that can be decomposed into four component values.
Concat5Encoding(Class<T>, Encoding<V1>, Encoding<V2>, Encoding<V3>, Encoding<V4>, Encoding<V5>, Function<? super T, ? extends V1>, Function<? super T, ? extends V2>, Function<? super T, ? extends V3>, Function<? super T, ? extends V4>, Function<? super T, ? extends V5>, Function<? super Tuple5<V1, V2, V3, V4, V5>, ? extends T>) - Constructor for class io.permazen.encoding.Concat5Encoding
Constructor.
Config() - Constructor for class io.permazen.kv.mvstore.MVStoreKVImplementation.Config
 
Config() - Constructor for class io.permazen.kv.simple.MemoryKVImplementation.Config
 
Config() - Constructor for class io.permazen.kv.simple.SimpleKVImplementation.Config
 
Config() - Constructor for class io.permazen.kv.sql.SQLDriverKVImplementation.Config
 
Config(File) - Constructor for class io.permazen.kv.raft.RaftKVImplementation.Config
 
Config(File) - Constructor for class io.permazen.kv.simple.XMLKVImplementation.Config
 
Config(File) - Constructor for class io.permazen.kv.sqlite.SQLiteKVImplementation.Config
 
Config(File) - Constructor for class io.permazen.kv.xodus.XodusKVImplementation.Config
 
Config(File, byte[]) - Constructor for class io.permazen.kv.fdb.FoundationKVImplementation.Config
 
Config(File, String) - Constructor for class io.permazen.kv.bdb.BerkeleyKVImplementation.Config
 
Config(File, String) - Constructor for class io.permazen.kv.lmdb.LMDBKVImplementation.Config
 
Config(String) - Constructor for class io.permazen.kv.spanner.SpannerKVImplementation.Config
 
Config(URI) - Constructor for class io.permazen.kv.sql.SQLDriverKVImplementation.Config
 
CONFIG_CHANGE - Enum constant in enum class io.permazen.core.TransactionConfig.SchemaRemoval
Perform automatic schema removal at the start of the very first transaction, and any other transaction configured differently from the previous transaction.
configChange(String, String) - Method in class io.permazen.kv.raft.RaftKVTransaction
Include a cluster configuration change when this transaction is committed.
configure(MVStoreAtomicKVStore) - Method in class io.permazen.kv.mvstore.MVStoreKVImplementation.Config
 
configure(SpannerKVDatabase) - Method in class io.permazen.kv.spanner.SpannerKVImplementation.Config
 
configure(SQLiteKVDatabase) - Method in class io.permazen.kv.sqlite.SQLiteKVImplementation.Config
 
configure(XodusKVDatabase) - Method in class io.permazen.kv.xodus.XodusKVImplementation.Config
 
configure(Log, String[], String[], String) - Method in class io.permazen.SchemaUtilityImpl
 
configureConnection(Connection) - Method in class io.permazen.kv.mssql.MSSQLKVDatabase
 
configureConnection(Connection) - Method in class io.permazen.kv.mysql.MySQLKVDatabase
 
configureConnection(Connection) - Method in class io.permazen.kv.sql.SQLKVDatabase
Configure a newly created Connection.
configureConnection(Connection) - Method in class io.permazen.kv.sqlite.SQLiteKVDatabase
 
configureFallback(KVDatabase) - Method in class io.permazen.kv.raft.RaftKVImplementation.Config
 
configureRaft(AtomicKVStore) - Method in class io.permazen.kv.raft.RaftKVImplementation.Config
 
configureSession(Session) - Method in class io.permazen.cli.config.CliConfig
Configure a new Session.
configureSession(Session) - Method in class io.permazen.cli.config.CoreApiCliConfig
 
configureSession(Session) - Method in class io.permazen.cli.config.KeyValueCliConfig
 
configureSession(Session) - Method in class io.permazen.cli.config.PermazenCliConfig
 
configureTransaction(PermazenTransaction, TransactionDefinition) - Method in class io.permazen.spring.PermazenTransactionManager
Configure a new transaction.
Conflict - Class in io.permazen.kv.mvcc
Represents an MVCC conflict.
connection - Variable in class io.permazen.kv.sql.SQLKVTransaction
 
CONNECTION_FAILED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Network connection failed.
CONNECTION_LEAKED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Connection object leaked.
CONNECTION_STRING_INVALID - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Connection string invalid.
consistency - Variable in class io.permazen.kv.spanner.SpannerKVTransaction
 
Consistency - Enum Class in io.permazen.kv.raft
RaftKVTransaction supported consistency levels.
contains(byte[]) - Method in interface io.permazen.kv.KeyFilter
Determine whether this instance contains the given key.
contains(byte[]) - Method in class io.permazen.kv.KeyRange
Determine if this key range contains the specified key.
contains(byte[]) - Method in class io.permazen.kv.KeyRanges
 
contains(KeyRange) - Method in class io.permazen.kv.KeyRange
Determine if this key range fully contains the specified key range.
contains(KeyRange) - Method in class io.permazen.kv.KeyRanges
Determine whether this instance contains the given KeyRange, i.e., all keys contained by the given KeyRange are also contained by this instance.
contains(KeyRanges) - Method in class io.permazen.kv.KeyRanges
Determine whether this instance contains the given KeyRanges, i.e., all keys contained by the given KeyRanges are also contained by this instance.
contains(Object) - Method in class io.permazen.core.util.ObjIdSet
 
contains(Object) - Method in class io.permazen.kv.util.AbstractKVNavigableSet
 
contains(Object) - Method in class io.permazen.util.ConvertedList
 
contains(Object) - Method in class io.permazen.util.ConvertedNavigableSet
 
contains(Object) - Method in class io.permazen.util.ConvertedSet
 
contains(Object) - Method in class io.permazen.util.ImmutableNavigableSet
 
containsKey(Object) - Method in class io.permazen.core.util.ObjIdMap
 
containsKey(Object) - Method in class io.permazen.kv.util.KVNavigableMap
 
containsKey(Object) - Method in class io.permazen.util.AbstractNavigableMap
 
containsKey(Object) - Method in class io.permazen.util.ImmutableNavigableMap
 
containsSource(ObjId) - Method in class io.permazen.core.util.ObjIdBiMultiMap
Determine if this instance has any targets associated with the specified source.
containsTarget(ObjId) - Method in class io.permazen.core.util.ObjIdBiMultiMap
Determine if this instance has any sources associated with the specified target.
containsValue(Object) - Method in class io.permazen.util.ImmutableNavigableMap
 
context - Variable in class io.permazen.kv.spanner.ReadOnlySpannerView
 
convert(Encoding<S>, S) - Method in class io.permazen.core.ReferenceEncoding
Attempt to convert a value from the given Encoding into a value of this Encoding.
convert(Encoding<S>, S) - Method in class io.permazen.encoding.ArrayEncoding
 
convert(Encoding<S>, S) - Method in class io.permazen.encoding.CharacterArrayEncoding
 
convert(Encoding<S>, S) - Method in class io.permazen.encoding.CharacterEncoding
 
convert(Encoding<S>, S) - Method in interface io.permazen.encoding.Encoding
Attempt to convert a value from the given Encoding into a value of this Encoding.
convert(Encoding<S>, S) - Method in class io.permazen.encoding.NullSafeEncoding
 
convert(Encoding<S>, S) - Method in class io.permazen.encoding.PrimitiveEncoding
 
convert(Encoding<S>, S) - Method in class io.permazen.encoding.StringEncoding
 
convert(String) - Method in class io.permazen.cli.config.JavaNameConverter
 
convert(String) - Method in class io.permazen.kv.fdb.FoundationKVImplementation.PrefixConverter
 
ConvertedEncoding<T,S> - Class in io.permazen.encoding
An Encoding that relies on some other Encoding, converting values to/from the other Encoding's Java type.
ConvertedEncoding(EncodingId, TypeToken<T>, Encoding<S>, Converter<T, S>, boolean) - Constructor for class io.permazen.encoding.ConvertedEncoding
Primary constructor.
ConvertedEncoding(EncodingId, Class<T>, Encoding<S>, Converter<T, S>) - Constructor for class io.permazen.encoding.ConvertedEncoding
Convenience constructor for when the new ConvertedEncoding does not sort naturally.
ConvertedEncoding(EncodingId, Class<T>, Encoding<S>, Converter<T, S>, boolean) - Constructor for class io.permazen.encoding.ConvertedEncoding
Convenience constructor taking Class instead of TypeToken.
ConvertedList<E,W> - Class in io.permazen.util
Provides a transformed view of a wrapped List using a strictly invertable Converter.
ConvertedList(List<W>, Converter<E, W>) - Constructor for class io.permazen.util.ConvertedList
Constructor.
ConvertedNavigableMap<K,V,WK,WV> - Class in io.permazen.util
Provides a transformed view of a wrapped NavigableMap using a strictly invertible Converter.
ConvertedNavigableMap(NavigableMap<WK, WV>, Converter<K, WK>, Converter<V, WV>) - Constructor for class io.permazen.util.ConvertedNavigableMap
Constructor.
ConvertedNavigableSet<E,W> - Class in io.permazen.util
Provides a transformed view of a wrapped NavigableSet using a strictly invertable Converter.
ConvertedNavigableSet(NavigableSet<W>, Converter<E, W>) - Constructor for class io.permazen.util.ConvertedNavigableSet
Constructor.
ConvertedSet<E,W> - Class in io.permazen.util
Provides a transformed view of a wrapped Set using a strictly invertable Converter.
ConvertedSet(Set<W>, Converter<E, W>) - Constructor for class io.permazen.util.ConvertedSet
Constructor.
ConvertedSpliterator<E,W> - Class in io.permazen.util
Provides a transformed view of a wrapped ConvertedSpliterator using a strictly invertable Converter.
ConvertedSpliterator(Spliterator<W>, Converter<W, E>) - Constructor for class io.permazen.util.ConvertedSpliterator
Constructor.
converter - Variable in class io.permazen.encoding.ConvertedEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.BooleanEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.ByteEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.CharacterEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.DoubleEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.FloatEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.IntegerEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.LongEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.PrimitiveEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.ShortEncoding
 
convertNumber(Number) - Method in class io.permazen.encoding.VoidEncoding
 
COORDINATED_STATE_CONFLICT - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Conflict occurred while changing coordination information.
COORDINATORS_CHANGED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Coordination servers have changed.
copy() - Method in class io.permazen.core.TransactionConfig
Create a TransactionConfig.Builder that is pre-configured as a copy of this instance.
copy() - Method in class io.permazen.core.util.XMLObjectSerializer.OutputOptions
Create a XMLObjectSerializer.OutputOptions.Builder that is pre-configured as a copy of this instance.
copy(ObjId, Transaction, boolean, boolean, ObjIdMap<ReferenceField>, ObjIdMap<ObjId>) - Method in class io.permazen.core.Transaction
Copy an object into a (possibly different) transaction.
copyCachingConfigTo(CachingConfig) - Method in interface io.permazen.kv.caching.CachingConfig
Copy config parameters.
copyIn(String...) - Method in interface io.permazen.PermazenObject
Copy this instance, and other instances reachable through the specified reference cascades (if any), into the transaction associated with the current thread.
copyMetaData(KVStore, KVStore) - Static method in class io.permazen.core.Layout
Copy non-object meta-data from one KVStore to another.
copyOut(String...) - Method in interface io.permazen.PermazenObject
Copy this instance, and other instances reachable through the specified reference cascades (if any), into the in-memory, detached transaction associated with this instance's transaction.
CopyState - Class in io.permazen
Holds state during a multi-object copy operation.
CopyState(boolean) - Constructor for class io.permazen.CopyState
Simple constructor.
CopyState(CopyState) - Constructor for class io.permazen.CopyState
Copy constructor.
CopyState(ObjIdMap<ObjId>, boolean) - Constructor for class io.permazen.CopyState
Remapping constructor.
CopyState(ObjIdSet, ObjIdMap<ObjId>, boolean) - Constructor for class io.permazen.CopyState
Primary constructor.
copyTo(PermazenTransaction, int, CopyState, String...) - Method in interface io.permazen.PermazenObject
Copy this instance, and other instances it references through the specified reference cascades, into the specified destination transaction.
copyTo(PermazenTransaction, CopyState, ObjIdSet) - Method in class io.permazen.PermazenTransaction
Copy the specified objects into the specified destination transaction.
copyTo(PermazenTransaction, CopyState, Stream<? extends PermazenObject>) - Method in class io.permazen.PermazenTransaction
Copy the specified objects into the specified destination transaction.
CORE_API - Enum constant in enum class io.permazen.cli.SessionMode
Permazen Core API mode.
CoreApiCliConfig - Class in io.permazen.cli.config
Configuration for a CLI application supporting Core API database interaction.
CoreApiCliConfig() - Constructor for class io.permazen.cli.config.CoreApiCliConfig
 
CoreIndex1<V,T> - Class in io.permazen.core
Core API Index1 implementation representing an index on a single field.
CoreIndex2<V1,V2,T> - Class in io.permazen.core
Core API Index2 implementation representing a composite index on two fields.
CoreIndex3<V1,V2,V3,T> - Class in io.permazen.core
Core API Index3 implementation representing a composite index on three fields.
CoreIndex4<V1,V2,V3,V4,T> - Class in io.permazen.core
Core API Index4 implementation representing a composite index on four fields.
Counter - Class in io.permazen
Represents a 64-bit counter value that can be adjusted concurrently by multiple transactions, typically without locking (depending on the underlying key/value store).
COUNTER_FIELD - Enum constant in enum class io.permazen.schema.ItemType
 
COUNTER_FIELD_TAG - Static variable in class io.permazen.schema.XMLConstants
 
CounterField - Class in io.permazen.core
Counter fields.
CounterSchemaField - Class in io.permazen.schema
A counter field in a SchemaObjectType.
CounterSchemaField() - Constructor for class io.permazen.schema.CounterSchemaField
 
create(ObjId) - Method in class io.permazen.core.Transaction
Create a new object with the given object ID, if it doesn't already exist.
create(ObjId, SchemaId) - Method in class io.permazen.core.Transaction
Create a new object with the given object ID, if it doesn't already exist.
create(Transaction) - Method in class io.permazen.core.ObjType
Create a new database object of this type in the given transaction.
create(KVStore, byte[]) - Static method in class io.permazen.kv.util.PrefixKVStore
Create a PrefixKVStore instance using the specified prefix and underlying KVStore.
create(SQLKVDatabase, Connection, Logger) - Method in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
create(PermazenClass<T>) - Method in class io.permazen.PermazenTransaction
Create a new instance of the given type in this transaction.
create(Class<T>) - Method in class io.permazen.PermazenTransaction
Create a new instance of the given model class in this transaction.
create(String) - Method in class io.permazen.core.Transaction
Create a new object with a randomly assigned object ID and having the given type.
create(String, SchemaId) - Method in class io.permazen.core.Transaction
Create a new object with a randomly assigned object ID and having the given type and schema.
createArray(List<E>) - Method in class io.permazen.encoding.ArrayEncoding
Create a new array instance containing the given elements.
createArray(List<E>) - Method in class io.permazen.encoding.ObjectArrayEncoding
 
createArray(List<Boolean>) - Method in class io.permazen.encoding.BooleanArrayEncoding
 
createArray(List<Byte>) - Method in class io.permazen.encoding.ByteArrayEncoding
 
createArray(List<Character>) - Method in class io.permazen.encoding.CharacterArrayEncoding
 
createArray(List<Double>) - Method in class io.permazen.encoding.DoubleArrayEncoding
 
createArray(List<Float>) - Method in class io.permazen.encoding.FloatArrayEncoding
 
createArray(List<Integer>) - Method in class io.permazen.encoding.IntegerArrayEncoding
 
createArray(List<Long>) - Method in class io.permazen.encoding.LongArrayEncoding
 
createArray(List<Short>) - Method in class io.permazen.encoding.ShortArrayEncoding
 
createAtomicKVStore(C) - Method in interface io.permazen.kv.KVImplementation
Create an AtomicKVStore using the specified configuration.
createAtomicKVStore(MVStoreKVImplementation.Config) - Method in class io.permazen.kv.mvstore.MVStoreKVImplementation
 
createAtomicKVStore(MemoryKVImplementation.Config) - Method in class io.permazen.kv.simple.MemoryKVImplementation
 
createAtomicKVStore(File) - Method in class io.permazen.kv.array.ArrayKVImplementation
 
createAtomicKVStore(File) - Method in class io.permazen.kv.leveldb.LevelDBKVImplementation
 
createAtomicKVStore(File) - Method in class io.permazen.kv.test.AtomicKVStoreTest
 
createAvailabilityCheckTransaction(RaftKVDatabase) - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Create a Raft availability check transaction.
createBranchedTransaction() - Method in class io.permazen.Permazen
Open a new branched transaction.
createBranchedTransaction(ValidationMode) - Method in class io.permazen.Permazen
Open a new branched transaction using the specified ValidationMode.
createBranchedTransaction(ValidationMode, Map<String, ?>, Map<String, ?>) - Method in class io.permazen.Permazen
Open a new branched transaction using the specified ValidationMode and key/value transaction options.
createClasspath() - Method in class io.permazen.ant.SchemaGeneratorTask
 
createDestinationTransaction(RaftKVDatabase) - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Create a Raft destination transaction.
createDetachedTransaction() - Method in class io.permazen.core.Transaction
Create an in-memory detached transaction.
createDetachedTransaction(KVStore, TransactionConfig) - Method in class io.permazen.core.Database
Create a detached transaction based on the provided key/value store.
createDetachedTransaction(KVStore, ValidationMode) - Method in class io.permazen.Permazen
Create a new DetachedPermazenTransaction based on the provided key/value store.
createDetachedTransaction(ValidationMode) - Method in class io.permazen.Permazen
Create a new, empty DetachedPermazenTransaction backed by a MemoryKVStore.
createDetachedTransaction(ValidationMode) - Method in class io.permazen.PermazenTransaction
Create a new, empty detached transaction.
createEnumArrayConverter(Class<? extends Enum<?>>, int) - Static method in class io.permazen.EnumConverter
Create a Converter for arrays based on converting the base elements with an EnumConverter.
createEnumConverter(Class<? extends Enum<?>>) - Static method in class io.permazen.EnumConverter
Convenience "constructor" allowing wildcard caller Enum types.
createExecutorThread(Runnable, int) - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Create the service thread used by this instance.
createGetAllStatement(boolean) - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that reads all of the key and value columns (in that order), possibly reversed.
createGetAtLeastStatement(boolean) - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that reads the key and value columns (in that order) associated with the smallest key greater than or equal to ?1, if any.
createGetAtMostStatement(boolean) - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that reads the key and value columns (in that order) associated with the greatest key strictly less than ?1, if any.
createGetRangeStatement(boolean) - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that reads the key and value columns (in that order) associated with all keys in the range ?1 (inclusive) to ?2 (exclusive), possibly reversed.
createGetStatement() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that reads the value column associated with key ?1.
createKVDatabase(C, KVDatabase, AtomicKVStore) - Method in interface io.permazen.kv.KVImplementation
Create an KVDatabase using the specified configuration.
createKVDatabase(C, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.sql.SQLDriverKVImplementation
 
createKVDatabase(BerkeleyKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.bdb.BerkeleyKVImplementation
 
createKVDatabase(FoundationKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.fdb.FoundationKVImplementation
 
createKVDatabase(LMDBKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.lmdb.LMDBKVImplementation
 
createKVDatabase(MVStoreKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.mvstore.MVStoreKVImplementation
 
createKVDatabase(RaftKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.raft.RaftKVImplementation
 
createKVDatabase(MemoryKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.simple.MemoryKVImplementation
 
createKVDatabase(SimpleKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.simple.SimpleKVImplementation
 
createKVDatabase(XMLKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.simple.XMLKVImplementation
 
createKVDatabase(SpannerKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.spanner.SpannerKVImplementation
 
createKVDatabase(SQLiteKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.sqlite.SQLiteKVImplementation
 
createKVDatabase(XodusKVImplementation.Config, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.xodus.XodusKVImplementation
 
createKVDatabase(File, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.array.ArrayKVImplementation
 
createKVDatabase(File, KVDatabase, AtomicKVStore) - Method in class io.permazen.kv.leveldb.LevelDBKVImplementation
 
createKVStore(Dbi<byte[]>, Txn<byte[]>) - Method in class io.permazen.kv.lmdb.ByteArrayLMDBKVTransaction
 
createKVStore(Dbi<T>, Txn<T>) - Method in class io.permazen.kv.lmdb.LMDBKVTransaction
 
createKVTransaction(KVDatabase) - Method in class io.permazen.kv.test.KVTestSupport
 
CreateListener - Interface in io.permazen.core
Listener interface for notifications that an object has just been created.
createLocalExecutionControl(MemoryLoaderDelegate) - Method in class io.permazen.cli.jshell.PermazenExecutionControlProvider
 
createMemoryClassLoader() - Method in class io.permazen.cli.jshell.PermazenExecutionControlProvider
 
createOptionParser(int) - Method in class io.permazen.cli.config.CliConfig
Create the OptionParser to be used to parse command line options.
createPermazenExecSession(ExecRequest, SimpleCommandSupport.FoundCommand) - Method in class io.permazen.cli.PermazenExec
 
createPermazenShellSession(ShellRequest, LineReader) - Method in class io.permazen.cli.PermazenShell
 
createPutStatement() - Method in class io.permazen.kv.cockroach.CockroachKVDatabase
 
createPutStatement() - Method in class io.permazen.kv.mssql.MSSQLKVDatabase
 
createPutStatement() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that inserts the key/value pair with key ?1 and value ?2 A row with key ?1 may already exist; if so, the value should be updated to ?2 (if syntax requires it, the value may be updated to ?3 instead; ?3, if it exists, will be set to the same value as ?2).
createPutStatement() - Method in class io.permazen.kv.sqlite.SQLiteKVDatabase
 
createRemoveAllStatement() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that deletes all rows.
createRemoveAtLeastStatement() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that deletes all rows with keys greater than or equal to ?1.
createRemoveAtMostStatement() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that deletes all rows with keys strictly less than ?1.
createRemoveRangeStatement() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that deletes all rows with keys in the range ?1 (inclusive} to ?2 (exclusive).
createRemoveStatement() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create an SQL statement that deletes the row associated with key ?1, if any.
createSession(PermazenExecSession) - Method in class io.permazen.cli.PermazenExec
 
createSession(PermazenShellSession) - Method in class io.permazen.cli.PermazenShell
 
createSnapshotKVTransaction(MutableView, long) - Method in class io.permazen.kv.array.ArrayKVDatabase
 
createSnapshotKVTransaction(MutableView, long) - Method in class io.permazen.kv.leveldb.LevelDBKVDatabase
 
createSnapshotKVTransaction(MutableView, long) - Method in class io.permazen.kv.mvcc.SnapshotKVDatabase
Instantiate a new SnapshotKVTransaction instance.
createSnapshotKVTransaction(MutableView, long) - Method in class io.permazen.kv.mvstore.MVStoreKVDatabase
 
createSnapshotTransaction() - Method in class io.permazen.core.Transaction
Create a detached transaction pre-populated with a snapshot of this transaction.
createSnapshotTransaction(ValidationMode) - Method in class io.permazen.PermazenTransaction
Create a new detached transaction pre-populated with a snapshot of this transaction.
createSourceTransaction(RaftKVDatabase) - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Create a Raft source transaction.
createSQLKVDatabase(C) - Method in class io.permazen.kv.sql.SQLDriverKVImplementation
Instantiate a SQLKVDatabase.
createSQLKVDatabase(SQLDriverKVImplementation.Config) - Method in class io.permazen.kv.cockroach.CockroachKVImplementation
 
createSQLKVDatabase(SQLDriverKVImplementation.Config) - Method in class io.permazen.kv.mssql.MSSQLKVImplementation
 
createSQLKVDatabase(SQLDriverKVImplementation.Config) - Method in class io.permazen.kv.mysql.MySQLKVImplementation
 
createSQLKVTransaction(Connection) - Method in class io.permazen.kv.cockroach.CockroachKVDatabase
 
createSQLKVTransaction(Connection) - Method in class io.permazen.kv.mssql.MSSQLKVDatabase
 
createSQLKVTransaction(Connection) - Method in class io.permazen.kv.mysql.MySQLKVDatabase
 
createSQLKVTransaction(Connection) - Method in class io.permazen.kv.sql.SQLKVDatabase
Create a new SQLKVTransaction for a new transaction given the specified Connection.
createStorage(int) - Method in class io.permazen.kv.mvstore.ByteArrayDataType
 
createSubMap(boolean, KeyRange, KeyFilter, Bounds<byte[]>) - Method in class io.permazen.kv.util.KVNavigableMap
 
createSubMap(boolean, KeyRange, KeyFilter, Bounds<K>) - Method in class io.permazen.kv.util.AbstractKVNavigableMap
Create a (possibly reversed) view of this instance with (possibly) tighter lower and/or upper bounds and the given KeyFilter, if any.
createSubMap(boolean, Bounds<K>) - Method in class io.permazen.kv.util.AbstractKVNavigableMap
 
createSubMap(boolean, Bounds<K>) - Method in class io.permazen.util.AbstractNavigableMap
Create a (possibly reversed) view of this instance with (possibly) tighter lower and/or upper bounds.
createSubMap(boolean, Bounds<K>) - Method in class io.permazen.util.ConvertedNavigableMap
 
createSubMap(boolean, Bounds<K>) - Method in class io.permazen.util.ImmutableNavigableMap
 
createSubSet(boolean, KeyRange, KeyFilter, Bounds<byte[]>) - Method in class io.permazen.kv.util.KVNavigableSet
 
createSubSet(boolean, KeyRange, KeyFilter, Bounds<E>) - Method in class io.permazen.kv.util.AbstractKVNavigableSet
Create a (possibly reversed) view of this instance with (possibly) tighter lower and/or upper bounds and the given KeyFilter, if any.
createSubSet(boolean, Bounds<E>) - Method in class io.permazen.kv.util.AbstractKVNavigableSet
 
createSubSet(boolean, Bounds<E>) - Method in class io.permazen.util.AbstractNavigableSet
Create a (possibly reversed) view of this instance with (possibly) tighter lower and/or upper bounds.
createSubSet(boolean, Bounds<E>) - Method in class io.permazen.util.ConvertedNavigableSet
 
createSubSet(boolean, Bounds<E>) - Method in class io.permazen.util.ImmutableNavigableSet
 
createTempDirectory() - Method in class io.permazen.test.TestSupport
 
createTransaction() - Method in class io.permazen.kv.array.ArrayKVDatabase
 
createTransaction() - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
 
createTransaction() - Method in class io.permazen.kv.caching.CachingKVDatabase
 
createTransaction() - Method in class io.permazen.kv.fdb.FoundationKVDatabase
 
createTransaction() - Method in interface io.permazen.kv.KVDatabase
Create a new transaction.
createTransaction() - Method in class io.permazen.kv.leveldb.LevelDBKVDatabase
 
createTransaction() - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
 
createTransaction() - Method in class io.permazen.kv.mvcc.SnapshotKVDatabase
Create a new transaction.
createTransaction() - Method in class io.permazen.kv.mvstore.MVStoreKVDatabase
 
createTransaction() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
 
createTransaction() - Method in class io.permazen.kv.raft.RaftKVDatabase
Create a new transaction.
createTransaction() - Method in class io.permazen.kv.simple.SimpleKVDatabase
 
createTransaction() - Method in class io.permazen.kv.simple.XMLKVDatabase
 
createTransaction() - Method in class io.permazen.kv.spanner.SpannerKVDatabase
 
createTransaction() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create a new transaction.
createTransaction() - Method in class io.permazen.kv.util.PrefixKVDatabase
 
createTransaction() - Method in class io.permazen.kv.xodus.XodusKVDatabase
 
createTransaction() - Method in class io.permazen.Permazen
Open a new transaction.
createTransaction(TimestampBound) - Method in class io.permazen.kv.spanner.SpannerKVDatabase
 
createTransaction(TransactionConfig) - Method in class io.permazen.core.Database
Create a new Transaction on this database using the specific configuration.
createTransaction(KVTransaction, TransactionConfig) - Method in class io.permazen.core.Database
Create a new Transaction on this database using an already-opened KVTransaction and specified configuration.
createTransaction(KVTransaction, ValidationMode) - Method in class io.permazen.Permazen
Create a new PermazenTransaction using an already-opened KVTransaction.
createTransaction(Consistency) - Method in class io.permazen.kv.raft.RaftKVDatabase
Create a new transaction with the specified consistency.
createTransaction(Consistency, boolean) - Method in class io.permazen.kv.raft.RaftKVDatabase
Create a new transaction with the specified consistency and with optional high priority.
createTransaction(SchemaModel) - Method in class io.permazen.core.Database
Create a new Transaction on this database using the given SchemaModel and the defaults for all other TransactionConfig items.
createTransaction(ValidationMode) - Method in class io.permazen.Permazen
Open a new transaction using the specified ValidationMode.
createTransaction(ValidationMode, Map<String, ?>) - Method in class io.permazen.Permazen
Open a new transaction using the specified ValidationMode and key/value transaction options.
createTransaction(Supplier<? extends KVTransaction>) - Method in class io.permazen.kv.caching.CachingKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.caching.CachingKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.fdb.FoundationKVDatabase
 
createTransaction(Map<String, ?>) - Method in interface io.permazen.kv.KVDatabase
Create a new transaction with the specified options.
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.mvcc.SnapshotKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.raft.RaftKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.simple.SimpleKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.spanner.SpannerKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.sql.SQLKVDatabase
Create a new transaction.
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.util.PrefixKVDatabase
 
createTransaction(Map<String, ?>) - Method in class io.permazen.kv.xodus.XodusKVDatabase
 
createTransaction(Map<String, Object>) - Method in class io.permazen.spring.PermazenTransactionManager
Create the underlying PermazenTransaction for a new transaction.
createTransactionConnection() - Method in class io.permazen.kv.sql.SQLKVDatabase
Create a Connection for a new transaction.
createTuple(Iterable<?>) - Static method in class io.permazen.tuple.Tuples
Create a Tuple of the appropriate cardinality for the given number of objects.
createTuple(Object[]) - Method in class io.permazen.encoding.Tuple2Encoding
 
createTuple(Object[]) - Method in class io.permazen.encoding.Tuple3Encoding
 
createTuple(Object[]) - Method in class io.permazen.encoding.Tuple4Encoding
 
createTuple(Object[]) - Method in class io.permazen.encoding.Tuple5Encoding
 
createTuple(Object[]) - Method in class io.permazen.encoding.TupleEncoding
 
createTuple(Object...) - Static method in class io.permazen.tuple.Tuples
Create a Tuple of the appropriate cardinality for the given number of objects.
CSTRING_PATTERN - Static variable in class io.permazen.cli.cmd.AbstractKVCommand
Matches the doubly-quoted C strings returnd by toCString().
CURRENT_FORMAT_VERSION - Static variable in class io.permazen.core.Layout
The current Database layout format version (1).
CursorIterator - Class in io.permazen.kv.mvstore
KVPair iterator based on an underlying Cursor.
CursorIterator(MVMap<byte[], byte[]>, byte[], byte[], boolean) - Constructor for class io.permazen.kv.mvstore.CursorIterator
Constructor.
customEncodingRegistries - Variable in class io.permazen.encoding.DefaultEncodingRegistry
 

D

database - Variable in class io.permazen.kv.sql.SQLKVTransaction
 
database(Database) - Method in class io.permazen.PermazenConfig.Builder
Configure the underlying Database.
Database - Class in io.permazen.core
Provides an object database abstraction on top of a key/value database.
Database(KVDatabase) - Constructor for class io.permazen.core.Database
Constructor.
DATABASE_LOCKED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Database is locked.
DATABASE_TAG - Static variable in class io.permazen.core.util.XMLObjectSerializer
 
DatabaseException - Exception in io.permazen.core
Superclass of all unchecked exceptions thrown by a Database.
DatabaseException() - Constructor for exception io.permazen.core.DatabaseException
 
DatabaseException(String) - Constructor for exception io.permazen.core.DatabaseException
 
DatabaseException(String, Throwable) - Constructor for exception io.permazen.core.DatabaseException
 
DatabaseException(Throwable) - Constructor for exception io.permazen.core.DatabaseException
 
dataSource - Variable in class io.permazen.kv.sql.SQLKVDatabase
 
DateEncoding - Class in io.permazen.encoding
Non-null Date type.
DateEncoding() - Constructor for class io.permazen.encoding.DateEncoding
 
db - Variable in class io.permazen.cli.config.CoreApiCliConfig
 
db - Variable in class io.permazen.cli.PermazenExec
 
db - Variable in class io.permazen.cli.PermazenShell
 
DB_FACTORY_PROPERTY - Static variable in class io.permazen.kv.leveldb.LevelDBUtil
The name of a system property that can be set to override the default DBFactory logic.
decode(byte[]) - Method in interface io.permazen.encoding.Encoding
Decode a valid from the given byte[] array.
decode(byte[]) - Static method in class io.permazen.util.LongEncoder
Decode the given value.
decode(byte[]) - Static method in class io.permazen.util.UnsignedIntEncoder
Decode the given value.
decode(Transaction, byte[]) - Static method in class io.permazen.cli.cmd.DecodeKeyCommand
Decode a key/value in the context of a Transaction.
decode(ByteReader) - Method in class io.permazen.kv.util.AbstractKVNavigableSet
Decode an element from a byte[] key.
decode(ByteReader) - Method in class io.permazen.kv.util.KVNavigableSet
 
decode(DataInputStream, int) - Method in class io.permazen.encoding.Base64ArrayEncoding
 
decode(DataInputStream, int) - Method in class io.permazen.encoding.ByteArrayEncoding
 
decode(DataInputStream, int) - Method in class io.permazen.encoding.DoubleArrayEncoding
 
decode(DataInputStream, int) - Method in class io.permazen.encoding.FloatArrayEncoding
 
decode(DataInputStream, int) - Method in class io.permazen.encoding.IntegerArrayEncoding
 
decode(DataInputStream, int) - Method in class io.permazen.encoding.LongArrayEncoding
 
decode(DataInputStream, int) - Method in class io.permazen.encoding.ShortArrayEncoding
 
decode(ByteBuffer, int) - Static method in class io.permazen.kv.raft.msg.Message
Decode a message from the given input.
decodeCounter(byte[]) - Method in class io.permazen.kv.AbstractKVStore
 
decodeCounter(byte[]) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
decodeCounter(byte[]) - Method in class io.permazen.kv.caching.CachingKVTransaction
 
decodeCounter(byte[]) - Static method in class io.permazen.kv.fdb.FoundationKVDatabase
Decode a 64 bit counter value.
decodeCounter(byte[]) - Method in class io.permazen.kv.fdb.FoundationKVStore
 
decodeCounter(byte[]) - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
decodeCounter(byte[]) - Method in interface io.permazen.kv.KVStore
Decode a counter value previously encoded by encodeCounter().
decodeCounter(byte[]) - Method in class io.permazen.kv.mvcc.AtomicKVDatabase
 
decodeCounter(byte[]) - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
decodeCounter(byte[]) - Method in class io.permazen.kv.mvcc.MutableView
 
decodeCounter(byte[]) - Method in class io.permazen.kv.raft.RaftKVTransaction
 
decodeCounter(byte[]) - Method in class io.permazen.kv.util.ForwardingKVStore
 
decodeKey(byte[]) - Method in class io.permazen.kv.sql.SQLKVTransaction
Decode the given database key value encoded by encodeKey().
decodeKey(ByteReader) - Method in class io.permazen.kv.util.AbstractKVNavigableMap
Decode a key object from an encoded byte[] key.
decodeKey(ByteReader) - Method in class io.permazen.kv.util.KVNavigableMap
 
DecodeKeyCommand - Class in io.permazen.cli.cmd
 
DecodeKeyCommand() - Constructor for class io.permazen.cli.cmd.DecodeKeyCommand
 
decodeLength(int) - Static method in class io.permazen.util.LongEncoder
Determine the length (in bytes) of an encoded value based on the first byte.
decodeLength(int) - Static method in class io.permazen.util.UnsignedIntEncoder
Determine the length (in bytes) of an encoded value based on the first byte.
decodePair(KVPair, ByteReader) - Method in class io.permazen.kv.util.AbstractKVIterator
Decode an iteration element from a key/value pair.
decodeProtocolVersion(ByteBuffer) - Static method in class io.permazen.kv.raft.msg.Message
Read the protocol version number header from the message encoded in the given input.
decodeSchema(ByteReader) - Static method in class io.permazen.core.Layout
Decode schema XML from a schema table entry.
decodeValue(KVPair) - Method in class io.permazen.kv.util.AbstractKVNavigableMap
Decode a value object from an encoded byte[] key/value pair.
decodeValue(KVPair) - Method in class io.permazen.kv.util.KVNavigableMap
 
decrement() - Method in class io.permazen.Counter
Decrement this counter's value by one.
DEFAULT_CAPACITY - Static variable in class io.permazen.kv.util.KeyWatchTracker
Default capacity (10000L).
DEFAULT_CHECK_INTERVAL - Static variable in class io.permazen.kv.raft.fallback.FallbackTarget
Default check interval (2000ms).
DEFAULT_COMMIT_TIMEOUT - Static variable in class io.permazen.kv.raft.RaftKVDatabase
Default transaction commit timeout (5000).
DEFAULT_COMPACTION_HIGH_WATER - Static variable in class io.permazen.kv.array.AtomicArrayKVStore
Default compaction space high-water mark in bytes (1073741824 bytes).
DEFAULT_COMPACTION_LOW_WATER - Static variable in class io.permazen.kv.array.AtomicArrayKVStore
Default compaction space low-water mark in bytes (65536 bytes).
DEFAULT_COMPACTION_MAX_DELAY - Static variable in class io.permazen.kv.array.AtomicArrayKVStore
Default compaction maximum delay in seconds (86400 seconds).
DEFAULT_DATABASE_ID - Static variable in class io.permazen.kv.spanner.SpannerKVDatabase
Default database ID: "permazen".
DEFAULT_DATABASE_NAME - Static variable in class io.permazen.kv.bdb.BerkeleyKVDatabase
Default Berkeley DB database name ("Permazen").
DEFAULT_DATABASE_NAME - Static variable in class io.permazen.kv.lmdb.LMDBKVDatabase
Default LMDB database name ("permazen").
DEFAULT_ERROR_MESSAGE_PREFIX - Static variable in class io.permazen.cli.Session
Default error message prefix.
DEFAULT_ERROR_OR - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Default error for an ErrorOr object.
DEFAULT_HEARTBEAT_TIMEOUT - Static variable in class io.permazen.kv.raft.RaftKVDatabase
Default heartbeat timeout (200ms).
DEFAULT_HOLD_TIMEOUT - Static variable in class io.permazen.kv.simple.SimpleKVDatabase
Default hold timeout in milliseconds (5000L).
DEFAULT_INITIAL_RETRY_DELAY - Static variable in class io.permazen.cli.Session
Default value for the initial retry delay (in milliseconds).
DEFAULT_INITIAL_RTT_ESTIMATE_MILLIS - Static variable in class io.permazen.kv.caching.CachingKVDatabase
Default for the initial round-trip time estimate in milliseconds.
DEFAULT_KEY_COLUMN_NAME - Static variable in class io.permazen.kv.sql.SQLKVDatabase
Default key column name ("kv_key").
DEFAULT_LARGE_KEYS - Static variable in class io.permazen.kv.mssql.MSSQLKVDatabase
 
DEFAULT_LARGE_VALUES - Static variable in class io.permazen.kv.mssql.MSSQLKVDatabase
 
DEFAULT_LOCK_TIMEOUT - Static variable in class io.permazen.kv.mssql.MSSQLKVDatabase
 
DEFAULT_LOG_LEVEL - Static variable in class io.permazen.cli.app.CliMain
 
DEFAULT_MAP_NAME - Static variable in class io.permazen.kv.mvstore.MVStoreKVImplementation
Default MVStore map name to use ("Permazen").
DEFAULT_MAX_ELECTION_TIMEOUT - Static variable in class io.permazen.kv.raft.RaftKVDatabase
Default maximum election timeout (1000ms).
DEFAULT_MAX_RANGE_BYTES - Static variable in interface io.permazen.kv.caching.CachingConfig
Default maximum number of bytes to cache in a single contiguous range of key/value pairs (10485760L).
DEFAULT_MAX_RANGE_BYTES - Static variable in class io.permazen.kv.caching.CachingKVStore
Default maximum number of bytes to cache in a single contiguous range of key/value pairs (10485760L).
DEFAULT_MAX_RANGES - Static variable in interface io.permazen.kv.caching.CachingConfig
Default maximum number of contiguous ranges of key/value pairs to allow before we start purging the least recently used ones (256).
DEFAULT_MAX_RANGES - Static variable in class io.permazen.kv.caching.CachingKVStore
Default maximum number of contiguous ranges of key/value pairs to allow before we start purging the least recently used ones (256).
DEFAULT_MAX_RETRIES - Static variable in class io.permazen.cli.Session
Default value for the maximum number of retry attempts.
DEFAULT_MAX_TOTAL_BYTES - Static variable in interface io.permazen.kv.caching.CachingConfig
Default maximum total number of bytes to cache including all ranges (104857600L).
DEFAULT_MAX_TOTAL_BYTES - Static variable in class io.permazen.kv.caching.CachingKVStore
Default maximum total number of bytes to cache including all ranges (104857600L).
DEFAULT_MAX_TRANSACTION_DURATION - Static variable in class io.permazen.kv.raft.RaftKVDatabase
Default maximum supported outstanding transaction duration (5000ms).
DEFAULT_MAXIMUM_LIFETIME - Static variable in class io.permazen.kv.util.KeyWatchTracker
Default maximum lifetime in seconds (2592000L).
DEFAULT_MAXIMUM_RETRY_DELAY - Static variable in class io.permazen.cli.Session
Default value for the maximum retry delay (in milliseconds).
DEFAULT_MIME_TYPE - Static variable in class io.permazen.spring.KVStoreHttpMessageConverter
Default MIME type supported by this instance: application/x-permazen-kvstore.
DEFAULT_MIN_AVAILABLE_TIME - Static variable in class io.permazen.kv.raft.fallback.FallbackTarget
Default minimum available type (10000ms).
DEFAULT_MIN_ELECTION_TIMEOUT - Static variable in class io.permazen.kv.raft.RaftKVDatabase
Default minimum election timeout (750ms).
DEFAULT_MIN_UNAVAILABLE_TIME - Static variable in class io.permazen.kv.raft.fallback.FallbackTarget
Default minimum unavailable type (30000ms).
DEFAULT_PAGE_SIZE - Static variable in class io.permazen.util.NavigableSetPager
Default page size (100).
DEFAULT_READ_AHEAD - Static variable in interface io.permazen.kv.caching.CachingConfig
Default for whether read-ahead is enabled.
DEFAULT_SCHEMA - Static variable in class io.permazen.kv.mssql.MSSQLKVDatabase
 
DEFAULT_STORE_NAME - Static variable in class io.permazen.kv.xodus.XodusKVDatabase
Default Xodus store name ("permazen").
DEFAULT_TABLE_NAME - Static variable in class io.permazen.kv.spanner.SpannerKVDatabase
Default table name: "KV".
DEFAULT_TABLE_NAME - Static variable in class io.permazen.kv.sql.SQLKVDatabase
Default table name ("KV").
DEFAULT_TCP_PORT - Static variable in class io.permazen.kv.raft.RaftKVDatabase
Default TCP port (9660) used to communicate with peers.
DEFAULT_THREAD_POOL_SIZE - Static variable in class io.permazen.kv.caching.CachingKVDatabase
Default thread pool size when no ExecutorService is explicitly configured.
DEFAULT_THREAD_POOL_SIZE - Static variable in class io.permazen.kv.spanner.SpannerKVDatabase
Default background task thread pool size.
DEFAULT_TRANSACTION_TIMEOUT - Static variable in class io.permazen.kv.raft.fallback.FallbackTarget
Default transaction timeout for assessing availability (1000ms).
DEFAULT_VALIDATION_MODE - Static variable in class io.permazen.spring.PermazenTransactionManager
The default ValidationMode to use for transactions (ValidationMode.AUTOMATIC).
DEFAULT_VALUE_COLUMN_NAME - Static variable in class io.permazen.kv.sql.SQLKVDatabase
Default value column name ("kv_value").
DEFAULT_WAIT_FACTOR - Static variable in interface io.permazen.kv.caching.CachingConfig
Default wait factor (1.5).
DEFAULT_WAIT_TIMEOUT - Static variable in class io.permazen.kv.simple.SimpleKVDatabase
Default wait timeout for newly created transactions in milliseconds (500L).
DEFAULT_WEAK_REFERENCE - Static variable in class io.permazen.kv.util.KeyWatchTracker
Default for the weak reference option (false).
DefaultEncodingRegistry - Class in io.permazen.encoding
Permazen's default EncodingRegistry.
DefaultEncodingRegistry() - Constructor for class io.permazen.encoding.DefaultEncodingRegistry
Constructor.
delegate - Variable in class io.permazen.encoding.ConvertedEncoding
 
delegate() - Method in class io.permazen.kv.leveldb.LevelDBAtomicKVStore
 
delegate() - Method in class io.permazen.kv.lmdb.LMDBKVTransaction
 
delegate() - Method in class io.permazen.kv.mvcc.SnapshotKVTransaction
Get the underlying KVStore.
delegate() - Method in class io.permazen.kv.raft.fallback.FallbackKVTransaction
 
delegate() - Method in class io.permazen.kv.spanner.SpannerKVTransaction
 
delegate() - Method in class io.permazen.kv.sql.SQLKVTransaction
 
delegate() - Method in class io.permazen.kv.util.CloseableForwardingKVStore
 
delegate() - Method in class io.permazen.kv.util.ForwardingKVStore
Get the underlying KVStore.
delegate() - Method in class io.permazen.kv.util.PrefixKVTransaction
 
delegate() - Method in class io.permazen.kv.util.UnmodifiableKVStore
 
delegate() - Method in class io.permazen.kv.xodus.XodusKVTransaction
 
delete() - Method in interface io.permazen.PermazenObject
Delete this instance, if it exists, in this instance's associated transaction.
delete(ObjId) - Method in class io.permazen.core.Transaction
Delete an object.
delete(PermazenObject) - Method in class io.permazen.PermazenTransaction
Delete the object with the given object ID in this transaction.
DELETE - Enum constant in enum class io.permazen.core.DeleteAction
Also delete the object containing the reference.
DeleteAction - Enum Class in io.permazen.core
Describes what action to take when an object is deleted and a reference to that object from some other object still exists.
deleteDirectoryHierarchy(File) - Method in class io.permazen.test.TestSupport
 
DeletedObjectException - Exception in io.permazen.core
Thrown when an object is accessed but the object does not exist in its associated transaction.
DeletedObjectException(ObjId) - Constructor for exception io.permazen.core.DeletedObjectException
Constructor.
DeletedObjectException(ObjId, String) - Constructor for exception io.permazen.core.DeletedObjectException
Constructor.
DeletedObjectException(Transaction, ObjId) - Constructor for exception io.permazen.core.DeletedObjectException
Constructor.
DeleteListener - Interface in io.permazen.core
Listener interface for notifications that an object is about to be deleted.
deleteObjectData(KVStore) - Static method in class io.permazen.core.Layout
Delete all object and index data from the given KVStore.
DeltaKVStore - Interface in io.permazen.kv.mvcc
Presents a mutable view of an underlying read-only KVStore and records the mutations in memory.
descendingIterator() - Method in class io.permazen.util.AbstractNavigableSet
 
descendingIterator() - Method in class io.permazen.util.ImmutableNavigableSet
 
descendingKeySet() - Method in class io.permazen.util.AbstractNavigableMap
 
descendingMap() - Method in class io.permazen.util.AbstractNavigableMap
 
descendingMap() - Method in class io.permazen.util.ImmutableNavigableMap
 
descendingSet() - Method in class io.permazen.util.AbstractNavigableSet
 
deserialize(InputStream) - Static method in class io.permazen.kv.mvcc.Writes
Deserialize a mutable instance created by serialize().
deserialize(InputStream, boolean) - Static method in class io.permazen.kv.mvcc.Writes
Deserialize an instance created by serialize().
deserializeIterator(InputStream) - Static method in class io.permazen.kv.KeyRanges
Deserialize an instance created by serialize() in the form of an iterator of the individual KeyRanges.
deserializeOnline(InputStream) - Static method in class io.permazen.kv.mvcc.Writes
Create an "online" Mutations view of a serialized Writes instance.
DetachedPermazenTransaction - Class in io.permazen
A PermazenTransaction that is not actually connected to a Permazen database instance, but instead exists just to hold objects in memory.
DetachedPermazenTransactionHttpMessageConverter - Class in io.permazen.spring
Spring HttpMessageConverter capable of encoding and decoding a graph of PermazenObjects contained in a DetachedPermazenTransaction that is backed by a MemoryKVStore.
DetachedPermazenTransactionHttpMessageConverter(Permazen) - Constructor for class io.permazen.spring.DetachedPermazenTransactionHttpMessageConverter
Constructor.
DetachedPermazenTransactionHttpMessageConverter(Permazen, MediaType...) - Constructor for class io.permazen.spring.DetachedPermazenTransactionHttpMessageConverter
Constructor.
DetachedTransaction - Class in io.permazen.core
A Transaction that is not actually connected to a persistent database, but instead exists just to hold objects in memory.
detail(String, Object...) - Method in interface io.permazen.jsck.JsckLogger
Log a high-detail message.
diff(String, String) - Method in class io.permazen.test.TestSupport
Run diff(1) on two strings.
difference(NavigableSet<E>, NavigableSet<E>) - Static method in class io.permazen.util.NavigableSets
Create a read-only view of the difference of two NavigableSets that have a consistent sort order.
differencesFrom(CollectionSchemaField) - Method in class io.permazen.schema.CollectionSchemaField
 
differencesFrom(ListSchemaField) - Method in class io.permazen.schema.ListSchemaField
 
differencesFrom(MapSchemaField) - Method in class io.permazen.schema.MapSchemaField
 
differencesFrom(SchemaCompositeIndex) - Method in class io.permazen.schema.SchemaCompositeIndex
 
differencesFrom(SchemaItem) - Method in class io.permazen.schema.SchemaItem
 
differencesFrom(SchemaModel) - Method in class io.permazen.schema.SchemaModel
 
differencesFrom(SchemaObjectType) - Method in class io.permazen.schema.SchemaObjectType
 
differencesFrom(SetSchemaField) - Method in class io.permazen.schema.SetSchemaField
 
differencesFrom(SimpleSchemaField) - Method in class io.permazen.schema.AbstractEnumSchemaField
 
differencesFrom(SimpleSchemaField) - Method in class io.permazen.schema.EnumArraySchemaField
 
differencesFrom(SimpleSchemaField) - Method in class io.permazen.schema.ReferenceSchemaField
 
differencesFrom(SimpleSchemaField) - Method in class io.permazen.schema.SimpleSchemaField
 
differencesFrom(T) - Method in interface io.permazen.util.DiffGenerating
Detect the differences of this instance when compared to the given instance.
DiffGenerating<T> - Interface in io.permazen.util
Implemented by classes that can generate a set of differences between themselves and other instances.
Diffs - Class in io.permazen.util
Used to report difference(s) between two hierarchical structures.
Diffs() - Constructor for class io.permazen.util.Diffs
Default constructor.
Diffs(Diffs) - Constructor for class io.permazen.util.Diffs
Copy constructor.
DIMENSIONS_ATTRIBUTE - Static variable in class io.permazen.schema.XMLConstants
 
DIRECTORY_ALREADY_EXISTS - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Directory already exists.
DIRECTORY_DOES_NOT_EXIST - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Directory does not exist.
DIRECTORY_PREFIX_IN_USE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Directory layer already has a conflicting prefix.
DIRECTORY_PREFIX_NOT_EMPTY - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Database has keys stored at the prefix chosen by the automatic prefix allocator.
DISABLED - Enum constant in enum class io.permazen.ValidationMode
Validation is disabled.
disableNewSchema - Variable in class io.permazen.cli.config.CoreApiCliConfig
 
disableReadTracking() - Method in interface io.permazen.kv.mvcc.DeltaKVStore
Permanently disable read tracking and discard the Reads associated with this instance.
disableReadTracking() - Method in class io.permazen.kv.mvcc.MutableView
 
doBackward(EnumValue) - Method in class io.permazen.EnumConverter
 
doBegin(Object, TransactionDefinition) - Method in class io.permazen.spring.PermazenTransactionManager
 
doCleanupAfterCompletion(Object) - Method in class io.permazen.spring.PermazenTransactionManager
 
doClose() - Method in class io.permazen.kv.mvstore.MVStoreAtomicKVStore
 
doCloseImmediately() - Method in class io.permazen.kv.mvstore.MVStoreAtomicKVStore
 
doCommit(DefaultTransactionStatus) - Method in class io.permazen.spring.PermazenTransactionManager
 
doCreateTransaction(KVDatabase) - Method in class io.permazen.kv.test.KVTestSupport
 
doCreateTransaction(Env<byte[]>, Dbi<byte[]>, Map<String, ?>) - Method in class io.permazen.kv.lmdb.ByteArrayLMDBKVDatabase
 
doCreateTransaction(Env<T>, Dbi<T>, Map<String, ?>) - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
 
doExecute() - Method in class io.permazen.cli.jshell.PermazenJShellShellSession
 
doForward(T) - Method in class io.permazen.EnumConverter
 
doGetTransaction() - Method in class io.permazen.spring.PermazenTransactionManager
 
doOpen() - Method in class io.permazen.kv.mvstore.MVStoreAtomicKVStore
 
doRemove(E, KVPair) - Method in class io.permazen.kv.util.AbstractKVIterator
Remove the previously iterated value.
doResume(Object, Object) - Method in class io.permazen.spring.PermazenTransactionManager
Resume a previously suspended transaction.
doRollback(DefaultTransactionStatus) - Method in class io.permazen.spring.PermazenTransactionManager
 
doSetRollbackOnly(DefaultTransactionStatus) - Method in class io.permazen.spring.PermazenTransactionManager
 
doSuspend(Object) - Method in class io.permazen.spring.PermazenTransactionManager
Suspend the current transaction.
DoubleArrayEncoding - Class in io.permazen.encoding
Non-null double[] array type.
DoubleArrayEncoding() - Constructor for class io.permazen.encoding.DoubleArrayEncoding
 
DoubleEncoding - Class in io.permazen.encoding
Double type.
DoubleEncoding(EncodingId) - Constructor for class io.permazen.encoding.DoubleEncoding
 
DoubleSummaryStatisticsEncoding - Class in io.permazen.encoding
DoubleSummaryStatisticsEncoding() - Constructor for class io.permazen.encoding.DoubleSummaryStatisticsEncoding
 
downCast(long) - Method in class io.permazen.encoding.ByteEncoding
 
downCast(long) - Method in class io.permazen.encoding.IntegerEncoding
 
downCast(long) - Method in class io.permazen.encoding.IntegralEncoding
 
downCast(long) - Method in class io.permazen.encoding.LongEncoding
 
downCast(long) - Method in class io.permazen.encoding.ShortEncoding
 
dumpRange(PrintStream, Iterator<KVPair>) - Static method in class io.permazen.cli.cmd.KVGetCommand
Print a hex and ASCII decode of the given key/value pairs.
dumpRange(PrintStream, Iterator<KVPair>, boolean, boolean, long) - Static method in class io.permazen.cli.cmd.KVGetCommand
Print a hex and ASCII decode of the given key/value pairs.
duplicate() - Method in exception io.permazen.kv.KVException
Create a duplicate of this exception, with the current thread's stack frames prepended.
duplicate() - Method in exception io.permazen.kv.KVTransactionException
 
duplicate() - Method in exception io.permazen.kv.mvcc.TransactionConflictException
 
duplicate() - Method in exception io.permazen.kv.RetryKVTransactionException
 
duplicate() - Method in exception io.permazen.kv.StaleKVTransactionException
 
DurationEncoding - Class in io.permazen.encoding
Non-null Duration type.
DurationEncoding() - Constructor for class io.permazen.encoding.DurationEncoding
 

E

early() - Element in annotation interface io.permazen.annotation.OnValidate
Specify when to invoke the annotated method relative to JSR 303 and uniqueness constraint validation.
element() - Element in annotation interface io.permazen.annotation.PermazenListField
Configuration for the field's elements.
element() - Element in annotation interface io.permazen.annotation.PermazenSetField
Configuration for the field's elements.
ELEMENT_FIELD_NAME - Static variable in class io.permazen.core.CollectionField
 
ELEMENT_TAG - Static variable in class io.permazen.core.util.XMLObjectSerializer
 
elementsAsNames(boolean) - Method in class io.permazen.core.util.XMLObjectSerializer.OutputOptions.Builder
Configure whether to output XML element names that are based on the corresponding object or field name.
empty() - Static method in class io.permazen.kv.KeyRanges
Create an empty instance containing zero ranges.
empty() - Static method in class io.permazen.util.NavigableSets
Create an empty NavigableSet.
empty(byte[]) - Static method in class io.permazen.kv.KeyRange
Create an empty key range at the specified key.
empty(Comparator<? super E>) - Static method in class io.permazen.util.NavigableSets
Create an empty NavigableSet with a specified Comparator.
EMPTY - Static variable in class io.permazen.util.ByteUtil
An empty byte array.
emptyIterator() - Static method in interface io.permazen.util.CloseableIterator
Return an empty CloseableIterator.
encode(byte[], DataOutputStream) - Method in class io.permazen.encoding.ByteArrayEncoding
 
encode(double[], DataOutputStream) - Method in class io.permazen.encoding.DoubleArrayEncoding
 
encode(float[], DataOutputStream) - Method in class io.permazen.encoding.FloatArrayEncoding
 
encode(int) - Method in class io.permazen.kv.raft.msg.Message
Serialize this instance.
encode(int) - Static method in class io.permazen.util.UnsignedIntEncoder
Encode the given value.
encode(int[], DataOutputStream) - Method in class io.permazen.encoding.IntegerArrayEncoding
 
encode(int, byte[], int) - Static method in class io.permazen.util.UnsignedIntEncoder
Encode the given value and write the encoded bytes into the given buffer.
encode(long) - Static method in class io.permazen.util.LongEncoder
Encode the given value.
encode(long[], DataOutputStream) - Method in class io.permazen.encoding.LongArrayEncoding
 
encode(short[], DataOutputStream) - Method in class io.permazen.encoding.ShortArrayEncoding
 
encode(ByteWriter, Object) - Method in class io.permazen.kv.util.AbstractKVNavigableSet
Encode the given object into a byte[] key.
encode(ByteWriter, Object) - Method in class io.permazen.kv.util.KVNavigableSet
 
encode(String) - Static method in class io.permazen.util.ParseContext
Encode a string into ASCII.
encode(T) - Method in interface io.permazen.encoding.Encoding
Encode the given value into a byte[] array.
encode(T, DataOutputStream) - Method in class io.permazen.encoding.Base64ArrayEncoding
 
encodeCounter(long) - Method in class io.permazen.kv.AbstractKVStore
 
encodeCounter(long) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
encodeCounter(long) - Method in class io.permazen.kv.caching.CachingKVTransaction
 
encodeCounter(long) - Static method in class io.permazen.kv.fdb.FoundationKVDatabase
Encode a 64 bit counter value.
encodeCounter(long) - Method in class io.permazen.kv.fdb.FoundationKVStore
 
encodeCounter(long) - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
encodeCounter(long) - Method in interface io.permazen.kv.KVStore
Encode a counter value into a byte[] value suitable for use with decodeCounter() and/or adjustCounter().
encodeCounter(long) - Method in class io.permazen.kv.mvcc.AtomicKVDatabase
 
encodeCounter(long) - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
encodeCounter(long) - Method in class io.permazen.kv.mvcc.MutableView
 
encodeCounter(long) - Method in class io.permazen.kv.raft.RaftKVTransaction
 
encodeCounter(long) - Method in class io.permazen.kv.util.ForwardingKVStore
 
Encoded(SchemaBundle.Encoded) - Constructor for class io.permazen.core.SchemaBundle.Encoded
Copy constructor.
Encoded(NavigableMap<Integer, byte[]>, NavigableMap<Integer, byte[]>) - Constructor for class io.permazen.core.SchemaBundle.Encoded
Constructor.
encodeKey(byte[]) - Method in class io.permazen.kv.sql.SQLKVTransaction
Encode the given key for the underlying database key column.
encodeKey(ByteWriter, Object) - Method in class io.permazen.kv.util.AbstractKVNavigableMap
Encode the given key object into a byte[] key.
encodeKey(ByteWriter, Object) - Method in class io.permazen.kv.util.KVNavigableMap
 
encodeLength(int) - Static method in class io.permazen.util.UnsignedIntEncoder
Determine the length (in bytes) of the encoded value.
encodeLength(long) - Static method in class io.permazen.util.LongEncoder
Determine the length (in bytes) of the encoded value.
encodeSchema(ByteWriter, SchemaModel) - Static method in class io.permazen.core.Layout
Encode schema XML for a schema table entry.
encodeVisible(Object, boolean) - Method in class io.permazen.kv.util.AbstractKVNavigableSet
Encode the given object, if possible, and verify corresponding byte[] key is visible, otherwise return null or throw an exception.
encodeVisibleKey(Object, boolean) - Method in class io.permazen.kv.util.AbstractKVNavigableMap
Encode the given key object, if possible, and verify the corresponding byte[] key is visible, otherwise return null or throw an exception.
encoding() - Element in annotation interface io.permazen.annotation.PermazenField
Specify the encoding for this field by EncodingId URN.
Encoding<T> - Interface in io.permazen.encoding
A range of values of some Java type, along with string and binary encodings and a total ordering of those values.
ENCODING_ATTRIBUTE - Static variable in class io.permazen.schema.XMLConstants
 
encodingId - Variable in class io.permazen.encoding.AbstractEncoding
 
EncodingId - Class in io.permazen.encoding
A globally unique identifier that identifies an Encoding's encoding scheme.
EncodingId(String) - Constructor for class io.permazen.encoding.EncodingId
Constructor.
EncodingIds - Class in io.permazen.encoding
EncodingId's for Permazen built-in encodings.
EncodingParser<T> - Class in io.permazen.cli.parse
Parses a value having type supported by an Encoding.
EncodingParser(Encoding<T>) - Constructor for class io.permazen.cli.parse.EncodingParser
Constructor.
encodingRegistry - Variable in class io.permazen.cli.config.CoreApiCliConfig
 
EncodingRegistry - Interface in io.permazen.encoding
A registry of Encodings.
encodingRegistryOption - Variable in class io.permazen.cli.config.CoreApiCliConfig
 
Encodings - Class in io.permazen.core
A few Encodings that are used for various general encoding tasks.
END_OF_STREAM - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
End of stream.
enterContext() - Method in class io.permazen.cli.jshell.PermazenExecutionControl
 
ENTRIES_TAG - Static variable in class io.permazen.kv.util.XMLSerializer
 
ENTRY_TAG - Static variable in class io.permazen.core.util.XMLObjectSerializer
 
ENTRY_TAG - Static variable in class io.permazen.kv.util.XMLSerializer
 
entrySet() - Method in class io.permazen.core.util.ObjIdMap
 
entrySet() - Method in class io.permazen.kv.util.AbstractKVNavigableMap
 
entrySet() - Method in class io.permazen.util.ConvertedNavigableMap
 
entrySet() - Method in class io.permazen.util.ImmutableNavigableMap
 
ENUM_ARRAY_FIELD - Enum constant in enum class io.permazen.schema.ItemType
 
ENUM_ARRAY_FIELD_TAG - Static variable in class io.permazen.schema.XMLConstants
 
ENUM_FIELD - Enum constant in enum class io.permazen.schema.ItemType
 
ENUM_FIELD_TAG - Static variable in class io.permazen.schema.XMLConstants
 
EnumArrayField - Class in io.permazen.core
A field that contains an array (having one or more dimensions) of values chosen from an ordered list of unique String identifiers.
EnumArraySchemaField - Class in io.permazen.schema
An enum array field (of one or more dimensions) in a SchemaObjectType.
EnumArraySchemaField() - Constructor for class io.permazen.schema.EnumArraySchemaField
 
EnumConverter<T extends Enum<T>> - Class in io.permazen
Converts between core database EnumValue objects and the corresponding Java Enum model values.
EnumConverter(Class<T>) - Constructor for class io.permazen.EnumConverter
Constructor.
EnumField - Class in io.permazen.core
A field that contains a value chosen from in an ordered list of unique String identifiers.
EnumNameParser<T extends Enum<T>> - Class in io.permazen.cli.parse
 
EnumNameParser(Class<T>) - Constructor for class io.permazen.cli.parse.EnumNameParser
 
EnumNameParser(Class<T>, boolean) - Constructor for class io.permazen.cli.parse.EnumNameParser
 
EnumSchemaField - Class in io.permazen.schema
An enum field in a SchemaObjectType.
EnumSchemaField() - Constructor for class io.permazen.schema.EnumSchemaField
 
EnumValue - Class in io.permazen.core
Holds a non-null Enum value without actually referencing any Java Enum type.
EnumValue(Enum<?>) - Constructor for class io.permazen.core.EnumValue
Constructor taking an Enum value.
EnumValue(String, int) - Constructor for class io.permazen.core.EnumValue
Constructor taking name and ordinal value.
EnumValueEncoding - Class in io.permazen.core
The Encoding for EnumValue, which is the data type used by EnumField.
EnumValueEncoding(Class<T>) - Constructor for class io.permazen.core.EnumValueEncoding
Constructor that derives the type name and identifier list from the given Enum type.
EnumValueEncoding(List<String>) - Constructor for class io.permazen.core.EnumValueEncoding
Primary constructor.
ENVIRONMENT_VARIABLE_NETWORK_OPTION_FAILED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Environment variable network option could not be set.
eq(T) - Static method in class io.permazen.util.Bounds
Create an instance with bounds that allow only the given value.
equals(Object) - Method in class io.permazen.change.Change
 
equals(Object) - Method in class io.permazen.change.FieldChange
 
equals(Object) - Method in class io.permazen.change.ListFieldAdd
 
equals(Object) - Method in class io.permazen.change.ListFieldRemove
 
equals(Object) - Method in class io.permazen.change.ListFieldReplace
 
equals(Object) - Method in class io.permazen.change.MapFieldAdd
 
equals(Object) - Method in class io.permazen.change.MapFieldRemove
 
equals(Object) - Method in class io.permazen.change.MapFieldReplace
 
equals(Object) - Method in class io.permazen.change.SetFieldAdd
 
equals(Object) - Method in class io.permazen.change.SetFieldRemove
 
equals(Object) - Method in class io.permazen.change.SimpleFieldChange
 
equals(Object) - Method in class io.permazen.core.EnumValue
 
equals(Object) - Method in class io.permazen.core.ObjId
 
equals(Object) - Method in class io.permazen.core.ReferenceEncoding
 
equals(Object) - Method in class io.permazen.core.SchemaBundle.Encoded
 
equals(Object) - Method in class io.permazen.core.util.ObjIdBiMultiMap
Compare for equality.
equals(Object) - Method in class io.permazen.encoding.AbstractEncoding
 
equals(Object) - Method in class io.permazen.encoding.ArrayEncoding
 
equals(Object) - Method in class io.permazen.encoding.ConvertedEncoding
 
equals(Object) - Method in class io.permazen.encoding.EncodingId
 
equals(Object) - Method in class io.permazen.encoding.NullSafeEncoding
 
equals(Object) - Method in class io.permazen.encoding.PrimitiveEncoding
 
equals(Object) - Method in class io.permazen.EnumConverter
 
equals(Object) - Method in class io.permazen.jsck.Issue
 
equals(Object) - Method in class io.permazen.kv.KeyRange
 
equals(Object) - Method in class io.permazen.kv.KeyRanges
 
equals(Object) - Method in class io.permazen.kv.KVPair
Compare for equality.
equals(Object) - Method in class io.permazen.kv.mvcc.ReadRemoveConflict
 
equals(Object) - Method in class io.permazen.kv.mvcc.ReadWriteConflict
 
equals(Object) - Method in class io.permazen.kv.raft.Timestamp
 
equals(Object) - Method in class io.permazen.ReferencePath
 
equals(Object) - Method in class io.permazen.schema.AbstractEnumSchemaField
 
equals(Object) - Method in class io.permazen.schema.ComplexSchemaField
 
equals(Object) - Method in class io.permazen.schema.EnumArraySchemaField
 
equals(Object) - Method in class io.permazen.schema.ReferenceSchemaField
 
equals(Object) - Method in class io.permazen.schema.SchemaCompositeIndex
 
equals(Object) - Method in class io.permazen.schema.SchemaId
 
equals(Object) - Method in class io.permazen.schema.SchemaItem
 
equals(Object) - Method in class io.permazen.schema.SchemaModel
 
equals(Object) - Method in class io.permazen.schema.SchemaObjectType
 
equals(Object) - Method in class io.permazen.schema.SimpleSchemaField
 
equals(Object) - Method in class io.permazen.spring.PermazenTransactionManager.TransactionSynchronizationCallback
 
equals(Object) - Method in class io.permazen.tuple.Tuple1
 
equals(Object) - Method in interface io.permazen.tuple.Tuple
Compare for equality.
equals(Object) - Method in class io.permazen.util.AbstractIterationSet
Overridden in AbstractIterationSet to minimize the use of AbstractIterationSet.size().
equals(Object) - Method in class io.permazen.util.Bounds
 
equals(Object) - Method in class io.permazen.util.ConvertedSpliterator
 
equals(Object) - Method in class io.permazen.util.ParseContext
 
ErrorCode - Enum Class in io.permazen.kv.fdb
FoundationDB error codes.
estimateSize() - Method in class io.permazen.util.ConvertedSpliterator
 
EVENTUAL - Enum constant in enum class io.permazen.kv.raft.Consistency
Eventual consistency.
EVENTUAL_COMMITTED - Enum constant in enum class io.permazen.kv.raft.Consistency
Committed eventual consistency.
EXACT_MODE_WITHOUT_LIMITS - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
EXACT streaming mode requires limits, but none were given.
EXCEPTION - Enum constant in enum class io.permazen.core.DeleteAction
Throw a ReferencedObjectException, thereby preventing the delete operation from happening.
exceptionDuringClose(Closeable, Throwable) - Method in class io.permazen.util.CloseableTracker
Handle an exception thrown while attempting to close() and item.
exceptionMapper - Variable in class io.permazen.kv.spanner.ReadOnlySpannerView
 
exceptionMapper - Variable in class io.permazen.kv.spanner.ReadWriteSpannerView
 
EXCLUSIVE - Enum constant in enum class io.permazen.util.BoundType
The bound is exclusive.
execute() - Method in class io.permazen.ant.SchemaGeneratorTask
 
execute(Session, String, List<String>) - Method in class io.permazen.cli.cmd.AbstractCommand
Execute this command.
execute(Session, String, List<String>) - Method in interface io.permazen.cli.cmd.Command
Execute this command.
execute(ConsoleSession<?, ?>, String, List<String>) - Method in class io.permazen.cli.SimpleCommandWrapper
 
EXECUTING - Enum constant in enum class io.permazen.kv.raft.TxState
The transaction is open, executing locally, and neither RaftKVTransaction.commit() nor RaftKVTransaction.rollback() has been invoked yet.
executor - Variable in class io.permazen.kv.test.KVDatabaseTest
 
exhaust(Stream<?>) - Static method in class io.permazen.util.Streams
Read and discard everything from the given Stream.
exists() - Method in interface io.permazen.PermazenObject
Determine whether this instance still exists in its associated transaction.
exists(ObjId) - Method in class io.permazen.core.Transaction
Determine if an object exists.
exists(ObjId) - Method in class io.permazen.PermazenTransaction
Determine whether the object with the given object ID exists in this transaction.
expect(char) - Method in class io.permazen.util.ParseContext
Read and advance past the next character, which must match ch.
expect(XMLStreamReader, boolean, QName...) - Method in class io.permazen.util.AbstractXMLStreaming
Scan forward until we see an opening or closing tag.
expectClose(XMLStreamReader) - Method in class io.permazen.util.AbstractXMLStreaming
Scan forward expecting to see a closing tag.
ExportContext - Class in io.permazen
Context for exporting plain (POJO) objects from a PermazenTransaction.
ExportContext(PermazenTransaction) - Constructor for class io.permazen.ExportContext
Constructor.
ExportContext(PermazenTransaction, Function<ObjId, Object>) - Constructor for class io.permazen.ExportContext
Constructor.
exportPlain(ObjId) - Method in class io.permazen.ExportContext
Export the PermazenObject with the given ObjId as a plain Java object, along with all other objects reachable from it via copied reference fields.
exportPlain(PermazenObject) - Method in class io.permazen.ExportContext
Export a PermazenObject as a plain Java object, along with all other objects reachable from it via copied reference fields.
EXTERNAL_CLIENT_ALREADY_LOADED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
External client has already been loaded.

F

failAll(Exception) - Method in class io.permazen.kv.util.KeyWatchTracker
Discard all outstanding key watches and fail them with the given exception.
FallbackKVDatabase - Class in io.permazen.kv.raft.fallback
A partition-tolerant KVDatabase that automatically migrates between a clustered RaftKVDatabase and a local, non-clustered "standalone mode" KVDatabase, based on availability of the Raft cluster.
FallbackKVDatabase() - Constructor for class io.permazen.kv.raft.fallback.FallbackKVDatabase
 
FallbackKVTransaction - Class in io.permazen.kv.raft.fallback
A KVTransaction associated with a FallbackKVDatabase.
FallbackTarget - Class in io.permazen.kv.raft.fallback
Represents one of the underlying RaftKVDatabases managed by a FallbackKVDatabase.
FallbackTarget() - Constructor for class io.permazen.kv.raft.fallback.FallbackTarget
 
Field<T> - Class in io.permazen.core
A field in an ObjType or a (simple) sub-field of a ComplexField in an ObjType.
FIELD_TAG - Static variable in class io.permazen.core.util.XMLObjectSerializer
 
FIELD_TAG - Static variable in class io.permazen.schema.XMLConstants
 
FieldChange<T> - Class in io.permazen.change
Notification object that gets passed to @OnChange-annotated methods when a field changes.
FieldChange(T, String) - Constructor for class io.permazen.change.FieldChange
Constructor.
fields() - Element in annotation interface io.permazen.annotation.PermazenCompositeIndex
The names of the indexed fields, in the desired order.
FieldSwitch<R> - Interface in io.permazen.core
Visitor pattern interface for Fields.
fifo() - Static method in class io.permazen.core.util.ObjIdQueues
Create a new empty instance with first-in-first-out (FIFO) behavior.
fifo(ObjIdSet) - Static method in class io.permazen.core.util.ObjIdQueues
Create a new instance with first-in-first-out (FIFO) behavior and initial contents copied from the given set.
FILE_CORRUPT - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
A structurally corrupt data file was detected.
FILE_NOT_FOUND - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
File not found.
FILE_NOT_READABLE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
File could not be read.
FILE_NOT_WRITABLE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
File could not be written.
FILE_TOO_LARGE - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
File too large to be read.
FileEncoding - Class in io.permazen.encoding
File type.
FileEncoding(EncodingId) - Constructor for class io.permazen.encoding.FileEncoding
 
filter(int, KeyFilter) - Method in class io.permazen.core.AbstractCoreIndex
Apply key filtering to field values at the specified index.
filter(int, KeyFilter) - Method in class io.permazen.core.CoreIndex1
 
filter(int, KeyFilter) - Method in class io.permazen.core.CoreIndex2
 
filter(int, KeyFilter) - Method in class io.permazen.core.CoreIndex3
 
filter(int, KeyFilter) - Method in class io.permazen.core.CoreIndex4
 
filterKeys(KeyFilter) - Method in class io.permazen.kv.util.AbstractKVNavigableMap
Create a view of this instance with additional filtering applied to the underlying byte[] keys.
filterKeys(KeyFilter) - Method in class io.permazen.kv.util.AbstractKVNavigableSet
Create a view of this instance with additional filtering applied to the underlying byte[] encoded keys.
finalize() - Method in class io.permazen.kv.array.AtomicArrayKVStore
Finalize this instance.
finalize() - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
 
finalize() - Method in class io.permazen.kv.leveldb.LevelDBAtomicKVStore
Finalize this instance.
finalize() - Method in class io.permazen.kv.leveldb.LevelDBKVStore
Finalize this instance.
finalize() - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
Finalize this instance.
finalize() - Method in class io.permazen.kv.lmdb.LMDBKVStore
Finalize this instance.
finalize() - Method in class io.permazen.kv.mvcc.SnapshotKVTransaction
 
finalize() - Method in class io.permazen.kv.mvstore.MVStoreAtomicKVStore
Finalize this instance.
finalize() - Method in class io.permazen.kv.raft.RaftKVTransaction
 
finalize() - Method in class io.permazen.kv.simple.SimpleKVTransaction
Ensure transaction is eventually rolled back if leaked due to an application bug.
finalize() - Method in class io.permazen.kv.sql.SQLKVTransaction
 
finalize() - Method in class io.permazen.kv.util.CloseableForwardingKVStore
Ensure the associated resource is CloseableForwardingKVStore.close()'d before reclaiming memory.
finalize() - Method in class io.permazen.kv.xodus.XodusKVDatabase
Finalize this instance.
finalize() - Method in class io.permazen.kv.xodus.XodusKVStore
Finalize this instance.
finalize() - Method in class io.permazen.util.CloseableRefs
Check that the reference count is zero before finalization.
finalize() - Method in class io.permazen.util.CloseableTracker
 
find(Class<T>) - Method in class io.permazen.core.EnumValue
Find the instance in the given Enum type that matches this instance in both name and ordinal value, if any.
findConflict(Mutations) - Method in class io.permazen.kv.mvcc.Reads
Determine whether any of the given mutations conflict with any of the keys read by this instance, and report the first conflict found.
findCustomEncodingRegistries() - Method in class io.permazen.encoding.DefaultEncodingRegistry
Scan the class path (via ServiceLoader and the current thread's context class loader) for custom EncodingRegistry implementations
findErasureDifference(TypeToken<?>, Collection<? extends TypeToken<?>>) - Static method in class io.permazen.Util
Check whether a generic type and its erased equivalent match the same set of candidate types.
findField(PermazenClass<?>, String) - Static method in class io.permazen.Util
Identify the named field in the given PermazenClass.
findField(PermazenClass<?>, String, Boolean) - Static method in class io.permazen.Util
Identify the named field in the given PermazenClass.
findKey(byte[]) - Method in class io.permazen.kv.KeyRanges
Find the contiguous KeyRange(s) within this instance containing, or adjacent to, the given key.
findLowestCommonAncestor(Stream<TypeToken<?>>) - Static method in class io.permazen.util.TypeTokens
Find the narrowest type that is a supertype of all of the given types.
findLowestCommonAncestorOfClasses(Stream<Class<?>>) - Static method in class io.permazen.util.TypeTokens
Find the narrowest type that is a supertype of all of the given types.
findLowestCommonAncestors(Stream<TypeToken<?>>) - Static method in class io.permazen.util.TypeTokens
Find the narrowest type(s) each of which is a supertype of all of the given types.
findLowestCommonAncestorsOfClasses(Stream<Class<?>>) - Static method in class io.permazen.util.TypeTokens
Find the narrowest type(s) each of which is a supertype of all of the given types.
findPermazenClass(Class<T>) - Method in class io.permazen.Permazen
Find the most specific PermazenClass for which the give type is a sub-type of the corresponding Java model type.
findSimpleField(PermazenClass<?>, String) - Static method in class io.permazen.Util
Identify the named simple field in the given PermazenClass.
first() - Method in class io.permazen.kv.util.AbstractKVNavigableSet
 
first() - Method in class io.permazen.util.AbstractNavigableSet
 
first() - Method in class io.permazen.util.ImmutableNavigableSet
 
firstEntry() - Method in class io.permazen.util.AbstractNavigableMap
 
firstEntry() - Method in class io.permazen.util.ImmutableNavigableMap
 
firstKey() - Method in class io.permazen.util.AbstractNavigableMap
 
firstKey() - Method in class io.permazen.util.ImmutableNavigableMap
 
firstPage() - Method in class io.permazen.util.NavigableSetPager
Jump to the first page.
FloatArrayEncoding - Class in io.permazen.encoding
Non-null float[] array type.
FloatArrayEncoding() - Constructor for class io.permazen.encoding.FloatArrayEncoding
 
FloatEncoding - Class in io.permazen.encoding
Float type.
FloatEncoding(EncodingId) - Constructor for class io.permazen.encoding.FloatEncoding
 
floor(E) - Method in class io.permazen.util.AbstractNavigableSet
 
floor(E) - Method in class io.permazen.util.ImmutableNavigableSet
 
floorEntry(K) - Method in class io.permazen.util.AbstractNavigableMap
 
floorEntry(K) - Method in class io.permazen.util.ImmutableNavigableMap
 
floorKey(K) - Method in class io.permazen.util.AbstractNavigableMap
 
floorKey(K) - Method in class io.permazen.util.ImmutableNavigableMap
 
flush() - Method in class io.permazen.kv.array.ArrayKVWriter
Flush all three outputs.
Follower - Class in io.permazen.kv.raft
Contains information maintained by leaders about followers.
FollowerRole - Class in io.permazen.kv.raft
Raft follower role.
followReferencePath(ReferencePath, Stream<? extends PermazenObject>) - Method in class io.permazen.PermazenTransaction
Find all target objects that are reachable from the given starting object set through the specified ReferencePath.
followReferencePath(Stream<? extends ObjId>, int[], KeyRanges[]) - Method in class io.permazen.core.Transaction
Find all objects referred to by any object in the given start set through the specified path of references.
forCode(int) - Static method in enum class io.permazen.kv.fdb.ErrorCode
Get the ErrorCode instance with the given error code, if any.
forEachRemaining(Consumer<? super E>) - Method in class io.permazen.util.ConvertedSpliterator
 
FORMAT_VERSION_1 - Static variable in class io.permazen.core.Layout
The original Database layout format version #1.
FORMAT_VERSION_ATTRIBUTE - Static variable in class io.permazen.schema.XMLConstants
 
forPrefix(byte[]) - Static method in class io.permazen.kv.KeyRange
Construct an instance containing all keys with the given prefix.
forPrefix(byte[]) - Static method in class io.permazen.kv.KeyRanges
Construct an instance containing a single range corresponding to all keys with the given prefix.
forTypeCode(String) - Static method in enum class io.permazen.schema.ItemType
Get instance that corresponds to the given type code.
FORWARD_DELETE_ATTRIBUTE - Static variable in class io.permazen.schema.XMLConstants
 
forwardCascades() - Element in annotation interface io.permazen.annotation.PermazenField
Define forward reference cascades for the annotated reference field.
forwardDelete() - Element in annotation interface io.permazen.annotation.PermazenField
For reference fields, configure cascading behavior when the referring object is deleted.
ForwardingKVStore - Class in io.permazen.kv.util
Forwards all KVStore operations to another underlying KVStore.
ForwardingKVStore() - Constructor for class io.permazen.kv.util.ForwardingKVStore
 
FoundationKVDatabase - Class in io.permazen.kv.fdb
FoundationDB KVDatabase implementation.
FoundationKVDatabase() - Constructor for class io.permazen.kv.fdb.FoundationKVDatabase
Constructor.
FoundationKVImplementation - Class in io.permazen.kv.fdb
 
FoundationKVImplementation() - Constructor for class io.permazen.kv.fdb.FoundationKVImplementation
 
FoundationKVImplementation.Config - Class in io.permazen.kv.fdb
 
FoundationKVImplementation.PrefixConverter - Class in io.permazen.kv.fdb
 
FoundationKVStore - Class in io.permazen.kv.fdb
A KVStore view of a FoundationDB Transaction.
FoundationKVStore(Transaction, byte[]) - Constructor for class io.permazen.kv.fdb.FoundationKVStore
Constructor.
FoundationKVTransaction - Class in io.permazen.kv.fdb
FoundationDB transaction.
fromArrayString(String) - Static method in class io.permazen.encoding.ArrayEncoding
Parse a combined String representation of an array of Strings and return the individual strings.
fromCString(String) - Static method in class io.permazen.cli.cmd.AbstractKVCommand
Parse a byte[] array encoded as a double-quoted C-string representation by toCString().
fromDouble(double) - Static method in class io.permazen.util.ByteUtil
Performs the inverse of toDouble().
fromString(String) - Method in class io.permazen.core.ObjIdEncoding
 
fromString(String) - Method in class io.permazen.encoding.Inet6AddressEncoding
 
fromString(String) - Method in class io.permazen.encoding.ArrayEncoding
 
fromString(String) - Method in class io.permazen.encoding.Base64ArrayEncoding
 
fromString(String) - Method in class io.permazen.encoding.BigDecimalEncoding
 
fromString(String) - Method in class io.permazen.encoding.BigIntegerEncoding
 
fromString(String) - Method in class io.permazen.encoding.BitSetEncoding
 
fromString(String) - Method in class io.permazen.encoding.CharacterEncoding
 
fromString(String) - Method in class io.permazen.encoding.ConvertedEncoding
 
fromString(String) - Method in class io.permazen.encoding.DateEncoding
 
fromString(String) - Method in class io.permazen.encoding.DurationEncoding
 
fromString(String) - Method in interface io.permazen.encoding.Encoding
Parse a non-null value previously encoded by toString(T).
fromString(String) - Method in class io.permazen.encoding.InstantEncoding
 
fromString(String) - Method in class io.permazen.encoding.LocalDateEncoding
 
fromString(String) - Method in class io.permazen.encoding.LocalDateTimeEncoding
 
fromString(String) - Method in class io.permazen.encoding.LocalTimeEncoding
 
fromString(String) - Method in class io.permazen.encoding.MonthDayEncoding
 
fromString(String) - Method in class io.permazen.encoding.NullSafeEncoding
 
fromString(String) - Method in class io.permazen.encoding.OffsetDateTimeEncoding
 
fromString(String) - Method in class io.permazen.encoding.OffsetTimeEncoding
 
fromString(String) - Method in class io.permazen.encoding.PeriodEncoding
 
fromString(String) - Method in class io.permazen.encoding.PrimitiveEncoding
 
fromString(String) - Method in class io.permazen.encoding.StringEncoding
Parse a non-null value previously encoded by toString().
fromString(String) - Method in class io.permazen.encoding.TupleEncoding
 
fromString(String) - Method in class io.permazen.encoding.UnsignedIntEncoding
 
fromString(String) - Method in class io.permazen.encoding.UUIDEncoding
 
fromString(String) - Method in class io.permazen.encoding.YearEncoding
 
fromString(String) - Method in class io.permazen.encoding.YearMonthEncoding
 
fromString(String) - Method in class io.permazen.encoding.ZonedDateTimeEncoding
 
fromString(String) - Method in class io.permazen.encoding.ZoneOffsetEncoding
 
fromXML(InputStream) - Static method in class io.permazen.schema.SchemaModel
Deserialize an instance from the given XML input.
full() - Static method in class io.permazen.kv.KeyRanges
Create a "full" instance containing a single KeyRange that contains all keys.
FULL - Static variable in class io.permazen.kv.KeyRange
The KeyRange containing the full range (i.e., all keys).
FUTURE_NOT_ERROR - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Future not an error.
FUTURE_NOT_SET - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Future not ready.
FUTURE_RELEASED - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Future has been released.
FUTURE_VERSION - Enum constant in enum class io.permazen.kv.fdb.ErrorCode
Request for future version.

G

ge(T) - Static method in class io.permazen.util.Bounds
Create an instance with an inclusive lower bound.
genAtomicKVStores() - Method in class io.permazen.kv.test.AtomicKVStoreTest
 
GENERATED_CLASS_NAME_SUFFIX - Static variable in class io.permazen.Permazen
The suffix that is appended to Java model class names to get the corresponding Permazen generated class name.
GeneratedIdCache - Class in io.permazen.core.util
Cache for randomly generated object IDs based on unique strings.
GeneratedIdCache() - Constructor for class io.permazen.core.util.GeneratedIdCache
 
generateId(String) - Method in class io.permazen.core.Transaction
Generate a random, unused ObjId for the given object type.
generateSchema(File) - Method in class io.permazen.SchemaUtilityImpl
 
genericize(Encoding<T>) - Static method in class io.permazen.core.Index
Genericize the given encoding for use in a index.
get() - Method in class io.permazen.Counter
Read this counter's current value.
get() - Method in class io.permazen.util.MovingAverage
Get the current average.
get(byte[]) - Method in class io.permazen.kv.AbstractKVStore
 
get(byte[]) - Method in class io.permazen.kv.array.ArrayKVStore
 
get(byte[]) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
get(byte[]) - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
 
get(byte[]) - Method in class io.permazen.kv.caching.CachingKVStore
 
get(byte[]) - Method in class io.permazen.kv.caching.CachingKVTransaction
 
get(byte[]) - Method in class io.permazen.kv.fdb.FoundationKVStore
 
get(byte[]) - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
get(byte[]) - Method in interface io.permazen.kv.KVStore
Get the value associated with the given key, if any.
get(byte[]) - Method in class io.permazen.kv.leveldb.LevelDBKVStore
 
get(byte[]) - Method in class io.permazen.kv.lmdb.LMDBKVStore
 
get(byte[]) - Method in class io.permazen.kv.mvcc.AtomicKVDatabase
 
get(byte[]) - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
get(byte[]) - Method in class io.permazen.kv.mvcc.MemoryAtomicKVStore
 
get(byte[]) - Method in class io.permazen.kv.mvcc.MutableView
 
get(byte[]) - Method in class io.permazen.kv.mvstore.MVMapKVStore
 
get(byte[]) - Method in class io.permazen.kv.raft.RaftKVTransaction
 
get(byte[]) - Method in class io.permazen.kv.simple.SimpleKVTransaction
 
get(byte[]) - Method in class io.permazen.kv.spanner.ReadOnlySpannerView
 
get(byte[]) - Method in class io.permazen.kv.spanner.SpannerKVTransaction
 
get(byte[]) - Method in class io.permazen.kv.util.ForwardingKVStore
 
get(byte[]) - Method in class io.permazen.kv.util.MemoryKVStore
 
get(byte[]) - Method in class io.permazen.kv.util.PrefixKVStore
 
get(byte[]) - Method in class io.permazen.kv.xodus.XodusKVStore
 
get(int) - Method in class io.permazen.util.ConvertedList
 
get(int) - Method in class io.permazen.util.ImmutableNavigableSet
Get the element at the specified index.
get(ObjId) - Method in class io.permazen.PermazenTransaction
Get the Java model object that is associated with this transaction and has the given ID.
get(ObjId, Class<T>) - Method in class io.permazen.PermazenTransaction
Get the Java model object that is associated with this transaction and has the given ID, cast to the given type.
get(Object) - Method in class io.permazen.core.util.ObjIdMap
 
get(Object) - Method in class io.permazen.kv.util.AbstractKVNavigableMap
 
get(Object) - Method in class io.permazen.util.ConvertedNavigableMap
 
get(Object) - Method in class io.permazen.util.ImmutableNavigableMap
 
get(T) - Method in class io.permazen.PermazenTransaction
Get the Java model object with the same object ID as the given PermazenObject and whose state derives from this transaction.
GET - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_ALL_FORWARD - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_ALL_REVERSE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_AT_LEAST_FORWARD - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_AT_LEAST_FORWARD_SINGLE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_AT_LEAST_REVERSE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_AT_LEAST_REVERSE_SINGLE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_AT_MOST_FORWARD - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_AT_MOST_FORWARD_SINGLE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_AT_MOST_REVERSE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_AT_MOST_REVERSE_SINGLE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_FIRST - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_LAST - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_RANGE_FORWARD - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_RANGE_FORWARD_SINGLE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_RANGE_REVERSE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
GET_RANGE_REVERSE_SINGLE - Enum constant in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.app.cmd.SetLogLevelCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.AbstractCommand
Process command line parameters and return action.
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.CompareSchemasCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.DecodeKeyCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.InfoCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.KVGetCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.KVLoadCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.KVPutCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.KVRemoveCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.KVSaveCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.LoadCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.RemoveSchemaCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.SaveCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.SetAllowNewSchemaCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.SetSchemaRemovalCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.SetSessionModeCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.SetValidationModeCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.SetVerboseCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.cli.cmd.ShowSchemaCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.jsck.cmd.JsckCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.kv.raft.cmd.RaftAddCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.kv.raft.cmd.RaftFallbackForceStandaloneCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.kv.raft.cmd.RaftFallbackStatusCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.kv.raft.cmd.RaftRemoveCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.kv.raft.cmd.RaftStartElectionCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.kv.raft.cmd.RaftStatusCommand
 
getAction(Session, Map<String, Object>) - Method in class io.permazen.kv.raft.cmd.RaftStepDownCommand
 
getAddress() - Method in class io.permazen.kv.raft.Follower
Get the address of this follower.
getAdjustPairs() - Method in interface io.permazen.kv.mvcc.Mutations
Get the counter adjustments contained by this instance.
getAdjustPairs() - Method in class io.permazen.kv.mvcc.Writes
 
getAdjusts() - Method in class io.permazen.kv.mvcc.Writes
Get the set of counter adjustments contained by this instance.
getAge() - Method in class io.permazen.kv.raft.LogEntry
Get the age of this log entry since instantiation.
getAll() - Method in class io.permazen.core.Transaction
Get all objects in the database.
getAll(Class<T>) - Method in class io.permazen.PermazenTransaction
Get all instances of the given type.
getAll(String) - Method in class io.permazen.core.Transaction
Get all objects whose object type has the specified name.
getAllConflicts(Mutations) - Method in class io.permazen.kv.mvcc.Reads
List all of the conflicts between the given mutations and any of the keys read by this instance.
getAnnotation(AnnotatedElement, Class<A>) - Static method in class io.permazen.Util
Find the annotation on the given element.
getArrayClass(Class<?>, int) - Static method in class io.permazen.cli.parse.ParseUtil
Get the array class with the given non-array base type and dimensions.
getArrayDimensions() - Method in class io.permazen.encoding.EncodingId
Get the number of array dimensions.
getArrayElement(boolean[], int) - Method in class io.permazen.encoding.BooleanArrayEncoding
 
getArrayElement(byte[], int) - Method in class io.permazen.encoding.ByteArrayEncoding
 
getArrayElement(char[], int) - Method in class io.permazen.encoding.CharacterArrayEncoding
 
getArrayElement(double[], int) - Method in class io.permazen.encoding.DoubleArrayEncoding
 
getArrayElement(float[], int) - Method in class io.permazen.encoding.FloatArrayEncoding
 
getArrayElement(int[], int) - Method in class io.permazen.encoding.IntegerArrayEncoding
 
getArrayElement(long[], int) - Method in class io.permazen.encoding.LongArrayEncoding
 
getArrayElement(short[], int) - Method in class io.permazen.encoding.ShortArrayEncoding
 
getArrayElement(E[], int) - Method in class io.permazen.encoding.ObjectArrayEncoding
 
getArrayElement(T, int) - Method in class io.permazen.encoding.ArrayEncoding
Get an element from the given array.
getArrayId() - Method in class io.permazen.encoding.EncodingId
Get the encoding ID corresponding to one more array dimension.
getArrayLength(boolean[]) - Method in class io.permazen.encoding.BooleanArrayEncoding
 
getArrayLength(byte[]) - Method in class io.permazen.encoding.ByteArrayEncoding
 
getArrayLength(char[]) - Method in class io.permazen.encoding.CharacterArrayEncoding
 
getArrayLength(double[]) - Method in class io.permazen.encoding.DoubleArrayEncoding
 
getArrayLength(float[]) - Method in class io.permazen.encoding.FloatArrayEncoding
 
getArrayLength(int[]) - Method in class io.permazen.encoding.IntegerArrayEncoding
 
getArrayLength(long[]) - Method in class io.permazen.encoding.LongArrayEncoding
 
getArrayLength(short[]) - Method in class io.permazen.encoding.ShortArrayEncoding
 
getArrayLength(E[]) - Method in class io.permazen.encoding.ObjectArrayEncoding
 
getArrayLength(T) - Method in class io.permazen.encoding.ArrayEncoding
Get the length of the given array.
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.AbstractKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.array.ArrayKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.caching.CachingKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.caching.CachingKVTransaction
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.fdb.FoundationKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
getAtLeast(byte[], byte[]) - Method in interface io.permazen.kv.KVStore
Get the key/value pair having the smallest key greater than or equal to the given minimum, if any.
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.mvcc.AtomicKVDatabase
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.mvcc.MemoryAtomicKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.mvstore.MVMapKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.raft.RaftKVTransaction
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.simple.SimpleKVTransaction
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.spanner.ReadOnlySpannerView
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.spanner.SpannerKVTransaction
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.util.ForwardingKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.util.MemoryKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.util.PrefixKVStore
 
getAtLeast(byte[], byte[]) - Method in class io.permazen.kv.xodus.XodusKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.AbstractKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.array.ArrayKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.caching.CachingKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.caching.CachingKVTransaction
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.fdb.FoundationKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
getAtMost(byte[], byte[]) - Method in interface io.permazen.kv.KVStore
Get the key/value pair having the largest key strictly less than the given maximum, if any.
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.mvcc.AtomicKVDatabase
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.mvcc.MemoryAtomicKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.mvstore.MVMapKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.raft.RaftKVTransaction
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.simple.SimpleKVTransaction
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.spanner.ReadOnlySpannerView
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.spanner.SpannerKVTransaction
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.util.ForwardingKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.util.MemoryKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.util.PrefixKVStore
 
getAtMost(byte[], byte[]) - Method in class io.permazen.kv.xodus.XodusKVStore
 
getAttr(XMLStreamReader, QName) - Method in class io.permazen.util.AbstractXMLStreaming
Get a requried attribute from the current element.
getAttr(XMLStreamReader, QName, boolean) - Method in class io.permazen.util.AbstractXMLStreaming
Get an attribute from the current element.
getBaseId() - Method in class io.permazen.encoding.EncodingId
Get the base encoding ID.
getBaseIndex() - Method in class io.permazen.kv.raft.msg.CommitRequest
 
getBaseIndex() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the index of the log entry on which this transaction is based.
getBaseKVStore() - Method in interface io.permazen.kv.mvcc.DeltaKVStore
Get the KVStore that underlies this instance.
getBaseKVStore() - Method in class io.permazen.kv.mvcc.MutableView
 
getBaseTerm() - Method in class io.permazen.kv.raft.msg.CommitRequest
 
getBaseTerm() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the term of the log entry on which this transaction is based.
getBaseType() - Method in class io.permazen.core.EnumArrayField
Get the base encoding.
getBaseVersion() - Method in class io.permazen.kv.mvcc.SnapshotKVTransaction
Get the MVCC database version number on which this instance is (or was originally) based.
getBoolean(ByteBuffer) - Static method in class io.permazen.kv.raft.msg.Message
Deserialize a boolean value previously serialized by putBoolean() from the buffer.
getBooleanAttr(XMLStreamReader, QName) - Method in class io.permazen.util.AbstractXMLStreaming
Get a requried boolean attribute from the current element.
getBooleanAttr(XMLStreamReader, QName, boolean) - Method in class io.permazen.util.AbstractXMLStreaming
Get an attribute from the current element and parse as a boolean value.
getBounds() - Method in class io.permazen.util.AbstractNavigableMap
Get the Bounds associated with this instance.
getBounds() - Method in class io.permazen.util.AbstractNavigableSet
Get the Bounds associated with this instance.
getByteBuffer(ByteBuffer) - Static method in class io.permazen.kv.raft.msg.Message
Deserialize a ByteBuffer previously serialized by putByteBuffer() from the buffer.
getBytes() - Method in class io.permazen.core.ObjId
Get the binary encoding of this instance.
getBytes() - Method in class io.permazen.util.ByteReader
Copy all the of bytes in the buffer.
getBytes() - Method in class io.permazen.util.ByteWriter
Retrieve all of the bytes that have been written to this instance.
getBytes(int) - Method in class io.permazen.util.ByteReader
Copy a range of bytes from the given offset to the end of the buffer.
getBytes(int) - Method in class io.permazen.util.ByteWriter
Retrieve the bytes that have been written to this instance, starting at the given offset.
getBytes(int, int) - Method in class io.permazen.util.ByteReader
Copy a range of bytes from the buffer.
getBytes(int, int) - Method in class io.permazen.util.ByteWriter
Retrieve a sub-range of the bytes that have been written to this instance.
getCachingKVStore() - Method in class io.permazen.kv.caching.CachingKVTransaction
Get the underlying CachingKVStore utilized by this instance.
getCheckInterval() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Get the interval between availability checks.
getClusterFile() - Method in class io.permazen.kv.fdb.FoundationKVImplementation.Config
 
getClusterId() - Method in class io.permazen.kv.raft.msg.Message
Get the cluster ID of the sender.
getClusterId() - Method in class io.permazen.kv.raft.RaftKVDatabase
Retrieve the unique 32-bit ID for this node's cluster.
getCode() - Method in enum class io.permazen.kv.fdb.ErrorCode
Get numerical error code.
getCommand() - Method in class io.permazen.cli.SimpleCommandWrapper
Get the underlying Command.
getCommitIndex() - Method in class io.permazen.kv.raft.msg.CommitResponse
Get the commit index for the transaction.
getCommitIndex() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get this instance's current commit index..
getCommitIndex() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the index of the Raft log entry on which this transaction is waiting to be committed (in the Raft sense) before it can complete.
getCommitLeaderLeaseTimeout() - Method in class io.permazen.kv.raft.msg.CommitResponse
Get the minimum required leader lease timeout value to commit, if any.
getCommitTerm() - Method in class io.permazen.kv.raft.msg.CommitResponse
Get the commit term for the transaction.
getCommitTerm() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the term of the Raft log entry on which this transaction is waiting to be committed (in the Raft sense) before it can complete.
getCommitTimeout() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the configured default transaction commit timeout.
getCommitVersion() - Method in class io.permazen.kv.mvcc.SnapshotKVTransaction
Get the MVCC database version number representing this transaction's successful commit, if any.
getComparator() - Method in class io.permazen.util.ConvertedSpliterator
 
getComparator(boolean) - Method in class io.permazen.util.AbstractNavigableMap
Get a non-null Comparator that sorts consistently with, and optionally reversed from, this instance.
getComparator(boolean) - Method in class io.permazen.util.AbstractNavigableSet
Get a non-null Comparator that sorts consistently with, and optionally reversed from, this instance.
getCompletions() - Method in exception io.permazen.util.ParseException
 
getCompositeIndex(String) - Method in class io.permazen.core.ObjType
Get the CompositeIndex associated with this instance with the given name.
getCompositeIndexes() - Method in class io.permazen.core.ObjType
Get all composite indexes associated with this object type keyed by name.
getCompositeIndexes() - Method in class io.permazen.core.SimpleField
Get the CompositeIndexs that contain this field, if any.
getCompositeIndexesByName() - Method in class io.permazen.PermazenClass
Get all PermazenCompositeIndex's defined on this PermazenClass, indexed by name.
getConfigChange() - Method in class io.permazen.kv.raft.LogEntry
Get the cluster config change associated with this log entry, if any.
getConfigChange() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the cluster configuration change associated with this transaction, if any.
getConfigType() - Method in interface io.permazen.kv.KVImplementation
Get the configuration object type for this instance.
getConflict() - Method in exception io.permazen.kv.mvcc.TransactionConflictException
Get the conflict that generated this exception.
getConflicts(Mutations) - Method in class io.permazen.kv.mvcc.Reads
List all of the conflicts between the given mutations and any of the keys read by this instance, in String form.
getConnectionIsolation() - Method in enum class io.permazen.kv.sql.IsolationLevel
Get the value corresponding to this isolation level suitable for Connection.setTransactionIsolation(int).
getConsistency() - Method in class io.permazen.kv.raft.cmd.AbstractTransactionRaftCommand.RaftTransactionAction
 
getConsistency() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the consistency level for this transaction.
getConsistency() - Method in class io.permazen.kv.spanner.SpannerKVTransaction
Get the consistency level configured for this transaction.
getContainingKVDatabase() - Method in class io.permazen.kv.util.PrefixKVDatabase
Get the containing KVDatabase associated with this instance.
getContentLength(DetachedPermazenTransaction, MediaType) - Method in class io.permazen.spring.DetachedPermazenTransactionHttpMessageConverter
 
getContentLength(KVStore, MediaType) - Method in class io.permazen.spring.KVStoreHttpMessageConverter
 
getContentLength(PermazenObject, MediaType) - Method in class io.permazen.spring.PermazenObjectHttpMessageConverter
 
getContinuationPrompt() - Method in class io.permazen.cli.PermazenShell
 
getConverter() - Method in class io.permazen.util.ConvertedList
Get the Converter associated with this instance.
getConverter() - Method in class io.permazen.util.ConvertedNavigableSet
Get the Converter associated with this instance.
getConverter() - Method in class io.permazen.util.ConvertedSet
Get the Converter associated with this instance.
getConverter() - Method in class io.permazen.util.ConvertedSpliterator
Get the Converter associated with this instance.
getConverter(PermazenTransaction) - Method in class io.permazen.PermazenEnumField
 
getConverter(PermazenTransaction) - Method in class io.permazen.PermazenCounterField
 
getConverter(PermazenTransaction) - Method in class io.permazen.PermazenField
Get a Converter that converts this field's value from what the core database returns to what the Java application expects, or null if no conversion is needed.
getConverter(PermazenTransaction) - Method in class io.permazen.PermazenListField
 
getConverter(PermazenTransaction) - Method in class io.permazen.PermazenMapField
 
getConverter(PermazenTransaction) - Method in class io.permazen.PermazenReferenceField
 
getConverter(PermazenTransaction) - Method in class io.permazen.PermazenSetField
 
getConverter(PermazenTransaction) - Method in class io.permazen.PermazenSimpleField
 
getCurrent() - Static method in class io.permazen.cli.jshell.PermazenJShellShellSession
Get the instance associated with the current thread.
getCurrent() - Static method in class io.permazen.PermazenTransaction
Get the PermazenTransaction associated with the current thread, if any, otherwise throw an exception.
getCurrent() - Method in class io.permazen.spring.PermazenTransactionManager
Like PermazenTransaction.getCurrent(), but returns null instead of throwing IllegalStateException.
getCurrentConfig() - Method in class io.permazen.kv.raft.RaftKVDatabase
Retrieve the current cluster configuration as understood by this node.
getCurrentProtocolVersion() - Static method in class io.permazen.kv.raft.msg.Message
Get the current (i.e., maximum known) protocol version number.
getCurrentRole() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get this instance's current role: leadeer, follower, or candidate.
getCurrentTargetIndex() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get the index of the currently active database.
getCurrentTerm() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get this instance's current term.
getCurrentTermStartTime() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the time at which this instance's current term advanced to its current value.
getCurrentTypesList() - Method in class io.permazen.ReferencePath
Get the current object types at each step in the path.
getCurrentVersion() - Method in class io.permazen.kv.mvcc.SnapshotKVDatabase
Get the current MVCC version number.
getData() - Method in class io.permazen.kv.raft.msg.InstallSnapshot
 
getDatabase() - Method in class io.permazen.cli.config.CliConfig
 
getDatabase() - Method in class io.permazen.cli.config.CoreApiCliConfig
 
getDatabase() - Method in class io.permazen.cli.Session
Get the associated Database, if any.
getDatabase() - Method in class io.permazen.core.Transaction
Get the database with which this transaction is associated.
getDatabase() - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
Get the underlying Database associated with this instance.
getDatabase() - Method in class io.permazen.kv.fdb.FoundationKVDatabase
Get the underlying Database associated with this instance.
getDatabase() - Method in class io.permazen.kv.lmdb.LMDBKVStore
Get the Dbi associated with this instance.
getDatabase() - Method in class io.permazen.Permazen
Get the core API Database underlying this instance.
getDatabase() - Method in class io.permazen.PermazenConfig
Get the underlying Database to be used.
getDatabaseConfig() - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
Get the DatabaseConfig to be used by this instance.
getDatabaseDescription() - Method in class io.permazen.cli.config.CliConfig
 
getDatabaseDescription() - Method in class io.permazen.cli.config.KeyValueCliConfig
 
getDatabaseDescription() - Method in class io.permazen.cli.Session
Get a description of the database.
getDatabaseFile() - Method in class io.permazen.kv.sqlite.SQLiteKVDatabase
Get the configured database file.
getDatabaseId() - Method in class io.permazen.kv.spanner.SpannerKVImplementation.Config
 
getDatabaseName() - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
Get the configured Database name.
getDatabaseName() - Method in class io.permazen.kv.bdb.BerkeleyKVImplementation.Config
 
getDatabaseName() - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
Get the LMDB database name to use.
getDatabaseName() - Method in class io.permazen.kv.lmdb.LMDBKVImplementation.Config
 
getDataSource() - Method in class io.permazen.kv.sql.SQLKVDatabase
Get the DataSource used with this instance.
getDB() - Method in class io.permazen.kv.leveldb.LevelDBAtomicKVStore
Get the underlying DB associated with this instance.
getDB() - Method in class io.permazen.kv.leveldb.LevelDBKVStore
Get the DB underlying this instance.
getDBs() - Method in class io.permazen.kv.test.KVDatabaseTest
 
getDeclaringAnnotation() - Method in class io.permazen.PermazenCounterField
 
getDeclaringAnnotation() - Method in class io.permazen.PermazenField
Get the Annotation that declared this field.
getDeclaringAnnotation() - Method in class io.permazen.PermazenListField
 
getDeclaringAnnotation() - Method in class io.permazen.PermazenMapField
 
getDeclaringAnnotation() - Method in class io.permazen.PermazenSetField
 
getDeclaringAnnotation() - Method in class io.permazen.PermazenSimpleField
 
getDefaultContentType(PermazenObject) - Method in class io.permazen.spring.PermazenObjectHttpMessageConverter
 
getDefaultDBFactory() - Static method in class io.permazen.kv.leveldb.LevelDBUtil
Get the default DBFactory.
getDefaultSchemaRemoval() - Method in class io.permazen.cli.config.CoreApiCliConfig
getDefaultSessionMode() - Method in class io.permazen.cli.config.CoreApiCliConfig
Get the default SessionMode.
getDefaultSessionMode() - Method in class io.permazen.cli.config.PermazenCliConfig
 
getDefaultValue() - Method in class io.permazen.encoding.AbstractEncoding
 
getDefaultValue() - Method in interface io.permazen.encoding.Encoding
Get the default value for this encoding.
getDefaultValueBytes() - Method in class io.permazen.encoding.AbstractEncoding
 
getDefaultValueBytes() - Method in interface io.permazen.encoding.Encoding
Get the default value for this encoding encoded as a byte[] array.
getDescription() - Method in enum class io.permazen.kv.fdb.ErrorCode
Get human readable description.
getDescription(C) - Method in interface io.permazen.kv.KVImplementation
Generate a short, human-readable description of the KVDatabase instance configured as given.
getDescription(BerkeleyKVImplementation.Config) - Method in class io.permazen.kv.bdb.BerkeleyKVImplementation
 
getDescription(FoundationKVImplementation.Config) - Method in class io.permazen.kv.fdb.FoundationKVImplementation
 
getDescription(LMDBKVImplementation.Config) - Method in class io.permazen.kv.lmdb.LMDBKVImplementation
 
getDescription(MVStoreKVImplementation.Config) - Method in class io.permazen.kv.mvstore.MVStoreKVImplementation
 
getDescription(RaftKVImplementation.Config) - Method in class io.permazen.kv.raft.RaftKVImplementation
 
getDescription(MemoryKVImplementation.Config) - Method in class io.permazen.kv.simple.MemoryKVImplementation
 
getDescription(SimpleKVImplementation.Config) - Method in class io.permazen.kv.simple.SimpleKVImplementation
 
getDescription(XMLKVImplementation.Config) - Method in class io.permazen.kv.simple.XMLKVImplementation
 
getDescription(SpannerKVImplementation.Config) - Method in class io.permazen.kv.spanner.SpannerKVImplementation
 
getDescription(SQLDriverKVImplementation.Config) - Method in class io.permazen.kv.cockroach.CockroachKVImplementation
 
getDescription(SQLDriverKVImplementation.Config) - Method in class io.permazen.kv.mssql.MSSQLKVImplementation
 
getDescription(SQLDriverKVImplementation.Config) - Method in class io.permazen.kv.mysql.MySQLKVImplementation
 
getDescription(SQLiteKVImplementation.Config) - Method in class io.permazen.kv.sqlite.SQLiteKVImplementation
 
getDescription(XodusKVImplementation.Config) - Method in class io.permazen.kv.xodus.XodusKVImplementation
 
getDescription(File) - Method in class io.permazen.kv.array.ArrayKVImplementation
 
getDescription(File) - Method in class io.permazen.kv.leveldb.LevelDBKVImplementation
 
getDestId(ObjId) - Method in class io.permazen.CopyState
Get the object ID for the copy of the given source object.
getDetachedTransaction() - Method in class io.permazen.PermazenTransaction
Get the default DetachedPermazenTransaction associated with this instance.
getDimensions() - Method in class io.permazen.core.EnumArrayField
Get the number of enum array dimensions.
getDimensions() - Method in class io.permazen.schema.EnumArraySchemaField
Get the number of enum array dimensions.
getDirectory() - Method in class io.permazen.kv.array.AtomicArrayKVStore
Get the filesystem directory containing the database.
getDirectory() - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
Get the filesystem directory containing the database.
getDirectory() - Method in class io.permazen.kv.bdb.BerkeleyKVImplementation.Config
 
getDirectory() - Method in class io.permazen.kv.leveldb.LevelDBAtomicKVStore
Get the filesystem directory containing the database.
getDirectory() - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
Get the filesystem directory containing the database.
getDirectory() - Method in class io.permazen.kv.lmdb.LMDBKVImplementation.Config
 
getDirectory() - Method in class io.permazen.kv.xodus.XodusKVDatabase
Get the filesystem directory containing the database.
getDirectory() - Method in class io.permazen.kv.xodus.XodusKVImplementation.Config
 
getElectionTimeout() - Method in class io.permazen.kv.raft.NonLeaderRole
Get the election timer deadline, if currently running.
getElement() - Method in class io.permazen.change.ListFieldAdd
Get the element that was added to the list.
getElement() - Method in class io.permazen.change.ListFieldRemove
Get the element that was removed from the list.
getElement() - Method in class io.permazen.change.SetFieldAdd
Get the element that was added to the set.
getElement() - Method in class io.permazen.change.SetFieldRemove
Get the element that was removed from the set.
getElementEncoding() - Method in class io.permazen.encoding.ArrayEncoding
Get the element type.
getElementField() - Method in class io.permazen.core.CollectionField
Get the element field.
getElementField() - Method in class io.permazen.PermazenCollectionField
Get the element sub-field.
getElementField() - Method in class io.permazen.schema.CollectionSchemaField
Get this collection field's element sub-field.
getElementId() - Method in class io.permazen.encoding.EncodingId
Get the encoding ID corresponding to one fewer array dimension.
getElementIndex() - Method in class io.permazen.core.CollectionField
Get the index on this fields's "element" sub-field.
getElementIndex() - Method in class io.permazen.core.ListField
 
getElementIndex() - Method in class io.permazen.core.SetField
 
getElementIndex(Transaction) - Method in class io.permazen.core.ListElementIndex
Get this index's view of the given transaction, including list index.
getElementName() - Method in enum class io.permazen.schema.ItemType
Get the XML element used for this item type.
getEncoded() - Method in class io.permazen.core.SchemaBundle
Get the encoded form of this instance.
getEncoding() - Method in class io.permazen.core.EnumField
Get the EnumValueEncoding associated with this instance.
getEncoding() - Method in class io.permazen.core.ReferenceField
 
getEncoding() - Method in class io.permazen.core.SimpleField
Get the Encoding associated with this field.
getEncoding() - Method in class io.permazen.core.SimpleIndex
Get the indexed field's encoding.
getEncoding() - Method in class io.permazen.PermazenSimpleField
Get the Encoding used by the core API to encode this field's values.
getEncoding(TypeToken<T>) - Method in interface io.permazen.encoding.EncodingRegistry
Get the unique Encoding in this registry that supports values of the given Java type.
getEncoding(EncodingId) - Method in class io.permazen.encoding.DefaultEncodingRegistry
 
getEncoding(EncodingId) - Method in interface io.permazen.encoding.EncodingRegistry
Get the Encoding with the given encoding ID in this registry.
getEncoding(EncodingId) - Method in class io.permazen.encoding.SimpleEncodingRegistry
 
getEncoding(Class<T>) - Method in interface io.permazen.encoding.EncodingRegistry
Get the unique Encoding in this registry that supports values of the given Java type.
getEncoding1() - Method in class io.permazen.encoding.Tuple2Encoding
 
getEncoding1() - Method in class io.permazen.encoding.Tuple3Encoding
 
getEncoding1() - Method in class io.permazen.encoding.Tuple4Encoding
 
getEncoding1() - Method in class io.permazen.encoding.Tuple5Encoding
 
getEncoding2() - Method in class io.permazen.encoding.Tuple2Encoding
 
getEncoding2() - Method in class io.permazen.encoding.Tuple3Encoding
 
getEncoding2() - Method in class io.permazen.encoding.Tuple4Encoding
 
getEncoding2() - Method in class io.permazen.encoding.Tuple5Encoding
 
getEncoding3() - Method in class io.permazen.encoding.Tuple3Encoding
 
getEncoding3() - Method in class io.permazen.encoding.Tuple4Encoding
 
getEncoding3() - Method in class io.permazen.encoding.Tuple5Encoding
 
getEncoding4() - Method in class io.permazen.encoding.Tuple4Encoding
 
getEncoding4() - Method in class io.permazen.encoding.Tuple5Encoding
 
getEncoding5() - Method in class io.permazen.encoding.Tuple5Encoding
 
getEncodingId() - Method in class io.permazen.encoding.AbstractEncoding
 
getEncodingId() - Method in interface io.permazen.encoding.Encoding
Get the globally unique encoding ID that identifies this encoding, if any.
getEncodingId() - Method in class io.permazen.schema.SimpleSchemaField
Get the EncodingId that identifies how this field's values are encoded.
getEncodingParser(String) - Static method in class io.permazen.cli.parse.EncodingParser
Create an instance based on type name.
getEncodingRegistry() - Method in class io.permazen.core.Database
Get the EncodingRegistry associated with this instance.
getEncodingRegistry() - Method in class io.permazen.core.SchemaBundle
Get the EncodingRegistry associated with this instance.
getEncodingRegistry() - Method in class io.permazen.jsck.JsckConfig
Get the EncodingRegistry used to interpret encoding names in recorded schemas.
getEncodings() - Method in class io.permazen.core.AbstractCoreIndex
Get all of the Encodings associated with this instance.
getEncodings() - Method in class io.permazen.core.Index
Get the field encoding(s).
getEncodings(TypeToken<T>) - Method in class io.permazen.encoding.DefaultEncodingRegistry
 
getEncodings(TypeToken<T>) - Method in interface io.permazen.encoding.EncodingRegistry
Get all of the Encodings in this registry that supports values of the given Java type.
getEncodings(TypeToken<T>) - Method in class io.permazen.encoding.SimpleEncodingRegistry
 
getEntry(int) - Method in class io.permazen.util.ImmutableNavigableMap
Get the entry at the specified index.
getEnumType() - Method in class io.permazen.PermazenEnumField
Get the Enum type that this field uses.
getEnumType() - Method in class io.permazen.EnumConverter
Get the Enum type associated with this instance.
getEnv() - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
Get the Env associated with this instance.
getEnvBuilder() - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
Get the Env.Builder that will be used when opening the associated Env.
getEnvFlags() - Method in class io.permazen.kv.lmdb.LMDBKVDatabase
Get the EnvFlags that will be used when opening the associated Env.
getEnvironment() - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
Get the underlying Environment associated with this instance.
getEnvironment() - Method in class io.permazen.kv.xodus.XodusKVDatabase
Get the underlying Environment associated with this instance.
getEnvironmentConfig() - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
Get the EnvironmentConfig to be used by this instance.
getEnvironmentConfig() - Method in class io.permazen.kv.xodus.XodusKVDatabase
Get the EnvironmentConfig that will be used when creating the associated Environment.
getError() - Method in class io.permazen.cli.Session
Get the error output for this CLI session.
getErrorMessage() - Method in class io.permazen.kv.raft.msg.CommitResponse
Get the error message in case of failure.
getErrorMessagePrefix() - Method in class io.permazen.cli.Session
Get prefix to use when displaying error messages.
getErrorPrefix() - Method in class io.permazen.cli.main.BasicCliMain
Get the prefix to use when displaying errors.
getExactSizeIfKnown() - Method in class io.permazen.util.ConvertedSpliterator
 
getExecutorService() - Method in class io.permazen.kv.caching.CachingKVDatabase
Get the configured ExecutorService, if any.
getExecutorService() - Method in class io.permazen.kv.spanner.SpannerKVDatabase
 
getFail() - Method in class io.permazen.kv.test.KVDatabaseTest.RandomTask
 
getFallback() - Method in class io.permazen.kv.raft.RaftKVImplementation.Config
 
getFallbackTarget() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get most preferred FallbackTarget.
getFallbackTarget() - Method in class io.permazen.kv.raft.RaftKVImplementation.Config
 
getFallbackTargets() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get the FallbackTarget(s).
getField() - Method in class io.permazen.core.SimpleIndex
Get the indexed field.
getField(int) - Method in class io.permazen.core.ObjType
Get the Field in this instance with the given storage ID.
getField(String) - Method in class io.permazen.core.ObjType
Get the Field in this instance with the given name.
getField(String, Class<T>) - Method in class io.permazen.PermazenClass
Get the specified PermazenField in this database object type, cast to the given Java type.
getFieldDescription(ObjId, String) - Method in class io.permazen.core.Transaction
Get a description of the given object field.
getFieldName() - Method in class io.permazen.change.FieldChange
Get the name of the field that changed.
getFieldName() - Method in exception io.permazen.core.ReferencedObjectException
Get the name of the field in the referring object that still referrs to the object that was supposed to be deleted.
getFieldName() - Method in exception io.permazen.core.UnknownFieldException
Get the name that was not recognized.
getFieldName() - Method in exception io.permazen.UpgradeConversionException
Get the name of the field from which the old value could not be converted.
getFields() - Method in class io.permazen.core.Index
Get the indexed field(s).
getFields() - Method in class io.permazen.core.ObjType
Get all fields associated with this object type keyed by name.
getFields() - Method in class io.permazen.PermazenCompositeIndex
Get the PermazenSimpleFields on which this index is based.
getFieldsAndSubFields() - Method in class io.permazen.core.ObjType
Get all fields associated with this object type keyed by name.
getFieldsByName() - Method in class io.permazen.PermazenClass
Get all PermazenField's associated with this instance, indexed by name.
getFieldsByStorageId() - Method in class io.permazen.PermazenClass
Get all PermazenField's associated with this instance, indexed by storage ID.
getFieldTruncationLength() - Method in class io.permazen.core.util.XMLObjectSerializer
Get the maximum length (number of characters) of any written simple field.
getFile() - Method in class io.permazen.kv.mvstore.MVStoreKVImplementation.Config
 
getFile() - Method in class io.permazen.kv.raft.LogEntry
Get the on-disk file for this log entry.
getFile() - Method in class io.permazen.kv.simple.XMLKVImplementation.Config
 
getFile() - Method in class io.permazen.kv.sqlite.SQLiteKVImplementation.Config
 
getFileSize() - Method in class io.permazen.kv.raft.LogEntry
Get the size of the on-disk file for this log entry.
getFixedWidth() - Method in class io.permazen.core.ObjIdEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.ArrayEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.BigDecimalEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.BigIntegerEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.BitSetEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.BooleanEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.CharacterEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.ConvertedEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.DateEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.DoubleEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.DurationEncoding
 
getFixedWidth() - Method in interface io.permazen.encoding.Encoding
Get the fixed width of this encoding, if any.
getFixedWidth() - Method in class io.permazen.encoding.FloatEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.Inet4AddressEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.Inet6AddressEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.InetAddressEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.InstantEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.IntegralEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.LocalDateEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.LocalDateTimeEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.LocalTimeEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.MonthDayEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.NullSafeEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.PeriodEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.StringEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.TupleEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.UnsignedIntEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.UUIDEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.VoidEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.YearEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.YearMonthEncoding
 
getFixedWidth() - Method in class io.permazen.encoding.ZoneOffsetEncoding
 
getFollowers() - Method in class io.permazen.kv.raft.LeaderRole
Get this leader's known followers.
getFormatVersionKey() - Static method in class io.permazen.core.Layout
Get the key under which the database format version is encoded.
getFormatVersionOverride() - Method in class io.permazen.jsck.JsckConfig
Configure a database format version to forcibly apply.
getForwardCascades() - Method in class io.permazen.PermazenReferenceField
Get this field's forward copy/find cascades.
getFullName() - Method in class io.permazen.core.Field
Get the full name of this field.
getFullName() - Method in class io.permazen.core.SimpleField
 
getFullName() - Method in class io.permazen.PermazenField
Get the "full name" of this field.
getFullName() - Method in class io.permazen.PermazenSimpleField
 
getFullName() - Method in class io.permazen.schema.SimpleSchemaField
Get the full name of this field.
getGeneratedId(Transaction, String, String) - Method in class io.permazen.core.util.GeneratedIdCache
Generate an object ID for the given object type name and string.
getGeneratedIdCache() - Method in class io.permazen.core.util.XMLObjectSerializer
Get the GeneratedIdCache associated with this instance.
getGeneration() - Method in class io.permazen.kv.simple.XMLKVDatabase
Get the generation number associated with the XML file.
getGeneration() - Method in class io.permazen.kv.simple.XMLKVTransaction
Get the generation number associated with this instance.
getGetter() - Method in class io.permazen.PermazenField
Get the getter method associated with this field.
getGreeting() - Method in class io.permazen.cli.PermazenShellSession
 
getHeartbeatTimeout() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the configured heartbeat timeout.
getHelpDetail() - Method in class io.permazen.cli.cmd.AbstractCommand
Get expanded help (typically multiple lines).
getHelpDetail() - Method in interface io.permazen.cli.cmd.Command
Get expanded help (typically multiple lines).
getHelpDetail() - Method in class io.permazen.cli.cmd.CompareSchemasCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.DecodeKeyCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.KVGetCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.KVLoadCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.KVPutCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.KVRemoveCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.KVSaveCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.LoadCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.RemoveSchemaCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.SaveCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.SetSessionModeCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.SetValidationModeCommand
 
getHelpDetail() - Method in class io.permazen.cli.cmd.ShowSchemaCommand
 
getHelpDetail() - Method in class io.permazen.jsck.cmd.JsckCommand
 
getHelpDetail() - Method in class io.permazen.kv.raft.cmd.RaftAddCommand
 
getHelpDetail() - Method in class io.permazen.kv.raft.cmd.RaftRemoveCommand
 
getHelpDetail() - Method in class io.permazen.kv.raft.cmd.RaftStartElectionCommand
 
getHelpDetail() - Method in class io.permazen.kv.raft.cmd.RaftStepDownCommand
 
getHelpDetail(String) - Method in class io.permazen.cli.SimpleCommandWrapper
 
getHelpSummary() - Method in class io.permazen.cli.app.cmd.SetLogLevelCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.AbstractCommand
Get summarized help (typically a single line).
getHelpSummary() - Method in interface io.permazen.cli.cmd.Command
Get summarized help (typically a single line).
getHelpSummary() - Method in class io.permazen.cli.cmd.CompareSchemasCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.DecodeKeyCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.InfoCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.KVGetCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.KVLoadCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.KVPutCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.KVRemoveCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.KVSaveCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.LoadCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.RemoveSchemaCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.SaveCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.SetAllowNewSchemaCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.SetSchemaRemovalCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.SetSessionModeCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.SetValidationModeCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.SetVerboseCommand
 
getHelpSummary() - Method in class io.permazen.cli.cmd.ShowSchemaCommand
 
getHelpSummary() - Method in class io.permazen.jsck.cmd.JsckCommand
 
getHelpSummary() - Method in class io.permazen.kv.raft.cmd.RaftAddCommand
 
getHelpSummary() - Method in class io.permazen.kv.raft.cmd.RaftFallbackForceStandaloneCommand
 
getHelpSummary() - Method in class io.permazen.kv.raft.cmd.RaftFallbackStatusCommand
 
getHelpSummary() - Method in class io.permazen.kv.raft.cmd.RaftRemoveCommand
 
getHelpSummary() - Method in class io.permazen.kv.raft.cmd.RaftStartElectionCommand
 
getHelpSummary() - Method in class io.permazen.kv.raft.cmd.RaftStatusCommand
 
getHelpSummary() - Method in class io.permazen.kv.raft.cmd.RaftStepDownCommand
 
getHelpSummary(String) - Method in class io.permazen.cli.SimpleCommandWrapper
 
getHoldTimeout() - Method in class io.permazen.kv.simple.LockManager
Get the hold timeout configured for this instance.
getHoldTimeout() - Method in class io.permazen.kv.simple.SimpleKVDatabase
Get the hold timeout configured for this instance.
getId() - Method in exception io.permazen.core.DeletedObjectException
Get the ID of the object that could not be accessed.
getId() - Method in exception io.permazen.core.InvalidObjectVersionException
Get the ID of the object containing the invalid schema index.
getId() - Method in exception io.permazen.core.ReferencedObjectException
Get the ID of the object that could not be deleted because it was referenced.
getId() - Method in class io.permazen.encoding.EncodingId
Get the encoding ID.
getId() - Method in class io.permazen.schema.SchemaId
Get the schema ID in string form.
getIdentifiers() - Method in class io.permazen.core.EnumValueEncoding
Get the identifiers associated with this instance in ordinal order.
getIdentifiers() - Method in class io.permazen.schema.AbstractEnumSchemaField
Get the ordered list of identifiers that constitute the enum type.
getIdentity() - Method in class io.permazen.kv.raft.Follower
Get the identity of this follower.
getIdentity() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get this node's Raft identity.
getIndex() - Method in class io.permazen.change.ListFieldAdd
Get the list index at which the new element was added.
getIndex() - Method in class io.permazen.change.ListFieldRemove
Get the list index from which the element was removed.
getIndex() - Method in class io.permazen.change.ListFieldReplace
Get the list index at which the element was replaced.
getIndex() - Method in class io.permazen.core.SimpleField
Get the SimpleIndex on this field.
getIndex() - Method in class io.permazen.kv.raft.LogEntry
Get the index of this instance.
getIndex() - Method in class io.permazen.util.ParseContext
Get the current index into the original input string.
getIndex(Transaction) - Method in class io.permazen.core.ComplexSubFieldIndex
 
getIndex(Transaction) - Method in class io.permazen.core.CompositeIndex
 
getIndex(Transaction) - Method in class io.permazen.core.Index
Get this index's view of the given transaction.
getIndex(Transaction) - Method in class io.permazen.core.SimpleFieldIndex
 
getIndex(Transaction) - Method in class io.permazen.core.SimpleIndex
 
getIndex(PermazenTransaction) - Method in class io.permazen.PermazenCompositeIndex
View this index.
getIndex(PermazenTransaction) - Method in class io.permazen.PermazenSimpleField
View the index on this field.
getIndexedFields() - Method in class io.permazen.schema.SchemaCompositeIndex
Get the fields that comprise this index.
getIndexName() - Method in exception io.permazen.core.UnknownIndexException
Get the name of the index that was not recognized.
getIndxLength() - Method in class io.permazen.kv.array.ArrayKVWriter
Get the number of bytes written so far to the index file.
getInitialContent() - Method in class io.permazen.kv.simple.XMLKVDatabase
Get the initial content for an uninitialized database.
getInitialContent() - Method in class io.permazen.spring.SpringXMLKVDatabase
Get the initial content for an uninitialized database.
getInitialRetryDelay() - Method in class io.permazen.cli.Session
Get the initial retry delay when a Session.RetryableTransactionalAction is given to performSessionAction().
getInitialRttEstimate() - Method in class io.permazen.kv.caching.CachingKVDatabase
Get the initial round trip time estimate.
getInitialTargetIndex() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get the configured target index to use when starting up for the very first time.
getInnerEncoding() - Method in class io.permazen.encoding.NullSafeEncoding
Get the inner Encoding that this instance wraps.
getInnerTransaction() - Method in class io.permazen.kv.caching.CachingKVTransaction
Get the underlying KVTransaction.
getInput() - Method in class io.permazen.util.ParseContext
Get the current input.
getInstance() - Static method in class io.permazen.util.ApplicationClassLoader
Obtain the unique instance having the current thread's context class loader as its parent, creating it on demand if needed.
getInstance(ClassLoader) - Static method in class io.permazen.util.ApplicationClassLoader
Obtain the unique instance having the given ClassLoader as its parent, creating it on demand if needed.
getInstanceId() - Method in class io.permazen.kv.spanner.SpannerKVImplementation.Config
 
getIntAttr(XMLStreamReader, QName) - Method in class io.permazen.util.AbstractXMLStreaming
Get a requried integer attribute from the current element.
getIntAttr(XMLStreamReader, QName, boolean) - Method in class io.permazen.util.AbstractXMLStreaming
Get an attribute from the current element and parse as a decimal integer value.
getInverseCascades() - Method in class io.permazen.PermazenReferenceField
Get this field's inverse copy/find cascades.
getInverseDelete() - Method in class io.permazen.core.ReferenceField
Get the desired behavior when an object referred to by this field is deleted.
getInverseDelete() - Method in class io.permazen.PermazenReferenceField
Get the inverse DeleteAction configured for this field.
getInverseDelete() - Method in class io.permazen.schema.ReferenceSchemaField
Get the desired behavior when an object referred to by this field is deleted.
getIsolationLevel() - Method in class io.permazen.kv.sql.SQLKVDatabase
Get the default transaction isolation level.
getIsolationLevel(Map<String, ?>) - Method in class io.permazen.kv.sql.SQLKVDatabase
Extract the IsolationLevel, if any, from the transaction options.
getItemType() - Method in class io.permazen.schema.CounterSchemaField
 
getItemType() - Method in class io.permazen.schema.EnumArraySchemaField
 
getItemType() - Method in class io.permazen.schema.EnumSchemaField
 
getItemType() - Method in class io.permazen.schema.ListSchemaField
 
getItemType() - Method in class io.permazen.schema.MapSchemaField
 
getItemType() - Method in class io.permazen.schema.ReferenceSchemaField
 
getItemType() - Method in class io.permazen.schema.SchemaCompositeIndex
 
getItemType() - Method in class io.permazen.schema.SchemaId
Get the ItemType of the schema item that originally generated this schema ID.
getItemType() - Method in class io.permazen.schema.SchemaModel
 
getItemType() - Method in class io.permazen.schema.SchemaObjectType
 
getItemType() - Method in class io.permazen.schema.CollectionSchemaField
Get the ItemType corresponding to this instance.
getItemType() - Method in class io.permazen.schema.SetSchemaField
 
getItemType() - Method in class io.permazen.schema.SimpleSchemaField
 
getJdbcUri() - Method in class io.permazen.kv.sql.SQLDriverKVImplementation.Config
 
getJsckLogger() - Method in class io.permazen.jsck.JsckConfig
Configure a destination for log messages emitted during the scan.
getKey() - Method in class io.permazen.change.MapFieldAdd
Get the key of the new key/value pair that was added.
getKey() - Method in class io.permazen.change.MapFieldRemove
Get the key of the key/value pair that was removed.
getKey() - Method in class io.permazen.change.MapFieldReplace
Get the key of the key/value pair whose value was replaced.
getKey() - Method in class io.permazen.jsck.Issue
Get the databse key.
getKey() - Method in class io.permazen.kv.KVPair
Get the key.
getKey() - Method in class io.permazen.kv.mvcc.ReadWriteConflict
Get the key at which the conflict occurred.
getKey(int) - Method in class io.permazen.util.ImmutableNavigableMap
Get the key at the specified index.
getKey(ObjId) - Method in class io.permazen.core.Field
Get the byte[] key in the underlying key/value store corresponding to this field in the specified object.
getKey(ObjId) - Method in class io.permazen.core.Transaction
Get the byte[] key prefix in the underlying key/value store corresponding to the specified object.
getKey(ObjId, int) - Method in class io.permazen.core.ListField
Get the byte[] key in the underlying key/value store corresponding to this field in the specified object and the specified list index.
getKey(ObjId, E) - Method in class io.permazen.core.SetField
Get the byte[] key in the underlying key/value store corresponding to this field in the specified object and the specified element.
getKey(ObjId, Object...) - Method in class io.permazen.core.Index
Get the byte[] key in the underlying key/value store corresponding to the given value tuple and target object in this index.
getKey(ObjId, K) - Method in class io.permazen.core.MapField
Get the byte[] key in the underlying key/value store corresponding to this field in the specified object and the specified map key.
getKey(ObjId, T) - Method in class io.permazen.core.SimpleIndex
Get the byte[] key in the underlying key/value store corresponding to the given value and target object in this index.
getKey(PermazenObject) - Method in class io.permazen.PermazenField
Get the byte[] key in the underlying key/value store corresponding to this field in the specified object.
getKey(PermazenObject) - Method in class io.permazen.PermazenTransaction
Get the byte[] key in the underlying key/value store corresponding to the specified object.
getKey(Object...) - Method in class io.permazen.core.Index
Get the byte[] key in the underlying key/value store corresponding to the given value tuple in this index.
getKey(T) - Method in class io.permazen.core.SimpleIndex
Get the byte[] key in the underlying key/value store corresponding to the given value in this index.
getKeyAfterPrefix(byte[]) - Static method in class io.permazen.util.ByteUtil
Get the first key that would be greater than the given key in unsigned lexicographic ordering and that does not have the given key as a prefix.
getKeyColumnName() - Method in class io.permazen.kv.sql.SQLKVDatabase
Get the name of the column containing keys.
getKeyConverter() - Method in class io.permazen.util.ConvertedNavigableMap
 
getKeyField() - Method in class io.permazen.core.MapField
Get the key field.
getKeyField() - Method in class io.permazen.PermazenMapField
Get the key sub-field.
getKeyField() - Method in class io.permazen.schema.MapSchemaField
Get this map field's key sub-field.
getKeyFilter() - Method in class io.permazen.kv.KVPairIterator
Get the KeyFilter instance used to filter visible keys, if any.
getKeyPrefix() - Method in class io.permazen.kv.fdb.FoundationKVDatabase
Get the key prefix for all keys.
getKeyPrefix() - Method in class io.permazen.kv.fdb.FoundationKVStore
Get the key prefix associated with this instance, if any.
getKeyPrefix() - Method in class io.permazen.kv.util.PrefixKVDatabase
Get the key prefix associated with this instance.
getKeyPrefix() - Method in class io.permazen.kv.util.PrefixKVStore
Get the byte[] key prefix associated with this instance.
getKeyRange() - Method in class io.permazen.kv.KVPairIterator
Get the KeyRange instance used to restrict the range of visible keys, if any.
getKeyRange() - Method in class io.permazen.kv.mvcc.ReadRemoveConflict
Get the key range at which the conflict occurred.
getKeyRange(byte[], byte[], boolean) - Method in class io.permazen.kv.lmdb.LMDBKVStore
Get the KeyRange corresponding to the given parameters.
getKeyRange(int) - Static method in class io.permazen.core.ObjId
Get the KeyRange containing all object IDs with the given storage ID.
getKeyRange(Bounds<? extends T>) - Method in interface io.permazen.encoding.Encoding
Calculate the KeyRange that includes exactly those encoded values that lie within the given bounds.
getKeysLength() - Method in class io.permazen.kv.array.ArrayKVWriter
Get the number of bytes written so far to the key data file.
getKVDatabase() - Method in class io.permazen.cli.config.CliConfig
 
getKVDatabase() - Method in class io.permazen.cli.config.KeyValueCliConfig
 
getKVDatabase() - Method in class io.permazen.cli.Session
Get the associated KVDatabase.
getKVDatabase() - Method in class io.permazen.core.Database
Get the KVDatabase underlying this instance.
getKVDatabase() - Method in class io.permazen.kv.array.ArrayKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.caching.CachingKVDatabase
Get the inner KVDatabase.
getKVDatabase() - Method in class io.permazen.kv.caching.CachingKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
getKVDatabase() - Method in interface io.permazen.kv.KVTransaction
Get the KVDatabase with which this instance is associated.
getKVDatabase() - Method in class io.permazen.kv.leveldb.LevelDBKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.lmdb.LMDBKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.mvcc.SnapshotKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.mvstore.MVStoreKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.raft.fallback.FallbackKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.raft.RaftKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.raft.Role
Get the RaftKVDatabase with which this instance is associated.
getKVDatabase() - Method in class io.permazen.kv.simple.SimpleKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.spanner.SpannerKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.sql.SQLKVTransaction
 
getKVDatabase() - Method in class io.permazen.kv.test.KVDatabaseTest
 
getKVDatabase() - Method in class io.permazen.kv.util.PrefixKVTransaction
Get the PrefixKVDatabase associated with this instance.
getKVDatabase() - Method in class io.permazen.kv.xodus.XodusKVTransaction
 
getKVOptions() - Method in class io.permazen.core.TransactionConfig
Configure KVDatabase transaction options.
getKVStore() - Method in class io.permazen.core.DetachedTransaction
Get the underlying KVStore that holds this detached transaction's state.
getKVStore() - Method in class io.permazen.kv.array.ArrayKVDatabase
Get the underlying AtomicArrayKVStore used by this instance.
getKVStore() - Method in class io.permazen.kv.KVPairIterator
Get the KVStore associated with this instance.
getKVStore() - Method in class io.permazen.kv.leveldb.LevelDBKVDatabase
Get the underlying LevelDBAtomicKVStore used by this instance.
getKVStore() - Method in class io.permazen.kv.mvcc.SnapshotKVDatabase
Get the underlying AtomicKVStore.
getKVStore() - Method in class io.permazen.kv.mvstore.MVStoreKVDatabase
Get the underlying MVStoreAtomicKVStore used by this instance.
getKVStoreContentLength(KVStore) - Static method in class io.permazen.spring.KVStoreHttpMessageConverter
Determine the content length of the given key/value store when encoded as payload.
getKVTransaction() - Method in class io.permazen.cli.Session
Get the KVTransaction currently associated with this instance.
getKVTransaction() - Method in class io.permazen.cli.Session.TxInfo
Get the associated KVTransaction.
getKVTransaction() - Method in class io.permazen.core.Transaction
Get the underlying key/value store transaction.
getKVTransaction() - Method in class io.permazen.kv.raft.fallback.FallbackKVTransaction
Get the underlying transaction, which will be associated with either one of the fallback databases, or the standalone mode database.
getLastActiveTime() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Get the last time this target was the active database.
getLastAppliedIndex() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get this instance's last applied log entry index.
getLastAppliedTerm() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get this instance's last applied log entry term.
getLastChangeTime() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Get the time of the last change in availability of this target, if known.
getLastInternalError() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the exception most recently thrown by the internal service thread, if any.
getLastLogIndex() - Method in class io.permazen.kv.raft.msg.AppendResponse
Get the index of the last log entry in the follower's log.
getLastLogIndex() - Method in class io.permazen.kv.raft.msg.RequestVote
 
getLastLogTerm() - Method in class io.permazen.kv.raft.msg.RequestVote
 
getLastStandaloneActiveTime() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get the last time the standalone database was active.
getLastStateChangeTime() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the Timestamp of the most recent state change.
getLeaderAddress() - Method in class io.permazen.kv.raft.FollowerRole
Get the address of my leader, if known.
getLeaderCommit() - Method in class io.permazen.kv.raft.Follower
Get the leader commit index most recently sent to this follower.
getLeaderCommit() - Method in class io.permazen.kv.raft.msg.AppendRequest
Get leader's commit index.
getLeaderIdentity() - Method in class io.permazen.kv.raft.FollowerRole
Get the identity of my leader, if known.
getLeaderLeaseTimeout() - Method in class io.permazen.kv.raft.msg.AppendRequest
 
getLeaderTimestamp() - Method in class io.permazen.kv.raft.Follower
Get the most recent (leader's) request timestamp returned by this follower in a response, if any.
getLeaderTimestamp() - Method in class io.permazen.kv.raft.msg.AppendRequest
 
getLeaderTimestamp() - Method in class io.permazen.kv.raft.msg.AppendResponse
Get the leaderTimestamp from the corresponding AppendRequest.
getLeaseTimeout() - Method in class io.permazen.kv.raft.LeaderRole
Get this leader's "lease timeout".
getLength() - Method in class io.permazen.util.ByteWriter
Get the current buffer length.
getLength(ByteReader) - Method in class io.permazen.encoding.Inet4AddressEncoding
 
getLength(ByteReader) - Method in class io.permazen.encoding.Inet6AddressEncoding
 
getLength(ByteReader) - Method in class io.permazen.encoding.InetAddressEncoding
 
getLinearizableCommitTimestamp() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the timestamp of the most recently committed linearizable transaction.
getLockTimeout() - Method in class io.permazen.kv.mssql.MSSQLKVDatabase
Get the lock timeout with which to configure new transactions.
getLockTimeout() - Method in class io.permazen.kv.mysql.MySQLKVDatabase
Get the lock timeout with which to configure new transactions.
getLogDirectory() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the directory in which uncommitted log entries are stored.
getLogEntryTerm() - Method in class io.permazen.kv.raft.msg.AppendRequest
 
getLogger() - Method in class io.permazen.util.CloseableRefs
Get the Logger to use for logging errors.
getLongAttr(XMLStreamReader, QName, boolean) - Method in class io.permazen.util.AbstractXMLStreaming
Get an attribute from the current element and parse as a decimal long value.
getLowerBound() - Method in class io.permazen.util.Bounds
Get the Java value corresponding to the lower bound restriction, if any.
getLowerBoundType() - Method in class io.permazen.util.Bounds
Get the type of the lower bound that corresponds to Bounds.getLowerBound().
getMapKeyIndex() - Method in class io.permazen.core.MapField
Get the index on this fields's "key" sub-field.
getMapValueIndex() - Method in class io.permazen.core.MapField
Get the index on this fields's "value" sub-field.
getMatchIndex() - Method in class io.permazen.kv.raft.Follower
Get the index of the highest log entry in the follower's log known to match the leader's log.
getMatchIndex() - Method in class io.permazen.kv.raft.msg.AppendResponse
Get the index of the most recent log entry known to match leader.
getMax() - Method in class io.permazen.cli.ParamParser.Param
 
getMax() - Method in class io.permazen.kv.KeyRange
Get range maximum (exclusive), or null if there is no upper bound.
getMax() - Method in class io.permazen.kv.KeyRanges
Get the maximum key contained by this instance (exclusive).
getMax() - Method in class io.permazen.util.ByteReader
Get maximum offset into buffer.
getMax(int) - Static method in class io.permazen.core.ObjId
Get the largest (i.e., last) instance having the given storage ID.
getMaxElectionTimeout() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the configured maximum election timeout.
getMaximumRetryDelay() - Method in class io.permazen.cli.Session
Configure the maximum retry delay when a Session.RetryableTransactionalAction is given to performSessionAction().
getMaximumTargetIndex() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get the maximum allowed target index.
getMaxIssues() - Method in class io.permazen.jsck.JsckConfig
Configure a maximum number of issues to generate.
getMaxKey() - Method in class io.permazen.kv.mvstore.MVCursorIterator
 
getMaxRangeBytes() - Method in class io.permazen.kv.caching.AbstractCachingConfig
 
getMaxRangeBytes() - Method in interface io.permazen.kv.caching.CachingConfig
Get the maximum number of bytes to cache in a single contiguous range of key/value pairs.
getMaxRangeBytes() - Method in class io.permazen.kv.caching.CachingKVStore
 
getMaxRanges() - Method in class io.permazen.kv.caching.AbstractCachingConfig
 
getMaxRanges() - Method in interface io.permazen.kv.caching.CachingConfig
Get the maximum number of contiguous ranges of key/value pairs to allow before we start purging the least recently used ones.
getMaxRanges() - Method in class io.permazen.kv.caching.CachingKVStore
 
getMaxRetries() - Method in class io.permazen.cli.Session
Get the maximum number of allowed retries when a Session.RetryableTransactionalAction is given to performSessionAction().
getMaxTotalBytes() - Method in class io.permazen.kv.caching.AbstractCachingConfig
 
getMaxTotalBytes() - Method in interface io.permazen.kv.caching.CachingConfig
Get the total number of bytes to cache.
getMaxTotalBytes() - Method in class io.permazen.kv.caching.CachingKVStore
 
getMaxTransactionDuration() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the configured maximum supported duration for outstanding transactions.
getMemory(byte[]) - Method in class io.permazen.kv.mvstore.ByteArrayDataType
 
getMetaDataKeyPrefix() - Static method in class io.permazen.core.Layout
Get the common prefix of all meta-data keys.
getMillis() - Method in class io.permazen.kv.raft.Timestamp
Get the relative milliseconds value contained by this instance.
getMin() - Method in class io.permazen.cli.ParamParser.Param
 
getMin() - Method in class io.permazen.kv.KeyRange
Get range minimum (inclusive).
getMin() - Method in class io.permazen.kv.KeyRanges
Get the minimum key contained by this instance (inclusive).
getMin(int) - Static method in class io.permazen.core.ObjId
Get the smallest (i.e., first) instance having the given storage ID.
getMinAvailableTime() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Get the minimum amount of time after becoming available before allowing this instance to become unavailable again.
getMinElectionTimeout() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the configured minimum election timeout.
getMinUnavailableTime() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Get the minimum amount of time after becoming unavailable before allowing this instance to become available again.
getMode() - Method in class io.permazen.cli.Session
Get this instance's SessionMode.
getMode() - Method in class io.permazen.cli.Session.TxInfo
Get the SessionMode that the transaction was opened with.
getModelClass() - Method in interface io.permazen.PermazenObject
Get the original Java model class of which this PermazenObject is an instance.
getModelClasses() - Method in class io.permazen.PermazenConfig
Get the Java model classes to be used.
getMutableView() - Method in class io.permazen.kv.mvcc.SnapshotKVTransaction
Get the MutableView associated with this instance.
getMutationData() - Method in class io.permazen.kv.raft.msg.AppendRequest
Get the serialized data for the log entry, if any.
getMutationData() - Method in class io.permazen.kv.raft.msg.CommitRequest
Get the transaction's mutations.
getMVMap() - Method in class io.permazen.kv.mvstore.CursorIterator
Get the MVMap underlying this instance, if any.
getMVMap() - Method in class io.permazen.kv.mvstore.MVMapKVStore
Get the underlying MVMap associated with this instance.
getMVMap() - Method in class io.permazen.kv.mvstore.MVStoreAtomicKVStore
 
getMVStore() - Method in class io.permazen.kv.mvstore.MVStoreAtomicKVStore
Get the underlying MVStore associated with this instance.
getName() - Method in class io.permazen.cli.cmd.AbstractCommand
 
getName() - Method in interface io.permazen.cli.cmd.Command
Get the name of this command.
getName() - Method in class io.permazen.cli.ParamParser.Param
 
getName() - Method in class io.permazen.core.EnumValue
Get the enum name.
getName() - Method in class io.permazen.core.SchemaItem
Get the name associated with this instance.
getName() - Method in class io.permazen.PermazenSchemaItem
Get the name of this instance.
getName() - Method in class io.permazen.schema.SchemaItem
Get the name associated with this instance, if any.
getNavigableMap() - Method in class io.permazen.kv.util.MemoryKVStore
Get the underlying ConcurrentNavigableMap used by this instance.
getNavigableSet() - Method in class io.permazen.util.NavigableSetPager
Get the NavigableSet through which to page.
getNetworkOptions() - Method in class io.permazen.kv.fdb.FoundationKVDatabase
Get the NetworkOptions associated with this instance.
getNewValue() - Method in class io.permazen.change.ListFieldReplace
Get the value of the field after the change.
getNewValue() - Method in class io.permazen.change.MapFieldReplace
Get the value of the key/value pair after the change.
getNewValue() - Method in class io.permazen.change.SimpleFieldChange
Get the value of the field after the change.
getNewValue() - Method in class io.permazen.jsck.Issue
Get the replacement value, if any.
getNextIndex() - Method in class io.permazen.kv.raft.Follower
Get the index of the next log entry to send to this follower.
getNextKey(byte[]) - Static method in class io.permazen.util.ByteUtil
Get the next key greater than the given key in unsigned lexicographic ordering.
getNodesProbed() - Method in class io.permazen.kv.raft.FollowerRole
Determine the number of nodes (including this node) that this node has successfully probed when probing for a majority of nodes with PingRequests prior to reverting to a candidate.
getNonconflictingTransactionCount() - Method in class io.permazen.kv.test.KVDatabaseTest
 
getNormalPrompt() - Method in class io.permazen.cli.PermazenShell
 
getNumKeysWatched() - Method in class io.permazen.kv.util.KeyWatchTracker
Count the number of keys being watched.
getNumParams() - Method in enum class io.permazen.kv.sql.SQLKVTransaction.StmtType
 
getNumSources() - Method in class io.permazen.core.util.ObjIdBiMultiMap
Get the the number of sources that have one or more associated targets.
getNumTargets() - Method in class io.permazen.core.util.ObjIdBiMultiMap
Get the the number of targets that have one or more associated sources.
getNumTries() - Method in class io.permazen.kv.test.KVTestSupport
 
getObjDescription(ObjId) - Method in class io.permazen.core.Transaction
Get a description of the given object.
getObject() - Method in class io.permazen.change.Change
Get the Java model object containing the field that changed.
getObject() - Method in exception io.permazen.ValidationException
Get the object that failed to validate.
getObjectIdMap() - Method in class io.permazen.CopyState
Get the mapping from object ID in the source transaction to object ID to use in the destination transaction.
getObjectMap() - Method in class io.permazen.ImportContext
Get the mapping from already imported POJO's to their corresponding database objects.
getObjectType() - Method in class io.permazen.schema.SchemaCompositeIndex
Get the SchemaObjectType of which this field is a member.
getObjectTypeName(int) - Method in class io.permazen.core.SchemaBundle
Get the object type name corresponding to the given storage ID.
getObjectTypes() - Method in exception io.permazen.core.InvalidReferenceException
Get the set of object types that are allowed to be referenced by the reference field.
getObjectTypes() - Method in class io.permazen.core.ReferenceEncoding
Get the object types this encoding is allowed to reference, if so restricted.
getObjectTypes() - Method in class io.permazen.core.ReferenceField
Get the object types this field is allowed to reference, if so restricted.
getObjectTypes() - Method in class io.permazen.PermazenReferenceField
Get the database object types which this field is allowed to reference.
getObjectTypes() - Method in class io.permazen.schema.ReferenceSchemaField
Get the object types this field is allowed to reference, if so restricted.
getObjId() - Method in class io.permazen.cli.parse.ObjInfo
 
getObjId() - Method in exception io.permazen.core.InvalidReferenceException
Get the ObjId of the object that could not be assigned to the reference field due to disallowed object type.
getObjId() - Method in exception io.permazen.core.TypeNotInSchemaException
Get the ObjId of the object that could not be migrated.
getObjId() - Method in interface io.permazen.PermazenObject
Get this instance's unique Permazen object identifier.
getObjId() - Method in exception io.permazen.UpgradeConversionException
Get the ID of the object containing the field whose value could not be converted.
getObjInfo(Session, ObjId) - Static method in class io.permazen.cli.parse.ObjInfo
Get object meta-data.
getObjType() - Method in class io.permazen.cli.parse.ObjInfo
 
getObjType() - Method in class io.permazen.core.Field
Get the ObjType that contains this field.
getObjType() - Method in class io.permazen.core.Index
Get the object type that contains the field(s) in this index.
getObjType() - Method in exception io.permazen.core.UnknownFieldException
Get the object in which the field was not found, if any.
getObjType(int) - Method in class io.permazen.core.Schema
Get the ObjType in this schema with the given storage ID.
getObjType(ObjId) - Method in class io.permazen.core.Transaction
Get the given object's ObjType.
getObjType(String) - Method in class io.permazen.core.Schema
Get the ObjType in this schema with the given name.
getObjTypes() - Method in class io.permazen.core.Schema
Get all of the ObjTypes that constitute this schema, indexed by type name.
getOffset() - Method in class io.permazen.util.ByteReader
Get current offset into buffer.
getOldValue() - Method in class io.permazen.change.ListFieldReplace
Get the value of the field before the change.
getOldValue() - Method in class io.permazen.change.MapFieldReplace
Get the value of the key/value pair before the change.
getOldValue() - Method in class io.permazen.change.SimpleFieldChange
Get the value of the field before the change.
getOldValue() - Method in class io.permazen.jsck.Issue
Get the original value, if any.
getOpenTransactions() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the set of open transactions associated with this database.
getOptionFlag() - Method in class io.permazen.cli.ParamParser.Param
 
getOptionFlags() - Method in class io.permazen.cli.ParamParser
Get option flags.
getOptions() - Method in class io.permazen.kv.leveldb.LevelDBAtomicKVStore
Get the Options this instance will use when opening the database at startup.
getOrdinal() - Method in class io.permazen.core.EnumValue
Get the enum ordinal value.
getOriginalInput() - Method in class io.permazen.util.ParseContext
Get the original input string as passed to the constructor.
getOutput() - Method in class io.permazen.cli.Session
Get the standard output for this CLI session.
getOwner() - Method in class io.permazen.cli.PermazenExecSession
 
getOwner() - Method in class io.permazen.cli.PermazenShellSession
 
getPageNumber() - Method in class io.permazen.util.NavigableSetPager
Get the current page number, if known.
getPageSize() - Method in class io.permazen.util.NavigableSetPager
Get the page size.
getPairIndex() - Method in class io.permazen.kv.raft.msg.InstallSnapshot
 
getParallelTransactionLoopCount() - Method in class io.permazen.kv.test.KVDatabaseTest
 
getParallelTransactionTaskCount() - Method in class io.permazen.kv.test.KVDatabaseTest
 
getParameters() - Method in class io.permazen.cli.ParamParser
Get regular parameters, in expected order.
getParent() - Method in class io.permazen.schema.SimpleSchemaField
Get the parent field if this is a sub-field of a ComplexSchemaField.
getParentField() - Method in class io.permazen.core.SimpleField
Get the parent field if this field is a sub-field of a complex field.
getParentField() - Method in class io.permazen.PermazenSimpleField
Get the PermazenComplexField of which this instance is a sub-field, if any.
getParseContext() - Method in exception io.permazen.util.ParseException
Get the associated ParseContext.
getParser() - Method in class io.permazen.cli.ParamParser.Param
 
getParser(String) - Method in class io.permazen.cli.cmd.AbstractCommand
Convert parameter spec type name into a Parser.
getParser(String) - Method in class io.permazen.cli.cmd.AbstractKVCommand
 
getParser(String) - Method in class io.permazen.cli.cmd.DecodeKeyCommand
 
getParser(String) - Method in class io.permazen.cli.cmd.KVLoadCommand
 
getParser(String) - Method in class io.permazen.cli.cmd.KVSaveCommand
 
getParser(String) - Method in class io.permazen.cli.cmd.LoadCommand
 
getParser(String) - Method in class io.permazen.cli.cmd.SaveCommand
 
getParser(String) - Method in class io.permazen.cli.cmd.SetSchemaRemovalCommand
 
getParser(String) - Method in class io.permazen.cli.cmd.SetSessionModeCommand
 
getParser(String) - Method in class io.permazen.cli.cmd.SetValidationModeCommand
 
getParser(String) - Method in class io.permazen.cli.ParamParser
Convert parameter spec type name into a Parser.
getPermazen() - Method in class io.permazen.cli.config.CliConfig
 
getPermazen() - Method in class io.permazen.cli.config.PermazenCliConfig
 
getPermazen() - Method in class io.permazen.cli.Session
Get the associated Permazen, if any.
getPermazen() - Method in class io.permazen.PermazenTransaction
Get the Permazen associated with this instance.
getPermazenClass() - Method in class io.permazen.PermazenField
Get the PermazenClass of which this field is a member.
getPermazenClass() - Method in interface io.permazen.PermazenObject
Get the PermazenClass of which this PermazenObject is an instance.
getPermazenClass(int) - Method in class io.permazen.Permazen
Get the PermazenClass associated with the given storage ID.
getPermazenClass(ObjId) - Method in class io.permazen.Permazen
Get the PermazenClass associated with the object ID.
getPermazenClass(Class<T>) - Method in class io.permazen.Permazen
Get the PermazenClass modeled by the given type.
getPermazenClass(String) - Method in class io.permazen.Permazen
Get the PermazenClass associated with the given object type name.
getPermazenClasses(Class<T>) - Method in class io.permazen.Permazen
Get all PermazenClasses which sub-type the given type.
getPermazenClassesByName() - Method in class io.permazen.Permazen
Get all PermazenClass's associated with this instance, indexed by object type name.
getPermazenClassesByStorageId() - Method in class io.permazen.Permazen
Get all PermazenClass's associated with this instance, indexed by storage ID.
getPermazenClassesByType() - Method in class io.permazen.Permazen
Get all PermazenClass's associated with this instance, indexed by Java model type.
getPermazenObject() - Method in class io.permazen.change.Change
Get the Java model object containing the field that changed.
getPermazenObjectMap() - Method in class io.permazen.ExportContext
Get the mapping from already exported database object to the corresponding POJO.
getPermazenSession() - Method in interface io.permazen.cli.HasPermazenSession
Get the Permazen Session associated with this instance.
getPermazenSession() - Method in class io.permazen.cli.jshell.PermazenJShellShellSession
 
getPermazenSession() - Method in class io.permazen.cli.PermazenExecRequest
 
getPermazenSession() - Method in class io.permazen.cli.PermazenExecSession
 
getPermazenSession() - Method in class io.permazen.cli.PermazenShellRequest
 
getPermazenSession() - Method in class io.permazen.cli.PermazenShellSession
 
getPermazenTransaction() - Method in class io.permazen.cli.Session
Get the PermazenTransaction currently associated with this instance.
getPermazenTransaction() - Method in class io.permazen.cli.Session.TxInfo
Get the associated PermazenTransaction, if any.
getPermazenTransaction() - Method in class io.permazen.ExportContext
Get the transaction from which objects are exported.
getPermazenTransaction() - Method in class io.permazen.ImportContext
Get the destination transaction for imported objects.
getPermazenTransaction() - Method in interface io.permazen.PermazenObject
Get this instance's associated PermazenTransaction.
getPort() - Method in class io.permazen.kv.raft.RaftKVImplementation.Config
 
getPragmas() - Method in class io.permazen.kv.sqlite.SQLiteKVImplementation.Config
 
getPrefix() - Method in class io.permazen.kv.fdb.FoundationKVImplementation.Config
 
getPrevLogIndex() - Method in class io.permazen.kv.raft.msg.AppendRequest
 
getPrevLogTerm() - Method in class io.permazen.kv.raft.msg.AppendRequest
 
getProjectId() - Method in class io.permazen.kv.spanner.SpannerKVImplementation.Config
 
getPutPairs() - Method in interface io.permazen.kv.mvcc.Mutations
Get the written key/value pairs contained by this instance.
getPutPairs() - Method in class io.permazen.kv.mvcc.Writes
 
getPuts() - Method in class io.permazen.kv.mvcc.Writes
Get the written key/value pairs contained by this instance.
getRaft() - Method in class io.permazen.kv.raft.RaftKVImplementation.Config
 
getRaftKVDatabase() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
getRandom(String) - Static method in class io.permazen.test.TestSupport
 
getRandomTaskMaxIterations() - Method in class io.permazen.kv.test.KVDatabaseTest
 
getRange(byte[], byte[]) - Method in interface io.permazen.kv.KVStore
Iterate the key/value pairs in the specified range in the forward direction.
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.array.ArrayKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.array.AtomicArrayKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.caching.CachingKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.caching.CachingKVTransaction
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.fdb.FoundationKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.fdb.FoundationKVTransaction
 
getRange(byte[], byte[], boolean) - Method in interface io.permazen.kv.KVStore
Iterate the key/value pairs in the specified range.
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.leveldb.LevelDBKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.lmdb.LMDBKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.mvcc.AtomicKVDatabase
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.mvcc.BranchedKVTransaction
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.mvcc.MemoryAtomicKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.mvcc.MutableView
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.mvstore.MVMapKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.raft.RaftKVTransaction
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.simple.SimpleKVTransaction
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.spanner.ReadOnlySpannerView
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.spanner.SpannerKVTransaction
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.util.ForwardingKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.util.MemoryKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.util.PrefixKVStore
 
getRange(byte[], byte[], boolean) - Method in class io.permazen.kv.xodus.XodusKVStore
 
getRange(KeyRange) - Method in interface io.permazen.kv.KVStore
Iterate the key/value pairs in the specified range in the forward direction.
getReads() - Method in interface io.permazen.kv.mvcc.DeltaKVStore
Get the Reads associated with this instance.
getReads() - Method in class io.permazen.kv.mvcc.MutableView
 
getReadsData() - Method in class io.permazen.kv.raft.msg.CommitRequest
 
getRecipientId() - Method in class io.permazen.kv.raft.msg.Message
Get the identity of the recipient.
getReferenceFields() - Method in class io.permazen.ReferencePath
Get the storage IDs of the reference fields in this path in the order they occur.
getReferrer() - Method in exception io.permazen.core.ReferencedObjectException
Get the ID of the object that still refers to the object that was to be deleted.
getRejoinMergeStrategy() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Get the merge strategy to apply when transitioning from a lower priority database to this database because our RaftKVDatabase cluster has become available.
getRemoveRanges() - Method in interface io.permazen.kv.mvcc.Mutations
Get the key ranges removals contained by this instance.
getRemoveRanges() - Method in class io.permazen.kv.mvcc.Writes
 
getRemoves() - Method in class io.permazen.kv.mvcc.Writes
Get the key ranges removals contained by this instance.
getResourceFactory() - Method in class io.permazen.spring.PermazenTransactionManager
 
getRttEstimate() - Method in class io.permazen.kv.caching.CachingKVDatabase
Get the current round trip time estimate.
getRttEstimate() - Method in class io.permazen.kv.caching.CachingKVStore
Get the current round trip time estimate.
getRttEstimate() - Method in class io.permazen.kv.spanner.ReadWriteSpannerView
Get the current RTT estimate.
getRttEstimate() - Method in class io.permazen.kv.spanner.SpannerKVDatabase
Get the current round trip time estimate.
getSchema() - Method in class io.permazen.cli.parse.ObjInfo
 
getSchema() - Method in class io.permazen.core.SchemaItem
Get the schema with which this instance is associated.
getSchema() - Method in class io.permazen.core.Transaction
Get the database schema associated with this transaction.
getSchema() - Method in exception io.permazen.core.UnknownTypeException
Get the schema in which the type was not found.
getSchema() - Method in class io.permazen.kv.mssql.MSSQLKVDatabase
Get schema name.
getSchema(int) - Method in class io.permazen.core.SchemaBundle
Get the Schema in this bundle with the given schema index.
getSchema(SchemaId) - Method in class io.permazen.core.SchemaBundle
Get the Schema in this bundle having the given schema ID.
getSchemaBundle() - Method in class io.permazen.core.Schema
Get the schema bundle that this instance is a member of.
getSchemaBundle() - Method in class io.permazen.core.Transaction
Get the database's schema bundle
getSchemaBytes() - Method in class io.permazen.core.SchemaBundle.Encoded
Get the encoded schema table.
getSchemaCompositeIndexes() - Method in class io.permazen.schema.SchemaObjectType
Get the SchemaCompositeIndexs defined on this object type's fields, indexed by name.
getSchemaEpoch() - Method in class io.permazen.schema.SchemaObjectType
Get the schema epoch included in the calculation of SchemaSupport.getSchemaId().
getSchemaFields() - Method in class io.permazen.schema.SchemaObjectType
Get this object type's SchemaFields, indexed by name.
getSchemaId() - Method in class io.permazen.core.Schema
Get the schema ID associated with this instance.
getSchemaId() - Method in class io.permazen.core.SchemaItem
Get the schema ID associated with this instance.
getSchemaId() - Method in exception io.permazen.core.SchemaMismatchException
Get the ID of the schema that failed to match.
getSchemaId() - Method in interface io.permazen.PermazenObject
Get the SchemaId that identifies this instance's current schema.
getSchemaId() - Method in class io.permazen.PermazenSchemaItem
Get the schema ID of this instance.
getSchemaId() - Method in class io.permazen.schema.SchemaModel
Generate a unique SchemaId corresponding to the type and encoding structure of this schema item.
getSchemaIdsByStorageId() - Method in class io.permazen.core.SchemaBundle
Get all of the storage ID's in this bundle with their corresponding SchemaId's.
getSchemaIndex() - Method in exception io.permazen.core.InvalidObjectVersionException
Get the invalid schema index number found.
getSchemaIndex() - Method in class io.permazen.core.Schema
Get the schema index associated with this instance.
getSchemaIndex(KVStore) - Static method in class io.permazen.core.Layout
Get a CoreIndex1 view of the object schema index in a key/value database.
getSchemaIndexKeyPrefix() - Static method in class io.permazen.core.Layout
Get the common prefix of all object schema index entries.
getSchemaItem() - Method in class io.permazen.PermazenClass
 
getSchemaItem() - Method in class io.permazen.PermazenCollectionField
 
getSchemaItem() - Method in class io.permazen.PermazenComplexField
 
getSchemaItem() - Method in class io.permazen.PermazenCompositeIndex
 
getSchemaItem() - Method in class io.permazen.PermazenCounterField
 
getSchemaItem() - Method in class io.permazen.PermazenEnumArrayField
 
getSchemaItem() - Method in class io.permazen.PermazenEnumField
 
getSchemaItem() - Method in class io.permazen.PermazenField
 
getSchemaItem() - Method in class io.permazen.PermazenListField
 
getSchemaItem() - Method in class io.permazen.PermazenMapField
 
getSchemaItem() - Method in class io.permazen.PermazenReferenceField
 
getSchemaItem() - Method in class io.permazen.PermazenSchemaItem
Get the corresonding core API database instance.
getSchemaItem() - Method in class io.permazen.PermazenSetField
 
getSchemaItem() - Method in class io.permazen.PermazenSimpleField
 
getSchemaModel() - Method in class io.permazen.cli.Session
Get the SchemaModel configured for this instance.
getSchemaModel() - Method in class io.permazen.core.Schema
Get the original SchemaModel on which this instance is based as it is recorded in the database.
getSchemaModel() - Method in class io.permazen.core.TransactionConfig
Get the schema model to use.
getSchemaModel() - Method in class io.permazen.Permazen
Get the SchemaModel associated with this instance derived from the annotations on the scanned classes, including actual storage ID assignments.
getSchemaModel(boolean) - Method in class io.permazen.core.Schema
Get the SchemaModel on which this instance is based, optionally including explicit storage ID assignments.
getSchemaModel(boolean) - Method in class io.permazen.Permazen
Get the SchemaModel associated with this instance derived from the annotations on the scanned classes.
getSchemaObjectTypes() - Method in class io.permazen.schema.SchemaModel
Get the object types defined in this schema.
getSchemaOverrides() - Method in class io.permazen.jsck.JsckConfig
Configure schemas to forcibly apply into the schema table.
getSchemaRemoval() - Method in class io.permazen.cli.Session
Get the obsolete schema removal policy.
getSchemaRemoval() - Method in class io.permazen.core.TransactionConfig
Get when to automatically detect and remove unused schemas.
getSchemasBySchemaId() - Method in class io.permazen.core.SchemaBundle
Get all of the schemas in this bundle keyed by SchemaId.
getSchemasBySchemaIndex() - Method in class io.permazen.core.SchemaBundle
Get all of the schemas in this bundle keyed by schema index.
getSchemaTablePrefix() - Static method in class io.permazen.core.Layout
Get the common prefix of all schema table keys.
getSenderId() - Method in class io.permazen.kv.raft.msg.Message
Get the identity of the sender.
getSequentialTransactionLoopCount() - Method in class io.permazen.kv.test.KVDatabaseTest
 
getSessionModes() - Method in class io.permazen.cli.app.cmd.SetLogLevelCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.AbstractCommand
Get the SessionMode(s) supported by this command.
getSessionModes() - Method in interface io.permazen.cli.cmd.Command
Get the SessionMode(s) supported by this command.
getSessionModes() - Method in class io.permazen.cli.cmd.CompareSchemasCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.InfoCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.KVGetCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.KVLoadCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.KVPutCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.KVRemoveCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.KVSaveCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.SetSessionModeCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.SetValidationModeCommand
 
getSessionModes() - Method in class io.permazen.cli.cmd.ShowSchemaCommand
 
getSessionModes() - Method in class io.permazen.jsck.cmd.JsckCommand
 
getSessionModes() - Method in class io.permazen.kv.raft.cmd.AbstractRaftCommand
 
getSessionModes() - Method in class io.permazen.kv.raft.cmd.RaftFallbackForceStandaloneCommand
 
getSessionModes() - Method in class io.permazen.kv.raft.cmd.RaftFallbackStatusCommand
 
getSetter() - Method in class io.permazen.PermazenSimpleField
Get the setter method associated with this field.
getSingleton(Class<T>) - Method in class io.permazen.PermazenTransaction
Get the singleton instance of the given type, creating it on demand if needed.
getSize() - Method in class io.permazen.encoding.TupleEncoding
Get the number of component encodings in this encoding.
getSize() - Method in class io.permazen.tuple.Tuple1
 
getSize() - Method in class io.permazen.tuple.Tuple2
 
getSize() - Method in class io.permazen.tuple.Tuple3
 
getSize() - Method in class io.permazen.tuple.Tuple4
 
getSize() - Method in class io.permazen.tuple.Tuple5
 
getSize() - Method in interface io.permazen.tuple.Tuple
Get the number of values in this tuple.
getSnapshotConfig() - Method in class io.permazen.kv.raft.msg.InstallSnapshot
 
getSnapshotIndex() - Method in class io.permazen.kv.raft.msg.InstallSnapshot
 
getSnapshotTerm() - Method in class io.permazen.kv.raft.msg.InstallSnapshot
 
getSnapshotTimestamp() - Method in class io.permazen.kv.raft.Follower
Get the (leader's) timestamp of the most recent snapshot install sent to this follower, if any.
getSources() - Method in class io.permazen.core.util.ObjIdBiMultiMap
Get all sources associated with this instance that have one or more associated targets.
getSources(ObjId) - Method in class io.permazen.core.util.ObjIdBiMultiMap
Get the sources associated with the given target, if any.
getStandaloneTarget() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get the configured "standalone mode" KVDatabase to be used when all FallbackTargets are unavailable.
getStartingType() - Method in class io.permazen.ReferencePath
Get the narrowest possible Java type of the object(s) at which this path starts.
getStartingTypes() - Method in class io.permazen.ReferencePath
Get the possible model object types for the objects at the start of this path.
getState() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the state of this transaction.
getStateFile() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get this instance's persistent state file.
getStorageId() - Method in class io.permazen.core.ObjId
Get the storage ID associated with this instance.
getStorageId() - Method in class io.permazen.core.SchemaItem
Get the storage ID associated with this instance.
getStorageId() - Method in class io.permazen.PermazenSchemaItem
Get the storage ID of this instance.
getStorageId() - Method in class io.permazen.schema.SchemaItem
Get the storage ID associated with this instance.
getStorageId(SchemaId) - Method in class io.permazen.core.SchemaBundle
Get the storage ID corresponding to the given schema ID.
getStorageIdBytes() - Method in class io.permazen.core.SchemaBundle.Encoded
Get the encoded storage ID table.
getStorageIdOverrides() - Method in class io.permazen.jsck.JsckConfig
Configure SchemaIds to forcibly apply into the storage ID table.
getStorageIdTablePrefix() - Static method in class io.permazen.core.Layout
Get the common prefix of all storage ID table keys.
getStore() - Method in exception io.permazen.kv.KVDatabaseException
Get the KVDatabase that generated this exception.
getStore() - Method in class io.permazen.kv.xodus.XodusKVStore
Get the Store associated with this instance.
getStoreName() - Method in class io.permazen.kv.xodus.XodusKVDatabase
Get the Xodus store name to use.
getStoreName() - Method in class io.permazen.kv.xodus.XodusKVImplementation.Config
 
getString(ByteBuffer) - Static method in class io.permazen.kv.raft.msg.Message
Deserialize a String previously serialized by putString() from the buffer.
getSubField(String) - Method in class io.permazen.PermazenComplexField
Get the sub-field with the given name.
getSubFields() - Method in class io.permazen.core.CollectionField
 
getSubFields() - Method in class io.permazen.core.ComplexField
Get the sub-field(s) associated with this instance, ordered according to their meaning.
getSubFields() - Method in class io.permazen.core.MapField
 
getSubFields() - Method in class io.permazen.PermazenCollectionField
 
getSubFields() - Method in class io.permazen.PermazenComplexField
Get the sub-fields associated with this field.
getSubFields() - Method in class io.permazen.PermazenMapField
 
getSubFields() - Method in class io.permazen.schema.CollectionSchemaField
 
getSubFields() - Method in class io.permazen.schema.ComplexSchemaField
Get the sub-fields of this field.
getSubFields() - Method in class io.permazen.schema.MapSchemaField
 
getTableName() - Method in class io.permazen.kv.spanner.SpannerKVImplementation.Config
 
getTableName() - Method in class io.permazen.kv.sql.SQLKVDatabase
Get the name of the table containing keys and values.
getTarget() - Method in class io.permazen.util.CloseableRefs
Get the underlying target instance, which must not yet be closed.
getTargets() - Method in class io.permazen.core.util.ObjIdBiMultiMap
Get all targets associated with this instance that have one or more associated sources.
getTargets(ObjId) - Method in class io.permazen.core.util.ObjIdBiMultiMap
Get the targets associated with the given source, if any.
getTargetType() - Method in class io.permazen.ReferencePath
Get the narrowest possible Java type of the object(s) at which this path ends.
getTargetTypes() - Method in class io.permazen.ReferencePath
Get the possible model object types for the objects at the end of this path.
getTerm() - Method in class io.permazen.kv.raft.LogEntry
Get the term of this instance.
getTerm() - Method in class io.permazen.kv.raft.msg.Message
Get the term of the sender of this message.
getThreadPoolSize() - Method in class io.permazen.kv.caching.CachingKVDatabase
Get the number of threads in the internally-created thread pool.
getThreadPoolSize() - Method in class io.permazen.kv.spanner.SpannerKVDatabase
Get the number of threads in the background task thread pool.
getThreadPriority() - Method in class io.permazen.kv.raft.fallback.FallbackKVDatabase
Get the configured internal service thread priority.
getThreadPriority() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the configured internal service thread priority.
getTimestamp() - Method in class io.permazen.kv.raft.msg.PingRequest
Get the ping request timestamp.
getTimestamp() - Method in class io.permazen.kv.spanner.SpannerKVTransaction
Get the timestamp associated with this transaction.
getTimestamp(ByteBuffer, int) - Static method in class io.permazen.kv.raft.msg.Message
Deserialize a Timestamp value previously serialized by putTimestamp() from the buffer.
getTotalMillisWaiting() - Method in class io.permazen.kv.array.AtomicArrayKVStore
Get the total number of milliseconds spent in artificial delays caused by waiting for compaction.
getTransaction() - Method in class io.permazen.cli.Session
Get the Transaction currently associated with this instance.
getTransaction() - Method in class io.permazen.cli.Session.TxInfo
Get the associated Transaction, if any.
getTransaction() - Method in exception io.permazen.core.TransactionException
Get the associated transaction.
getTransaction() - Method in class io.permazen.DetachedPermazenTransaction
Get the DetachedTransaction associated with this instance.
getTransaction() - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction
Get the underlying Transaction associated with this instance.
getTransaction() - Method in class io.permazen.kv.fdb.FoundationKVStore
Get the underlying Transaction associated with this instance.
getTransaction() - Method in class io.permazen.kv.fdb.FoundationKVTransaction
Get the underlying Transaction associated with this instance.
getTransaction() - Method in exception io.permazen.kv.KVTransactionException
Get the KVTransaction that generated this exception.
getTransaction() - Method in class io.permazen.kv.lmdb.LMDBKVStore
Get the Txn associated with this instance.
getTransaction() - Method in class io.permazen.kv.xodus.XodusKVStore
Get the Transaction associated with this instance.
getTransaction() - Method in class io.permazen.PermazenTransaction
Get the Transaction associated with this instance.
getTransactionConfig() - Method in class io.permazen.kv.bdb.BerkeleyKVDatabase
Get the default TransactionConfig to be used by this instance.
getTransactionConfig(Session) - Method in interface io.permazen.cli.Session.TransactionalAction
Get the configuration for the new Core API transaction.
getTransactionMode(Session) - Method in interface io.permazen.cli.cmd.AbstractKVCommand.KVAction
 
getTransactionMode(Session) - Method in interface io.permazen.cli.Session.TransactionalAction
Get the SessionMode corresponding to the transaction that should be opened.
getTransactionOptions() - Method in interface io.permazen.cli.Session.TransactionalActionWithOptions
Get the options, if any, to be used when creating a new transaction for this action to run in.
getTransactionOptions() - Method in class io.permazen.kv.raft.cmd.AbstractTransactionRaftCommand.RaftTransactionAction
 
getTransactionTimeout() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Get the transaction timeout used when determining database availability.
getTransactionType() - Method in class io.permazen.kv.xodus.XodusKVStore
Get the TransactionType associated with this instance.
getTuple2Encoding() - Method in class io.permazen.encoding.Concat2Encoding
 
getTuple3Encoding() - Method in class io.permazen.encoding.Concat3Encoding
 
getTuple4Encoding() - Method in class io.permazen.encoding.Concat4Encoding
 
getTuple5Encoding() - Method in class io.permazen.encoding.Concat5Encoding
 
getTxId() - Method in class io.permazen.kv.raft.msg.CommitRequest
 
getTxId() - Method in class io.permazen.kv.raft.msg.CommitResponse
Get the sender's ID for the transaction.
getTxId() - Method in class io.permazen.kv.raft.RaftKVTransaction
Get the locally unique ID of this transaction.
getTxInfo() - Method in class io.permazen.cli.Session
Get information about the transaction currently associated with this instance.
getType() - Method in class io.permazen.PermazenClass
Get the Java model object type associated with this instance.
getTypeCode() - Method in enum class io.permazen.schema.ItemType
Get the type code, which prefixes generated SchemaIds.
getTypeDescription(ObjId) - Method in class io.permazen.core.Transaction
Get a description of the given object's type.
getTypeName() - Method in class io.permazen.cli.ParamParser.Param
 
getTypeName() - Method in exception io.permazen.core.InvalidReferenceException
Get the name of the object type that could not be assigned to the reference field due to disallowed object type.
getTypeName() - Method in exception io.permazen.core.UnknownTypeException
Get the type name that was not recognized.
getTypeName(int) - Method in class io.permazen.core.Transaction
Get the object type assigned to the given storage ID.
getTypeParameter(Type, int) - Static method in class io.permazen.Util
Get the n'th generic type parameter.
getTypeToken() - Method in class io.permazen.core.Field
Get the Java type corresponding to this field.
getTypeToken() - Method in class io.permazen.encoding.AbstractEncoding
 
getTypeToken() - Method in interface io.permazen.encoding.Encoding
Get the Java type corresponding to this encoding's values.
getTypeToken() - Method in class io.permazen.PermazenCollectionField
 
getTypeToken() - Method in class io.permazen.PermazenCounterField
 
getTypeToken() - Method in class io.permazen.PermazenEnumField
 
getTypeToken() - Method in class io.permazen.PermazenField
Get the type of this field.
getTypeToken() - Method in class io.permazen.PermazenMapField
 
getTypeToken() - Method in class io.permazen.PermazenSimpleField
Get the type of this field.
getUnappliedLog() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the unapplied LogEntrys in this instance's Raft log.
getUnappliedLogMemoryUsage() - Method in class io.permazen.kv.raft.RaftKVDatabase
Get the estimated total memory used by unapplied log entries.
getUnavailableMergeStrategy() - Method in class io.permazen.kv.raft.fallback.FallbackTarget
Get the merge strategy to apply when transitioning from this database to a lower priority database because our RaftKVDatabase cluster has become unavailable.
getUnresolvedReferences() - Method in class io.permazen.core.util.XMLObjectSerializer
Get all unresolved forward object references.
getUpperBound() - Method in class io.permazen.util.Bounds
Get the Java value corresponding to the upper bound restriction, if any.
getUpperBoundType() - Method in class io.permazen.util.Bounds
Get the type of the upper bound that corresponds to Bounds.getUpperBound().
getUsage() - Method in class io.permazen.cli.cmd.AbstractCommand
Get command usage string.
getUsage() - Method in interface io.permazen.cli.cmd.Command
Get command usage string.
getUsage() - Method in class io.permazen.cli.ParamParser
Build a usage summary string.
getUsage(String) - Method in class io.permazen.cli.SimpleCommandWrapper
 
getUserMetaDataKeyPrefix() - Static method in class io.permazen.core.Layout
Get the common prefix of all user-defined meta-data keys.
getUserObject() - Method in class io.permazen.core.Transaction
Get the object with this instance by setUserObject(), if any.
getValidationMode() - Method in class io.permazen.cli.Session
Get the ValidationMode associated with this instance.
getValidationMode() - Method in class io.permazen.PermazenTransaction
Get the ValidationMode configured for this instance.
getValidatorFactory() - Method in class io.permazen.PermazenConfig
Get the ValidatorFactory that will create the Validators used for validation within transactions.
getValsLength() - Method in class io.permazen.kv.array.ArrayKVWriter
Get the number of bytes written so far to the value data file.
getValue() - Method in class io.permazen.change.MapFieldAdd
Get the value of the new key/value pair that was added.
getValue() - Method in class io.permazen.change.MapFieldRemove
Get the value of the key/value pair that was removed.
getValue() - Method in class io.permazen.kv.KVPair
Get the value.
getValue(int) - Method in class io.permazen.util.ImmutableNavigableMap
Get the value at the specified index.
getValue(Transaction, ObjId) - Method in class io.permazen.core.CollectionField
 
getValue(Transaction, ObjId) - Method in class io.permazen.core.CounterField
 
getValue(Transaction, ObjId) - Method in class io.permazen.core.Field
Get the value of this field in the given object.
getValue(Transaction, ObjId) - Method in class io.permazen.core.ListField
 
getValue(Transaction, ObjId) - Method in class io.permazen.core.MapField
 
getValue(Transaction, ObjId) - Method in class io.permazen.core.SetField
 
getValue(Transaction, ObjId) - Method in class io.permazen.core.SimpleField
 
getValue(PermazenObject) - Method in class io.permazen.PermazenCollectionField
 
getValue(PermazenObject) - Method in class io.permazen.PermazenCounterField
 
getValue(PermazenObject) - Method in class io.permazen.PermazenField
Get the Java value of this field in the given Java model object.
getValue(PermazenObject) - Method in class io.permazen.PermazenListField
 
getValue(PermazenObject) - Method in class io.permazen.PermazenMapField
 
getValue(PermazenObject) - Method in class io.permazen.PermazenReferenceField
 
getValue(PermazenObject) - Method in class io.permazen.PermazenSetField
 
getValue(PermazenObject) - Method in class io.permazen.PermazenSimpleField
 
getValue1() - Method in class io.permazen.tuple.Tuple1
 
getValue1() - Method in interface io.permazen.tuple.Has1
Get the first value.
getValue2() - Method in class io.permazen.tuple.Tuple3
 
getValue2() - Method in interface io.permazen.tuple.Has2
Get the second value.
getValue3() - Method in class io.permazen.tuple.Tuple3
 
getValue3() - Method in interface io.permazen.tuple.Has3
Get the third value.
getValue4() - Method in class io.permazen.tuple.Tuple5
 
getValue4() - Method in interface io.permazen.tuple.Has4
Get the fourth value.
getValue5() - Method in class io.permazen.tuple.Tuple5
 
getValue5() - Method in interface io.permazen.tuple.Has5
Get the fifth value.
getValueColumnName() - Method in class io.permazen.kv.sql.SQLKVDatabase
Get the name of the column containing values.
getValueConverter() - Method in class io.permazen.util.ConvertedNavigableMap
 
getValueField() - Method in class io.permazen.core.MapField
Get the value field.
getValueField() - Method in class io.permazen.PermazenMapField
Get the value sub-field.
getValueField() - Method in class io.permazen.schema.MapSchemaField
Get this map field's value sub-field.
getValueIndex(Transaction) - Method in class io.permazen.core.MapValueIndex
Get this index's view of the given transaction, including entry key.
getViolations() - Method in exception io.permazen.ValidationException
Get the validation errors in case validation failed due to a failed JSR 303 validation check.
getVotedFor() - Method in class io.permazen.kv.raft.FollowerRole
Get the identity of the node that this node voted for this term, if any.
getVotesReceived() - Method in class io.permazen.kv.raft.CandidateRole
Get the number of votes received so far.
getVotesRequired() - Method in class io.permazen.kv.raft.CandidateRole
Get the number of votes required to win the election.
getWaitFactor() - Method in class io.permazen.kv.caching.AbstractCachingConfig
 
getWaitFactor() - Method in interface io.permazen.kv.caching.CachingConfig
Get the wait factor.
getWaitFactor() - Method in class io.permazen.kv.caching.CachingKVStore
 
getWaitTimeout() - Method in class io.permazen.kv.simple.SimpleKVDatabase
Get the wait timeout for newly created transactions.
getWildcardedType(Class<T>) - Static method in class io.permazen.util.TypeTokens
Parameterize the raw type with wildcards.
getWords() - Method in class io.permazen.cli.parse.WordParser
Get the set of valid words, if there is such a set.
getWrappedList() - Method in class io.permazen.util.ConvertedList
Get the wrapped List.
getWrappedNavigableSet() - Method in class io.permazen.util.ConvertedNavigableSet
Get the wrapped NavigableSet.
getWrappedSet() - Method in class io.permazen.util.ConvertedSet
Get the wrapped Set.
getWrappedSpliterator() - Method in class io.permazen.util.ConvertedSpliterator
Get the wrapped Spliterator.
getWrites() - Method in interface io.permazen.kv.mvcc.DeltaKVStore
Get the Writes associated with this instance.
getWrites() - Method in class io.permazen.kv.mvcc.MutableView
 
GrantVote - Class in io.permazen.kv.raft.msg
Sent from a follower to a candidate to grant a vote during an election.
GrantVote(int, String, String, long) - Constructor for class io.permazen.kv.raft.msg.GrantVote
Constructor.
groups() - Element in annotation interface io.permazen.annotation.OnValidate
Specify the validation group(s) for which the annotated method should be invoked.
gt(T) - Static method in class io.permazen.util.Bounds
Create an instance with an exclusive lower bound.

H

handleCloseException(IOException) - Method in class io.permazen.util.CloseableRefs
Handle an exception being thrown by Closeable.close() when closing the target.
handleException(SQLException) - Method in class io.permazen.kv.sql.SQLKVTransaction
Handle an unexpected SQL exception.
Has1<V1> - Interface in io.permazen.tuple
Implemented by tuples that have a first value.
Has2<V1,V2> - Interface in io.permazen.tuple
Implemented by tuples that have at least two values.
Has3<V1,V2,V3> - Interface in io.permazen.tuple
Implemented by tuples that have at least three values.
Has4<V1,V2,V3,V4> - Interface in io.permazen.tuple
Implemented by tuples that have at least four values.
Has5<V1,V2,V3,V4,V5> - Interface in io.permazen.tuple
Implemented by tuples that have at least five values.
hasCharacteristics(int) - Method in class io.permazen.util.ConvertedSpliterator
 
hasCoreAPI() - Method in enum class io.permazen.cli.SessionMode
Determine whether the core API (e.g., Transaction) is available in this mode.
hasCurrent() - Static method in class io.permazen.PermazenTransaction
Determine if there is a PermazenTransaction associated with the current thread.
hasDefaultValidationAnnotation(AnnotatedElement) - Static method in class io.permazen.Util
Determine whether the given object has any JSR 303 annotation(s) defining validation constraints in the default group.
hasDefaultValue(Transaction, ObjId) - Method in class io.permazen.core.CollectionField
 
hasDefaultValue(Transaction, ObjId) - Method in class io.permazen.core.CounterField
 
hasDefaultValue(Transaction, ObjId) - Method in class io.permazen.core.Field
Determine if this field in the specified object has its default value in the specified Transaction.
hasDefaultValue(Transaction, ObjId) - Method in class io.permazen.core.MapField
 
hasDefaultValue(Transaction, ObjId) - Method in class io.permazen.core.SimpleField
 
hasFixedEncoding() - Method in class io.permazen.schema.AbstractEnumSchemaField
 
hasFixedEncoding() - Method in class io.permazen.schema.ReferenceSchemaField
 
hasFixedEncoding() - Method in class io.permazen.schema.SimpleSchemaField
Determine if this field has a fixed encoding.
hashCode() - Method in class io.permazen.change.Change
 
hashCode() - Method in class io.permazen.change.FieldChange
 
hashCode() - Method in class io.permazen.change.ListFieldAdd
 
hashCode() - Method in class io.permazen.change.ListFieldRemove
 
hashCode() - Method in class io.permazen.change.ListFieldReplace
 
hashCode() - Method in class io.permazen.change.MapFieldAdd
 
hashCode() - Method in class io.permazen.change.MapFieldRemove
 
hashCode() - Method in class io.permazen.change.MapFieldReplace
 
hashCode() - Method in class io.permazen.change.SetFieldAdd
 
hashCode() - Method in class io.permazen.change.SetFieldRemove
 
hashCode() - Method in class io.permazen.change.SimpleFieldChange
 
hashCode() - Method in class io.permazen.core.EnumValue
 
hashCode() - Method in class io.permazen.core.ObjId
Returns the hash code value for this instance.
hashCode() - Method in class io.permazen.core.ReferenceEncoding
 
hashCode() - Method in class io.permazen.core.SchemaBundle.Encoded
 
hashCode() - Method in class io.permazen.core.util.ObjIdBiMultiMap
Calculate a hash code value for this instance.
hashCode() - Method in class io.permazen.core.util.ObjIdMap
 
hashCode() - Method in class io.permazen.core.util.ObjIdSet
 
hashCode() - Method in class io.permazen.encoding.AbstractEncoding
 
hashCode() - Method in class io.permazen.encoding.ArrayEncoding
 
hashCode() - Method in class io.permazen.encoding.ConvertedEncoding
 
hashCode() - Method in class io.permazen.encoding.EncodingId
 
hashCode() - Method in class io.permazen.encoding.NullSafeEncoding
 
hashCode() - Method in class io.permazen.encoding.PrimitiveEncoding
 
hashCode() - Method in class io.permazen.EnumConverter
 
hashCode() - Method in class io.permazen.jsck.Issue
 
hashCode() - Method in class io.permazen.kv.KeyRange
 
hashCode() - Method in class io.permazen.kv.KeyRanges
 
hashCode() - Method in class io.permazen.kv.KVPair
Calculate hash code.
hashCode() - Method in class io.permazen.kv.mvcc.ReadRemoveConflict
 
hashCode() - Method in class io.permazen.kv.mvcc.ReadWriteConflict
 
hashCode() - Method in class io.permazen.kv.raft.Timestamp
 
hashCode() - Method in class io.permazen.ReferencePath
 
hashCode() - Method in class io.permazen.schema.AbstractEnumSchemaField
 
hashCode() - Method in class io.permazen.schema.ComplexSchemaField
 
hashCode() - Method in class io.permazen.schema.EnumArraySchemaField
 
hashCode() - Method in class io.permazen.schema.ReferenceSchemaField
 
hashCode() - Method in class io.permazen.schema.SchemaCompositeIndex
 
hashCode() - Method in class io.permazen.schema.SchemaId
 
hashCode() - Method in class io.permazen.schema.SchemaItem
 
hashCode() - Method in class io.permazen.schema.SchemaModel
 
hashCode() - Method in class io.permazen.schema.SchemaObjectType
 
hashCode() - Method in class io.permazen.schema.SimpleSchemaField
 
hashCode() - Method in class io.permazen.spring.PermazenTransactionManager.TransactionSynchronizationCallback
 
hashCode() - Method in class io.permazen.tuple.Tuple1
 
hashCode() - Method in interface io.permazen.tuple.Tuple
Compute hash code.
hashCode() - Method in class io.permazen.util.AbstractIterationSet
 
hashCode() - Method in class io.permazen.util.Bounds
 
hashCode() - Method in class io.permazen.util.ConvertedSpliterator
 
hashCode() - Method in class io.permazen.util.ParseContext
 
hasLowerBound() - Method in class io.permazen.util.Bounds
Determine whether this instance has a lower bound.
hasNext() - Method in class io.permazen.kv.bdb.BerkeleyKVTransaction.CursorIterator
 
hasNext() - Method in class io.permazen.kv.KVPairIterator
 
hasNext() - Method in class io.permazen.kv.mvstore.CursorIterator
 
hasNext() - Method in class io.permazen.kv.util.AbstractKVIterator
 
hasNext() - Method in class io.permazen.util.UniqueIterator
 
hasNextPage() - Method in class io.permazen.util.NavigableSetPager
Indicates that there are more results after the current page.
hasOccurred() - Method in class io.permazen.kv.raft.Timestamp
Determine whether this timestamp is in the past or the future.
hasPermazen() - Method in enum class io.permazen.cli.SessionMode
Determine whether the Permazen Java API (e.g., PermazenTransaction) based on a Permazen instance is available in this mode.
HasPermazenSession - Interface in io.permazen.cli
Implemented by our customized JCT objects that can provide access to the current Permazen Session.
hasPrefix0x00() - Method in class io.permazen.core.ObjIdEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.BigDecimalEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.BigIntegerEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.BitSetEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.BooleanArrayEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.BooleanEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.CharacterArrayEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.CharacterEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.ConvertedEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.DateEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.DoubleArrayEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.DoubleEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.DurationEncoding
 
hasPrefix0x00() - Method in interface io.permazen.encoding.Encoding
Determine whether any of this encoding's encoded values start with a 0x00 byte.
hasPrefix0x00() - Method in class io.permazen.encoding.FloatArrayEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.FloatEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.Inet4AddressEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.Inet6AddressEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.InetAddressEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.InstantEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.IntegralArrayEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.IntegralEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.LocalDateEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.LocalDateTimeEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.LocalTimeEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.MonthDayEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.NullSafeEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.ObjectArrayEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.PeriodEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.StringEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.TupleEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.UnsignedIntEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.UUIDEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.VoidEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.YearEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.YearMonthEncoding
 
hasPrefix0x00() - Method in class io.permazen.encoding.ZoneOffsetEncoding
 
hasPrefix0xff() - Method in class io.permazen.core.ObjIdEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.BigDecimalEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.BigIntegerEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.BitSetEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.BooleanArrayEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.BooleanEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.CharacterArrayEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.CharacterEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.ConvertedEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.DateEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.DoubleArrayEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.DoubleEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.DurationEncoding
 
hasPrefix0xff() - Method in interface io.permazen.encoding.Encoding
Determine whether any of this encoding's encoded values start with a 0xff byte.
hasPrefix0xff() - Method in class io.permazen.encoding.FloatArrayEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.FloatEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.Inet4AddressEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.Inet6AddressEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.InetAddressEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.InstantEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.IntegralArrayEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.IntegralEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.LocalDateEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.LocalDateTimeEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.LocalTimeEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.MonthDayEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.NullSafeEncoding
Always returns true.
hasPrefix0xff() - Method in class io.permazen.encoding.ObjectArrayEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.PeriodEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.StringEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.TupleEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.UnsignedIntEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.UUIDEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.VoidEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.YearEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.YearMonthEncoding
 
hasPrefix0xff() - Method in class io.permazen.encoding.ZoneOffsetEncoding
 
hasPrevPage() - Method in class io.permazen.util.NavigableSetPager
Indicates that there are more results before the current page.
hasTransaction() - Method in class io.permazen.cli.Session
Determine whether there is a transaction associated with this instance.
hasUpperBound() - Method in class io.permazen.util.Bounds
Determine whether this instance has an upper bound.
hasValidation(Class<?>) - Static method in class io.permazen.Util
Determine if any JSR 303 validation annotations are present on the given type itself or any of its methods (public methods only).
hasValidationAnnotation(AnnotatedElement) - Static method in class io.permazen.Util
Determine whether the given object has any JSR 303 annotation(s).
headMap(K) - Method in class io.permazen.util.