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

A

AALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
AASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
abnormalClose() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Used by error handling to forcibly close an environment, and by tests to close an environment to simulate a crash.
abnormalClose() - Method in class com.sleepycat.je.rep.impl.RepImpl
Used by error handling to forcibly close an environment, and by tests to close an environment to simulate a crash.
abnormalClose() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
abort(Exception) - Method in class com.sleepycat.je.rep.impl.node.MasterTransfer
Aborts an existing, in-progress Master Transfer operation, if it hasn't reached the point of no return.
abort() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
abort(boolean) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
abort(ReplicationContext, int) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
abort(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
abort() - Method in class com.sleepycat.je.Transaction
Cause an abnormal termination of the transaction.
abort(Transaction) - Method in interface com.sleepycat.je.trigger.TransactionTrigger
The trigger method invoked after the transaction has been aborted.
abort(Xid) - Method in class com.sleepycat.je.txn.Txn
 
abort() - Method in class com.sleepycat.je.txn.Txn
Abort this transaction.
abort(boolean) - Method in class com.sleepycat.je.txn.Txn
Abort this transaction.
abortLsn - Variable in class com.sleepycat.je.txn.Txn
 
abortOldTxns() - Method in class com.sleepycat.je.rep.impl.node.Replay
When mastership changes, all inflight replay transactions are aborted.
abortTransaction() - Method in class com.sleepycat.collections.CurrentTransaction
Aborts the transaction that is active for the current thread for this environment and makes the parent transaction (if any) the current transaction.
abortUndo(Logger, Level, DatabaseImpl, TreeLocation, LN, byte[], long, long, boolean) - Static method in class com.sleepycat.je.recovery.RecoveryManager
 
AbstractInput - Class in com.sleepycat.persist.impl
Base class for EntityInput implementations.
AbstractInput(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.AbstractInput
 
ACC_ABSTRACT - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_ANNOTATION - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_BRIDGE - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_CONSTRUCTOR - Static variable in class com.sleepycat.asm.MethodWriter
Pseudo access flag used to denote constructors.
ACC_DEPRECATED - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_ENUM - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_FINAL - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_INTERFACE - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_NATIVE - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_PRIVATE - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_PROTECTED - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_PUBLIC - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_STATIC - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_STRICT - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_SUPER - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_SYNCHRONIZED - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_SYNTHETIC - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_SYNTHETIC_ATTRIBUTE - Static variable in class com.sleepycat.asm.ClassWriter
Pseudo access flag to distinguish between the synthetic attribute and the synthetic access flag.
ACC_TRANSIENT - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_VARARGS - Static variable in interface com.sleepycat.asm.Opcodes
 
ACC_VOLATILE - Static variable in interface com.sleepycat.asm.Opcodes
 
accept(ClassVisitor, int) - Method in class com.sleepycat.asm.ClassReader
Makes the given visitor visit the Java class of this ClassReader.
accept(ClassVisitor, Attribute[], int) - Method in class com.sleepycat.asm.ClassReader
Makes the given visitor visit the Java class of this ClassReader.
accept(File, String) - Method in class com.sleepycat.je.log.JEFileFilter
A JE file has to be of the format nnnnnnnn.suffix.
ACCEPT - Variable in class com.sleepycat.je.rep.elections.Protocol
 
ACCEPTED - Variable in class com.sleepycat.je.rep.elections.Protocol
 
Acceptor - Class in com.sleepycat.je.rep.elections
Plays the role of Acceptor in the consensus algorithm.
Acceptor(Protocol, RepNode, Acceptor.SuggestionGenerator) - Constructor for class com.sleepycat.je.rep.elections.Acceptor
Creates an Acceptor
Acceptor.SuggestionGenerator - Interface in com.sleepycat.je.rep.elections
 
Accessor - Interface in com.sleepycat.persist.impl
Field binding operations implemented via reflection (ReflectionAccessor) or bytecode enhancement (EnhancedAccessor).
accountForDeferredWriteSubtreeRemoval(INList, IN) - Method in class com.sleepycat.je.tree.IN
For a deferred-write DB, account for a deleted subtree.
accountForDeferredWriteSubtreeRemoval(INList, IN) - Method in class com.sleepycat.je.tree.LN
No need to do anything, stop the search.
accountForDeferredWriteSubtreeRemoval(INList, IN) - Method in class com.sleepycat.je.tree.Node
For a deferred-write DB, account for a deleted subtree.
accountForSubtreeRemoval(INList, LocalUtilizationTracker) - Method in class com.sleepycat.je.tree.IN
For a regular (not deferred-write) DB, account for a deleted subtree.
accountForSubtreeRemoval(INList, LocalUtilizationTracker) - Method in class com.sleepycat.je.tree.LN
No need to do anything, stop the search.
accountForSubtreeRemoval(INList, LocalUtilizationTracker) - Method in class com.sleepycat.je.tree.Node
For a regular (not deferred-write) DB, account for a deleted subtree.
accountsForKeyByteMemUsage() - Method in class com.sleepycat.je.tree.INKeyRep
Returns true if the key bytes mem usage is accounted for internally here, or false if each key has a separate byte array and its mem usage is accounted for by the parent.
accountsForKeyByteMemUsage() - Method in class com.sleepycat.je.tree.INKeyRep.Default
 
accountsForKeyByteMemUsage() - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
ACCUMULATED_LIMIT - Static variable in class com.sleepycat.je.tree.IN
 
ACCUMULATED_LIMIT - Static variable in class com.sleepycat.je.txn.Txn
 
accumulateDupLNs - Variable in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
accumulateLNs - Variable in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
accumulateLSNs(IN, LSNAccumulator) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
accumulateStats(TreeWalkerStatsAccumulator) - Method in class com.sleepycat.je.tree.BIN
 
accumulateStats(TreeWalkerStatsAccumulator) - Method in class com.sleepycat.je.tree.IN
 
ACK - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
ACK_WAIT_MS - Static variable in class com.sleepycat.je.rep.stream.FeederTxnStatDefinition
 
acksPending() - Method in exception com.sleepycat.je.rep.InsufficientAcksException
It returns the number of Replicas that did not respond with an acknowledgment within the Replica commit timeout period.
acksRequired() - Method in exception com.sleepycat.je.rep.InsufficientAcksException
It returns the number of acknowledgments required by the commit policy.
ackTimeout() - Method in exception com.sleepycat.je.rep.InsufficientAcksException
Returns the acknowledgment timeout that was in effect at the time of the exception.
ACONST_NULL - Static variable in interface com.sleepycat.asm.Opcodes
 
acquire() - Method in class com.sleepycat.je.latch.Latch
Acquire a latch for exclusive/write access.
acquire() - Method in class com.sleepycat.je.utilint.TimingLatch
 
acquireExclusive() - Method in class com.sleepycat.je.latch.SharedLatch
Acquire a latch for exclusive/write access.
acquireExclusiveNoWait() - Method in class com.sleepycat.je.latch.SharedLatch
Probe a latch for exclusive access, but don't block if it's not available.
acquireNoWait() - Method in class com.sleepycat.je.latch.Latch
Acquire a latch for exclusive/write access, but do not block if it's not available.
acquireShared() - Method in class com.sleepycat.je.latch.SharedLatch
Acquire a latch for shared/read access.
activateCleaner() - Method in class com.sleepycat.je.cleaner.UtilizationTracker
Wakeup the cleaner thread and reset the log byte counter.
activateFeeder(Feeder) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Transitions a Feeder to being active, so that it can be used in considerations relating to commit acknowledgments.
activeReplicaCount() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
The numbers of Replicas currently "active" with this feeder.
activeReplicas() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Returns the set of Replicas that are currently active with this feeder.
activeReplicasMap() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
activeServers - Variable in exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.LoadThresholdExceededException
 
ActiveTxnArrayStat - Class in com.sleepycat.je.utilint
An array of active Txn stats.
ActiveTxnArrayStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
ActiveTxnArrayStat(StatGroup, StatDefinition, TransactionStats.Active[]) - Constructor for class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
ActivityCounter - Class in com.sleepycat.utilint
Tracks the number of operations begun, as a way of measuring level of activity.
ActivityCounter(int, long, int, Logger) - Constructor for class com.sleepycat.utilint.ActivityCounter
 
adapter - Variable in class com.sleepycat.persist.BasicCursor
 
add(E) - Method in class com.sleepycat.collections.BlockIterator
 
add(Object, Object) - Method in class com.sleepycat.collections.StoredCollection
 
add(Map.Entry<K, V>) - Method in class com.sleepycat.collections.StoredEntrySet
Adds the specified element to this set if it is not already present (optional operation).
add(E) - Method in class com.sleepycat.collections.StoredIterator
Inserts the specified element into the list or inserts a duplicate into other types of collections (optional operation).
add(K) - Method in class com.sleepycat.collections.StoredKeySet
Adds the specified key to this set if it is not already present (optional operation).
add(int, E) - Method in class com.sleepycat.collections.StoredList
Inserts the specified element at the specified position in this list (optional operation).
add(E) - Method in class com.sleepycat.collections.StoredList
Appends the specified element to the end of this list (optional operation).
add(E) - Method in class com.sleepycat.collections.StoredValueSet
Adds the specified entity to this set if it is not already present (optional operation).
add(DbFileSummary) - Method in class com.sleepycat.je.cleaner.DbFileSummary
Add the totals of the given summary object to the totals of this object.
add(FileSummary) - Method in class com.sleepycat.je.cleaner.FileSummary
Add the totals of the given summary object to the totals of this object.
add(long, boolean) - Method in class com.sleepycat.je.cleaner.OffsetList
Adds the given value and returns whether a new segment was allocated.
add(long) - Method in class com.sleepycat.je.cleaner.OffsetList.Segment
Call this method on the tail.
add(IN) - Method in class com.sleepycat.je.dbi.INList
An IN has just come into memory, add it to the list.
add(long) - Method in class com.sleepycat.je.dbi.LSNAccumulator
 
add(Block) - Method in class com.sleepycat.je.rep.util.ldiff.BlockBag
Adds a new Block to the bag.
add(Stat<TransactionStats.Active[]>) - Method in class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
add(int) - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
add(Stat<Integer>) - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
add(long) - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
add(Stat<Long>) - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
add(Stat<Boolean>) - Method in class com.sleepycat.je.utilint.BooleanStat
 
add(Stat<Float>) - Method in class com.sleepycat.je.utilint.FloatStat
 
add(int) - Method in class com.sleepycat.je.utilint.IntStat
 
add(Stat<Integer>) - Method in class com.sleepycat.je.utilint.IntStat
 
add(Stat<long[]>) - Method in class com.sleepycat.je.utilint.LongArrayStat
 
add(long) - Method in class com.sleepycat.je.utilint.LongStat
 
add(Stat<Long>) - Method in class com.sleepycat.je.utilint.LongStat
 
add(Stat<T>) - Method in class com.sleepycat.je.utilint.Stat
Add the value of "other" to this stat.
add(Stat<String>) - Method in class com.sleepycat.je.utilint.StringStat
 
add(T) - Method in class com.sleepycat.je.utilint.TinyHashSet
 
add(int, int) - Method in class com.sleepycat.persist.evolve.EvolveStats
 
addAll(Collection<? extends E>) - Method in class com.sleepycat.collections.StoredCollection
Adds all of the elements in the specified collection to this collection (optional operation).
addAll(int, Collection<? extends E>) - Method in class com.sleepycat.collections.StoredList
Inserts all of the elements in the specified collection into this list at the specified position (optional operation).
addAll(StatGroup) - Method in class com.sleepycat.je.utilint.StatGroup
Add all the stats from the other group into this group.
addBinRefToQueue(BINReference, boolean) - Method in class com.sleepycat.je.incomp.INCompressor
Adds the BINReference to the queue if the BIN is not already in the queue, or adds the deleted keys to an existing entry if one exists.
addBinToQueue(BIN, boolean) - Method in class com.sleepycat.je.incomp.INCompressor
Adds the BIN to the queue if the BIN is not already in the queue.
addBlockBagAdditionalDiffs(Window, BlockBag) - Method in class com.sleepycat.je.rep.util.ldiff.DiffTracker
 
addBuddy(BuddyLocker) - Method in class com.sleepycat.je.txn.Locker
By default the set of buddy lockers is not maintained.
addBuddy(BuddyLocker) - Method in class com.sleepycat.je.txn.Txn
 
addClassToEvolve(String) - Method in class com.sleepycat.persist.evolve.EvolveConfig
Adds an entity class for a primary index to be converted.
addCleanedFile(Long, Set<DatabaseId>, VLSN, MemoryBudget) - Method in class com.sleepycat.je.cleaner.FileSelector
When cleaning is complete, move the file from the BEING_CLEANED to CLEANED.
addCondition(SecondaryIndex<SK, PK, E>, SK) - Method in class com.sleepycat.persist.EntityJoin
Adds a secondary key condition to the equality join.
addConfigObserver(EnvConfigObserver) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Adds an observer of mutable config changes.
addConfiguredFileset(FileSet) - Method in class com.sleepycat.persist.model.ClassEnhancerTask
 
addConnectionEventListener(ConnectionEventListener) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
addConsistencyPolicyFormat(String, RepUtils.ConsistencyPolicyFormat<?>) - Static method in class com.sleepycat.je.rep.utilint.RepUtils
Define a new ConsistencyPolicyFormat.
addConverter(Converter) - Method in class com.sleepycat.persist.evolve.Mutations
Adds a converter mutation.
addCursor(ForwardCursor) - Method in class com.sleepycat.je.Database
 
addCursor(BIN) - Method in class com.sleepycat.je.dbi.CursorImpl
 
addCursor() - Method in class com.sleepycat.je.dbi.CursorImpl
Add to the current cursor.
addCursor(CursorImpl) - Method in class com.sleepycat.je.tree.BIN
Register a cursor with this BIN.
addDataSet(String, Collection<SyncDatabase>) - Method in class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
 
addDataSet(String, Collection<SyncDatabase>) - Method in class com.sleepycat.je.sync.mobile.MobileSyncProcessor
 
addDataSet(S) - Method in class com.sleepycat.je.sync.ProcessorMetadata
 
addDataSet(String, Collection<SyncDatabase>) - Method in class com.sleepycat.je.sync.SyncProcessor
Adds a data set that is managed by this processor.
addDbBackup(DbBackup) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; just return true for a standalone environment.
addDbBackup(DbBackup) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
addDeleteInfo(BIN) - Method in class com.sleepycat.je.txn.Locker
Add delete information, to be added to the inCompressor queue when the transaction ends.
addDeleteInfo(BIN) - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Forwards this method to the transactional buddy.
addDeleter(Deleter) - Method in class com.sleepycat.persist.evolve.Mutations
Adds a deleter mutation.
addDiffRegion(Window) - Method in class com.sleepycat.je.rep.util.ldiff.DiffTracker
 
addEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.Evictor
 
addEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.PrivateSelector
Only supported by SharedSelector.
addEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.SharedSelector
Synchronized so that the set of environments cannot be changed in the middle of an eviction (which is also synchronized).
addEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.TargetSelector
Only supported by SharedEvictor.
addErrorMessage(String) - Method in exception com.sleepycat.je.DatabaseException
For internal use only.
addEvent(EventTrace) - Static method in class com.sleepycat.je.utilint.EventTrace
Always return true so this method can be used with asserts: i.e.
addEvent(String) - Static method in class com.sleepycat.je.utilint.EventTrace
 
addEvolveError(Format, Format, String, String) - Method in class com.sleepycat.persist.impl.Evolver
Adds a specified error when no specific mutation is involved.
addExtraMarshaledMemorySize(BIN) - Method in class com.sleepycat.je.tree.FileSummaryLN
Adds the extra memory used by obsoleteOffsets to the parent BIN memory size.
addExtraMarshaledMemorySize(BIN) - Method in class com.sleepycat.je.tree.LN
Account for FileSummaryLN's extra marshaled memory.
addFeeder(Feeder) - Method in class com.sleepycat.je.rep.impl.node.MasterTransfer
Enables the given Feeder to contribute to this Master Transfer operation.
addFirstNode() - Method in class com.sleepycat.je.rep.impl.RepGroupDB
Ensures that information about this node, the current master is in the member database.
addIN(IN, boolean) - Method in class com.sleepycat.je.recovery.DirtyINMap
Add a node unconditionally to the dirty map.
addInvalidMutation(Format, Format, Mutation, String) - Method in class com.sleepycat.persist.impl.Evolver
Adds an error for an invalid mutation.
addListener(Learner.Listener) - Method in class com.sleepycat.je.rep.elections.Learner
Adds a Listener to the existing set of listeners, so that it can be informed of the outcome of election results.
addLNsLoaded(int) - Method in class com.sleepycat.je.PreloadStats
 
addLock(Long, LockType, LockGrantType) - Method in class com.sleepycat.je.txn.BasicLocker
Add a lock to set owned by this transaction.
addLock(Long, LockType, LockGrantType) - Method in class com.sleepycat.je.txn.Locker
Add a lock to set owned by this transaction.
addLock(Long, LockType, LockGrantType) - Method in class com.sleepycat.je.txn.Txn
Add lock to the appropriate queue.
addLogInfo(long) - Method in class com.sleepycat.je.txn.Txn
Called by the recovery manager when logging a transaction aware object.
addMissingMutation(Format, Format, String) - Method in class com.sleepycat.persist.impl.Evolver
Adds an error for a missing mutation.
addMissingSimpleFormats(ClassLoader, List<Format>) - Static method in class com.sleepycat.persist.impl.SimpleCatalog
 
addMultipleBinRefsToQueue(Collection<BINReference>, boolean) - Method in class com.sleepycat.je.incomp.INCompressor
Adds an entire collection of BINReferences to the queue at once.
addNonEntityFormat(Format) - Method in class com.sleepycat.persist.impl.Evolver
Called by PersistCatalog for all non-entity formats.
addObsoleteInfo(long, boolean, int) - Method in class com.sleepycat.je.cleaner.PackedObsoleteInfo
 
addOpenedDatabase(Database) - Method in class com.sleepycat.je.txn.Locker
 
addOpenedDatabase(Database) - Method in class com.sleepycat.je.txn.Txn
Called at the end of a database open operation to add the database handle to a user txn.
addOperations() - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
addOperations() - Method in class com.sleepycat.je.jmx.JEMBean
Add MBean operations into the list.
addOperations() - Method in class com.sleepycat.je.jmx.JEMonitor
 
addOperations() - Method in class com.sleepycat.je.rep.jmx.RepJEMonitor
 
addPendingDB(DatabaseImpl) - Method in class com.sleepycat.je.cleaner.Cleaner
Adds the DB ID to the pending DB set if it is being deleted but deletion is not yet complete.
addPendingDB(DatabaseId) - Method in class com.sleepycat.je.cleaner.FileSelector
Adds the given DatabaseId to the pending DB set.
addPendingLN(long, LN, DatabaseId, byte[]) - Method in class com.sleepycat.je.cleaner.FileSelector
Adds the given LN info to the pending LN set.
addPostMarshallingInfo(EnvironmentImpl, ByteBuffer, long, ReplicationContext) - Method in class com.sleepycat.je.log.LogEntryHeader
Add those parts of the header that must be calculated later to the entryBuffer, and also assign the fields in this class.
addProtectedFileRange(long) - Method in class com.sleepycat.je.cleaner.Cleaner
Adds a range of log files to be protected from deletion during a backup or similar procedures where log files must not be deleted.
addReferringHandle(Database) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Add a referring handle
addRenamer(Renamer) - Method in class com.sleepycat.persist.evolve.Mutations
Adds a renamer mutation.
addRepConfigObserver(RepEnvConfigObserver) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
ADDRESS_WIDTH - Static variable in class com.sleepycat.je.rep.elections.TimebasedProposalGenerator
 
addSize(int) - Method in class com.sleepycat.util.FastOutputStream
Skip the given number of bytes in the buffer.
addSupportedParam(ConfigParam) - Static method in class com.sleepycat.je.config.EnvironmentParams
 
addTargetType(LogEntryType) - Method in class com.sleepycat.je.log.INFileReader
Configure this reader to target this kind of entry.
addTargetType(LogEntryType) - Method in class com.sleepycat.je.log.LNFileReader
 
addToCompressorQueue(BIN, boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Tells the asynchronous IN compressor thread about a BIN with a deleted entry.
addToCompressorQueue(BINReference, boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Tells the asynchronous IN compressor thread about a BINReference with a deleted entry.
addToCompressorQueue(Collection<BINReference>, boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Tells the asynchronous IN compressor thread about a collections of BINReferences with deleted entries.
addToSubroutine(long, int) - Method in class com.sleepycat.asm.Label
Marks this basic block as belonging to the given subroutine.
addToTipMap(Map<String, String>) - Method in class com.sleepycat.je.utilint.StatGroup
 
addTrackedSummary(TrackedFileSummary) - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Adds the obsolete offsets as well as the totals of the given object.
addTrigger(DatabaseTrigger, boolean) - Method in class com.sleepycat.je.Database
Adds a given trigger to the list of triggers.
addTrigger(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
addTrigger(Transaction) - Method in interface com.sleepycat.je.trigger.Trigger
The trigger method invoked when this trigger is added to the database.
addType(String) - Method in class com.sleepycat.asm.ClassWriter
Adds the given internal name to ClassWriter.typeTable and returns its index.
addUninitializedType(String, int) - Method in class com.sleepycat.asm.ClassWriter
Adds the given "uninitialized" type to ClassWriter.typeTable and returns its index.
addWindowAdditionalDiffs(Window) - Method in class com.sleepycat.je.rep.util.ldiff.DiffTracker
 
adjustCursors(IN, int, int) - Method in class com.sleepycat.je.tree.BIN
Adjust any cursors that are referring to this BIN.
adjustCursors(IN, int, int) - Method in class com.sleepycat.je.tree.IN
 
adjustCursorsForInsert(int) - Method in class com.sleepycat.je.tree.BIN
Adjust cursors referring to this BIN following an insert.
adjustCursorsForInsert(int) - Method in class com.sleepycat.je.tree.IN
 
adjustReadBufferSize(int) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
Change the read buffer size if we start hitting large log entries so we don't get into an expensive cycle of multiple reads and piecing together of log entries.
adjustUtilization(long, long, FileSummary, FileSummary) - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Saves the true average LN size for use in calculating utilization.
Adler32 - Class in com.sleepycat.je.utilint
Adler32 checksum implementation.
Adler32() - Constructor for class com.sleepycat.je.utilint.Adler32
 
Adler32.ChunkingAdler32 - Class in com.sleepycat.je.utilint
 
Adler32.ChunkingAdler32(int) - Constructor for class com.sleepycat.je.utilint.Adler32.ChunkingAdler32
 
ADLER32_CHUNK_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ADLER32_CHUNK_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
By default, JE passes an entire log record to the Adler32 class for checksumming.
adler32ChunkSize - Variable in class com.sleepycat.je.utilint.Adler32.ChunkingAdler32
 
advanceCursor(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Cursor
 
advanceCursor(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.dbi.CursorImpl
Advance a cursor.
advanceCursor(Cursor, DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.advanceCursor()
adviseMasterTransferProgress() - Method in class com.sleepycat.je.rep.impl.node.Feeder
 
afterLog(LogManager, INLogItem, INLogContext) - Method in class com.sleepycat.je.tree.BIN
Overrides the IN method to account for deltas.
afterLog(LogManager, INLogItem, INLogContext) - Method in class com.sleepycat.je.tree.IN
Post-log processing.
afterLogCommon(LogManager, INLogItem, INLogContext, long, long) - Method in class com.sleepycat.je.tree.IN
Post-log processing shared by IN and BIN classes.
alert() - Method in class com.sleepycat.je.evictor.Evictor
Let the eviction pool know there's work to do.
alertEvictor() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
allocateInitializedBuffer(int) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.Message
Allocate a buffer for the message with the header initialized.
ALLOW - Static variable in class com.sleepycat.je.txn.LockConflict
 
ALLOW_UNKNOWN_STATE_ENV_OPEN - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
ALLOW_UNKNOWN_STATE_ENV_OPEN - Static variable in class com.sleepycat.je.rep.ReplicationConfig
Deprecated.
For internal use only. When set to true, it permits opening of a ReplicatedEnvironment handle in the ReplicatedEnvironment.State.UNKNOWN state, if a Master could not be determined within the timeout specified by ReplicationConfig.ENV_SETUP_TIMEOUT. If it's false, an UnknownMasterException exception is thrown upon expiration of the timeout.

A ReplicatedEnvironment handle in the ReplicatedEnvironment.State.UNKNOWN state can only be used to initiate read operations with an appropriately relaxed NoConsistencyRequiredPolicy; write operations will fail with a ReplicaWriteException. The handle will transition to a Master or Replica state when it can contact a sufficient number of other nodes in the replication group.

Name Type Mutable Default
"je.rep.allowUnknownStateEnvOpen" Boolean No False
allowCompress - Variable in class com.sleepycat.je.tree.INLogContext
Whether a full BIN may be compressed before being logged.
allowDeltas - Variable in class com.sleepycat.je.tree.INLogContext
Whether a BINDelta may be logged.
allowEvolveFromProxy() - Method in class com.sleepycat.persist.impl.Format
Currently, only FBigDec will return true.
allowEvolveFromProxy() - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigDec
 
allowRegisterProxy(Class) - Static method in class com.sleepycat.persist.impl.SimpleCatalog
 
allowReleaseLockAfterLsnChange() - Method in class com.sleepycat.je.txn.HandleLocker
Because handle lockers are legitimately very long lived, it is important that lockAfterLsnChange releases the locks on the old LSN, to avoid a steady accumulation of locks in a HandleLocker
allowReleaseLockAfterLsnChange() - Method in class com.sleepycat.je.txn.Locker
 
allowReplicaWrite() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Used to determine whether to throw ReplicaWriteException when a write to this database is attempted.
ALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
ALT_MATCHPOINT - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
ANEWARRAY - Static variable in interface com.sleepycat.asm.Opcodes
 
AnnotationModel - Class in com.sleepycat.persist.model
The default annotation-based entity model.
AnnotationModel() - Constructor for class com.sleepycat.persist.model.AnnotationModel
Constructs a model for annotated entity classes.
ANNOTATIONS - Static variable in class com.sleepycat.asm.ClassReader
True to enable annotations support.
AnnotationVisitor - Class in com.sleepycat.asm
A visitor to visit a Java annotation.
AnnotationVisitor(int) - Constructor for class com.sleepycat.asm.AnnotationVisitor
Constructs a new AnnotationVisitor.
AnnotationVisitor(int, AnnotationVisitor) - Constructor for class com.sleepycat.asm.AnnotationVisitor
Constructs a new AnnotationVisitor.
AnnotationWriter - Class in com.sleepycat.asm
An AnnotationVisitor that generates annotations in bytecode form.
AnnotationWriter(ClassWriter, boolean, ByteVector, ByteVector, int) - Constructor for class com.sleepycat.asm.AnnotationWriter
Constructs a new AnnotationWriter.
api - Variable in class com.sleepycat.asm.AnnotationVisitor
The ASM API version implemented by this visitor.
api - Variable in class com.sleepycat.asm.ClassVisitor
The ASM API version implemented by this visitor.
api - Variable in class com.sleepycat.asm.FieldVisitor
The ASM API version implemented by this visitor.
api - Variable in class com.sleepycat.asm.MethodVisitor
The ASM API version implemented by this visitor.
append(Object, Object[], Object[]) - Method in class com.sleepycat.collections.DataView
Appends a value and returns the new key.
append(E) - Method in class com.sleepycat.collections.StoredList
Appends a given value returning the newly assigned index.
append(V) - Method in class com.sleepycat.collections.StoredMap
Appends a given value returning the newly assigned key.
append(Database, Transaction, DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.compat.DbCompat
 
append(VLSNRecoveryTracker) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
APPEND_FRAME - Static variable in class com.sleepycat.asm.MethodWriter
Frame where current locals are the same as the locals in the previous frame, except that k additional locals are defined.
appendEnvironmentName(StringBuilder) - Method in class com.sleepycat.je.rep.utilint.ReplicationFormatter
 
appendEnvironmentName(StringBuilder) - Method in class com.sleepycat.je.utilint.TracerFormatter
 
applyFileConfig(File, Properties, boolean) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Apply the configurations specified in the je.properties file to override the programmatically set configuration values held in the property bag.
AppStateMonitor - Interface in com.sleepycat.je.rep
A mechanism for adding application specific information when asynchronously tracking the state of a running JE HA application.
Arbiter - Class in com.sleepycat.je.evictor
The Arbiter determines whether eviction should occur, by consulting the memory budget.
Arbiter(EnvironmentImpl) - Constructor for class com.sleepycat.je.evictor.Arbiter
 
areDuplicatesAllowed() - Method in class com.sleepycat.collections.StoredContainer
Returns whether duplicate keys are allowed in this container.
areDuplicatesOrdered() - Method in class com.sleepycat.collections.StoredContainer
Returns whether duplicate keys are allowed and sorted by element value.
areFormatsChanged() - Method in class com.sleepycat.persist.impl.Evolver
Returns whether any formats were changed during evolution, and therefore need to be stored in the catalog.
areKeyRangesAllowed() - Method in class com.sleepycat.collections.StoredContainer
Returns whether key ranges are allowed in this container.
areKeysRenumbered() - Method in class com.sleepycat.collections.StoredContainer
Returns whether keys are renumbered when insertions and deletions occur.
areNestedRefsProhibited() - Method in class com.sleepycat.persist.impl.Format
Certain formats (ProxiedFormat for example) prohibit nested fields that reference the parent object.
areNestedRefsProhibited() - Method in class com.sleepycat.persist.impl.ProxiedFormat
In the future if we implement container proxies, which support nested references to the container, then we will return false if this is a container proxy.
areOtherSerializableTransactionsActive(Locker) - Method in class com.sleepycat.je.txn.TxnManager
Returns whether there are any active serializable transactions, excluding the transaction given (if non-null).
ARETURN - Static variable in interface com.sleepycat.asm.Opcodes
 
ARRAY - Static variable in class com.sleepycat.asm.Type
The sort of array reference types.
array - Variable in class com.sleepycat.je.utilint.LongArrayStat
 
ARRAY_OF - Static variable in class com.sleepycat.asm.Frame
Constant to be added to a type to get a type with one more dimension.
ARRAY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
ARRAY_SIZE_INCLUDED - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
ARRAYLENGTH - Static variable in interface com.sleepycat.asm.Opcodes
 
ARRAYLIST_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
ASM4 - Static variable in interface com.sleepycat.asm.Opcodes
 
assertSync() - Method in class com.sleepycat.je.rep.stream.MasterStatus
An assertion form of the above.
assignKey(DatabaseEntry) - Method in interface com.sleepycat.collections.PrimaryKeyAssigner
Assigns a new primary key value into the given data buffer.
assignPrimaryKey(Object, DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistKeyAssigner
 
associateConnection(Object) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
ASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
asyncInformMonitors(Proposer.Proposal, Protocol.Value) - Method in class com.sleepycat.je.rep.elections.Elections
Used to propagate the results of an election to any monitors.
ATHROW - Static variable in interface com.sleepycat.asm.Opcodes
 
AtomicIntStat - Class in com.sleepycat.je.utilint
A int JE stat.
AtomicIntStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.AtomicIntStat
 
AtomicLongStat - Class in com.sleepycat.je.utilint
A long JE stat.
AtomicLongStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.AtomicLongStat
 
ATT_CACHE_PERCENT - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_CACHE_PERCENT - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
ATT_CACHE_SIZE - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_CACHE_SIZE - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
ATT_CONSOLEHANDLER_LEVEL - Static variable in class com.sleepycat.je.jmx.JEDiagnostics
 
ATT_ENV_HOME - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_ENV_HOME - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
ATT_FILEHANDLER_LEVEL - Static variable in class com.sleepycat.je.jmx.JEDiagnostics
 
ATT_IS_READ_ONLY - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_IS_READ_ONLY - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
ATT_IS_SERIALIZABLE - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_IS_SERIALIZABLE - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
ATT_IS_TRANSACTIONAL - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_IS_TRANSACTIONAL - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
ATT_LOCK_TIMEOUT - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_LOCK_TIMEOUT - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
ATT_OPEN - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_SET_READ_ONLY - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_SET_SERIALIZABLE - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_SET_TRANSACTIONAL - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_TXN_TIMEOUT - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
ATT_TXN_TIMEOUT - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
attemptLock(Long, Locker, LockType, boolean, boolean) - Method in class com.sleepycat.je.txn.DummyLockManager
 
attemptLock(Long, Locker, LockType, boolean, boolean) - Method in class com.sleepycat.je.txn.LockManager
 
attemptLock(Long, Locker, LockType, boolean, boolean) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
attemptLockInternal(Long, Locker, LockType, boolean, boolean, int) - Method in class com.sleepycat.je.txn.LockManager
 
attemptRefresh() - Method in class com.sleepycat.persist.impl.Store
Attempts to refresh metadata and returns whether a refresh occurred.
Attribute - Class in com.sleepycat.asm
A non standard class, field, method or code attribute.
Attribute(String) - Constructor for class com.sleepycat.asm.Attribute
Constructs a new empty attribute.
auxOldLsn - Variable in class com.sleepycat.je.log.LogItem
Another LSN to be counted as obsolete in the LogContext.nodeDb database, or NULL_LSN.
av - Variable in class com.sleepycat.asm.AnnotationVisitor
The annotation visitor to which this visitor must delegate method calls.
available() - Method in class com.sleepycat.je.util.LogVerificationInputStream
available() - Method in class com.sleepycat.util.FastInputStream
 
AVG_BATCH_DESC - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
await(long, TimeUnit) - Method in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareCountDownLatch
Deprecated.
AWAIT_CONSISTENCY_MS - Static variable in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
awaitConsistency() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Ensure that the in-memory vlsn index encompasses all logged entries before it is flushed to disk.
awaitOrException(long, TimeUnit) - Method in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareCountDownLatch
Blocks, waiting for the latch to count down to zero, or until an Exception is provided.
awaitOrException() - Method in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareCountDownLatch
 
awaitReplicaAcks(MasterTxn, int) - Method in class com.sleepycat.je.rep.stream.FeederTxns
Waits for the required number of replica acks to come through.
awaitThaw() - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
Used to wait for an event that unfreezes the VLSN.
awaitVLSN(long, ReplicaConsistencyPolicy) - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
Wait until the log record identified by VLSN has gone by.
awaitVLSNConsistency() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Ensure that the in-memory vlsn index encompasses all logged entries before it is flushed to disk.
awaitVLSNConsistency() - Method in class com.sleepycat.je.rep.impl.RepImpl
Ensure that the in-memory vlsn index encompasses all logged entries before it is flushed to disk.

B

b - Variable in class com.sleepycat.asm.ClassReader
The class to be parsed.
backgroundIO - Variable in class com.sleepycat.je.log.LogContext
Whether the write should be counted as background IO when throttling of background IO is configured.
BACKUP_FILE_COUNT - Static variable in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackupStatDefinition
 
backupIsOpen() - Method in class com.sleepycat.je.util.DbBackup
 
BAD_SUFFIX - Static variable in class com.sleepycat.je.log.FileManager
 
BALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
BASE - Static variable in class com.sleepycat.asm.Frame
Kind of the types that are not relative to an input stack map frame.
BASE_KIND - Static variable in class com.sleepycat.asm.Frame
Mask to get the kind of base types.
BASE_VALUE - Static variable in class com.sleepycat.asm.Frame
Mask to get the value of base types.
BaseEntry - Class in com.sleepycat.je.log.entry
A Log entry allows you to read, write and dump a database log entry.
BaseEntry(Class<?>) - Constructor for class com.sleepycat.je.log.entry.BaseEntry
Constructor to read an entry.
BaseEntry() - Constructor for class com.sleepycat.je.log.entry.BaseEntry
Constructor to write an entry.
BaseIterator<E> - Class in com.sleepycat.collections
Common interface for BlockIterator and StoredIterator.
BaseIterator() - Constructor for class com.sleepycat.collections.BaseIterator
 
BaseLocalUtilizationTracker - Class in com.sleepycat.je.cleaner
Shared implementation for all local utilization trackers.
BaseLocalUtilizationTracker(EnvironmentImpl, Map<Object, DbFileSummaryMap>) - Constructor for class com.sleepycat.je.cleaner.BaseLocalUtilizationTracker
Creates a local tracker with a map keyed by DatabaseId or DatabaseImpl.
BaseUtilizationTracker - Class in com.sleepycat.je.cleaner
Shared implementation for all utilization trackers.
BaseUtilizationTracker(EnvironmentImpl, Cleaner) - Constructor for class com.sleepycat.je.cleaner.BaseUtilizationTracker
 
BasicCursor<V> - Class in com.sleepycat.persist
Implements EntityCursor and uses a ValueAdapter so that it can enumerate either keys or entities.
BasicCursor(RangeCursor, ValueAdapter<V>, boolean) - Constructor for class com.sleepycat.persist.BasicCursor
 
BasicIndex<K,E> - Class in com.sleepycat.persist
Implements EntityIndex using a ValueAdapter.
BasicIndex(Database, Class<K>, EntryBinding, ValueAdapter<E>) - Constructor for class com.sleepycat.persist.BasicIndex
 
BasicIterator<V> - Class in com.sleepycat.persist
Implements Iterator for an arbitrary EntityCursor.
BasicIterator(EntityCursor<V>, LockMode) - Constructor for class com.sleepycat.persist.BasicIterator
An EntityCursor is given and the remove() method is supported.
BasicIterator(ForwardCursor<V>, LockMode) - Constructor for class com.sleepycat.persist.BasicIterator
A ForwardCursor is given and the remove() method is not supported.
BasicLocker - Class in com.sleepycat.je.txn
A non-transactional Locker that simply tracks locks and releases them when releaseNonTxnLocks or operationEnd is called.
BasicLocker(EnvironmentImpl) - Constructor for class com.sleepycat.je.txn.BasicLocker
Creates a BasicLocker.
BasicLocker(EnvironmentImpl, boolean) - Constructor for class com.sleepycat.je.txn.BasicLocker
Creates a BasicLocker with a noWait argument.
basicWriteLockInfo - Static variable in class com.sleepycat.je.txn.WriteLockInfo
 
BASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
bdbGetField(Object, int, int, boolean) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbIsPriKeyFieldNullOrZero() - Method in interface com.sleepycat.persist.impl.Enhanced
Calls the super class method if this class does not contain the primary key field.
bdbNewArray(int) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbNewInstance() - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbReadCompositeKeyFields(EntityInput, Format[]) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbReadNonKeyFields(EntityInput, int, int, int) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbReadPriKeyField(EntityInput, Format) - Method in interface com.sleepycat.persist.impl.Enhanced
Calls the super class method if this class does not contain the primary key field.
bdbReadSecKeyFields(EntityInput, int, int, int) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbSetField(Object, int, int, boolean, Object) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbSetPriField(Object, Object) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbWriteCompositeKeyFields(EntityOutput, Format[]) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbWriteNonKeyFields(EntityOutput) - Method in interface com.sleepycat.persist.impl.Enhanced
 
bdbWritePriKeyField(EntityOutput, Format) - Method in interface com.sleepycat.persist.impl.Enhanced
Calls the super class method if this class does not contain the primary key field.
bdbWriteSecKeyFields(EntityOutput) - Method in interface com.sleepycat.persist.impl.Enhanced
 
beforeCheckpointStart() - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
beforeFlushHook - Static variable in class com.sleepycat.je.recovery.Checkpointer
 
beforeLog(LogManager, INLogItem, INLogContext) - Method in class com.sleepycat.je.tree.BIN
Overrides the IN method to account for deltas.
beforeLog(LogManager, INLogItem, INLogContext) - Method in class com.sleepycat.je.tree.IN
Pre-log processing.
beforeLogCommon(INLogItem, INLogContext, long, long) - Method in class com.sleepycat.je.tree.IN
Pre-log processing shared by IN and BIN classes.
begin() - Method in class com.sleepycat.je.jca.ra.JELocalTransaction
 
beginAutoCommit() - Method in class com.sleepycat.collections.StoredContainer
 
beginCheckpoint(boolean, boolean) - Method in class com.sleepycat.je.recovery.DirtyINMap
Must be called before starting a checkpoint, and must not be called for Database.sync.
beginInclusive - Variable in class com.sleepycat.util.keyrange.KeyRange
 
beginInternalTransaction(Environment, TransactionConfig) - Static method in class com.sleepycat.je.DbInternal
 
beginInternalTransaction(TransactionConfig) - Method in class com.sleepycat.je.Environment
Like beginTransaction, but does not require that the Environment is transactional.
beginKey - Variable in class com.sleepycat.util.keyrange.KeyRange
 
beginTag() - Method in class com.sleepycat.je.tree.BIN
 
beginTag() - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
beginTag() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
beginTag() - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
beginTag() - Method in class com.sleepycat.je.tree.FileSummaryLN
 
beginTag() - Method in class com.sleepycat.je.tree.IN
 
beginTag() - Method in class com.sleepycat.je.tree.LN
 
beginTag() - Method in class com.sleepycat.je.tree.MapLN
 
beginTag() - Method in class com.sleepycat.je.tree.NameLN
 
beginTransaction(TransactionConfig) - Method in class com.sleepycat.collections.CurrentTransaction
Begins a new transaction for this environment and associates it with the current thread.
beginTransaction(Transaction, TransactionConfig) - Method in class com.sleepycat.je.Environment
Creates a new transaction in the database environment.
BETA_VERSION - Static variable in interface com.sleepycat.persist.impl.Catalog
 
BigDecimalBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for an unsorted BigDecimal value.
BigDecimalBinding() - Constructor for class com.sleepycat.bind.tuple.BigDecimalBinding
 
bigDecimalToEntry(BigDecimal, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.BigDecimalBinding
Converts a BigDecimal value into an entry buffer.
bigDecimalToEntry(BigDecimal, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedBigDecimalBinding
Converts a BigDecimal value into an entry buffer.
BigIntegerBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a BigInteger value.
BigIntegerBinding() - Constructor for class com.sleepycat.bind.tuple.BigIntegerBinding
 
bigIntegerToEntry(BigInteger, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.BigIntegerBinding
Converts a BigInteger value into an entry buffer.
BIN - Class in com.sleepycat.je.tree
A BIN represents a Bottom Internal Node in the JE tree.
BIN() - Constructor for class com.sleepycat.je.tree.BIN
 
BIN(DatabaseImpl, byte[], int, int) - Constructor for class com.sleepycat.je.tree.BIN
 
BIN(SizeofMarker) - Constructor for class com.sleepycat.je.tree.BIN
For Sizeof, set all array fields to null, since they are not part of the fixed overhead.
bin - Variable in class com.sleepycat.je.tree.TreeLocation
 
BIN_DELTA_PERCENT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
BIN_EVICTION_TYPE_DESC - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
BIN_FETCH - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
BIN_FETCH_MISS - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
BIN_FIXED_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
BIN_LEVEL - Static variable in class com.sleepycat.je.tree.IN
 
BIN_MAX_DELTAS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
BIN_NODE_STATE_REQ - Static variable in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol
 
BIN_NODE_STATE_RESP - Static variable in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol
 
BINARY - Static variable in class com.sleepycat.je.tree.Key.DumpType
 
BinaryNodeStateProtocol - Class in com.sleepycat.je.rep.impl
Defines the protocol used in support of node state querying.
BinaryNodeStateProtocol(NameIdPair, RepImpl) - Constructor for class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol
 
BinaryNodeStateProtocol.BinaryNodeStateRequest - Class in com.sleepycat.je.rep.impl
 
BinaryNodeStateProtocol.BinaryNodeStateRequest(String, String) - Constructor for class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateRequest
 
BinaryNodeStateProtocol.BinaryNodeStateRequest(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateRequest
 
BinaryNodeStateProtocol.BinaryNodeStateResponse - Class in com.sleepycat.je.rep.impl
 
BinaryNodeStateProtocol.BinaryNodeStateResponse(String, String, String, JEVersion, long, ReplicatedEnvironment.State, long, long, int, int, byte[], double) - Constructor for class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
BinaryNodeStateProtocol.BinaryNodeStateResponse(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
BinaryNodeStateService - Class in com.sleepycat.je.rep.impl
The service registered by a RepNode to answer the state request.
BinaryNodeStateService(ServiceDispatcher, RepNode) - Constructor for class com.sleepycat.je.rep.impl.BinaryNodeStateService
 
BinaryNodeStateService.NodeStateServiceRunnable - Class in com.sleepycat.je.rep.impl
 
BinaryNodeStateService.NodeStateServiceRunnable(SocketChannel) - Constructor for class com.sleepycat.je.rep.impl.BinaryNodeStateService.NodeStateServiceRunnable
 
BinaryProtocol - Class in com.sleepycat.je.rep.utilint
Supplies the basic infrastructure for BinaryProtocols used to exchange messages by the replications stream and during network based restore operations.
BinaryProtocol(NameIdPair, int, int, EnvironmentImpl) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol
Returns a Protocol object configured that implements the specified (supported) version.
BinaryProtocol.ClientVersion - Class in com.sleepycat.je.rep.utilint
 
BinaryProtocol.ClientVersion() - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.ClientVersion
 
BinaryProtocol.ClientVersion(ByteBuffer) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.ClientVersion
 
BinaryProtocol.IncompatibleVersion - Class in com.sleepycat.je.rep.utilint
 
BinaryProtocol.IncompatibleVersion(String) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.IncompatibleVersion
 
BinaryProtocol.IncompatibleVersion(ByteBuffer) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.IncompatibleVersion
 
BinaryProtocol.Message - Class in com.sleepycat.je.rep.utilint
Base message class for all messages exchanged in the protocol.
BinaryProtocol.Message() - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.Message
 
BinaryProtocol.MessageOp - Class in com.sleepycat.je.rep.utilint
The Operations that are part of the protocol.
BinaryProtocol.MessageOp(short, Class<? extends BinaryProtocol.Message>) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.MessageOp
 
BinaryProtocol.ProtocolError - Class in com.sleepycat.je.rep.utilint
 
BinaryProtocol.ProtocolError(String) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolError
 
BinaryProtocol.ProtocolError(ByteBuffer) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolError
 
BinaryProtocol.ProtocolException - Exception in com.sleepycat.je.rep.utilint
Thrown in response to an unexpected response to a request.
BinaryProtocol.ProtocolException(BinaryProtocol.Message, Class<? extends BinaryProtocol.Message>) - Constructor for exception com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolException
Constructor used for message sequencing errors.
BinaryProtocol.ProtocolException(String) - Constructor for exception com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolException
 
BinaryProtocol.ProtocolVersion - Class in com.sleepycat.je.rep.utilint
Version broadcasts the sending node's protocol version.
BinaryProtocol.ProtocolVersion(int) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolVersion
 
BinaryProtocol.ProtocolVersion(ByteBuffer) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolVersion
 
BinaryProtocol.RejectMessage - Class in com.sleepycat.je.rep.utilint
The base class for reject responses to requests
BinaryProtocol.RejectMessage(String) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.RejectMessage
 
BinaryProtocol.RejectMessage(ByteBuffer) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.RejectMessage
 
BinaryProtocol.ServerVersion - Class in com.sleepycat.je.rep.utilint
 
BinaryProtocol.ServerVersion() - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.ServerVersion
 
BinaryProtocol.ServerVersion(ByteBuffer) - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.ServerVersion
 
BinaryProtocol.SimpleMessage - Class in com.sleepycat.je.rep.utilint
Base class for simple messages.
BinaryProtocol.SimpleMessage() - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
 
BinaryProtocol.WireFormatable - Interface in com.sleepycat.je.rep.utilint
 
BinaryProtocolStatDefinition - Class in com.sleepycat.je.rep.utilint
Per-stat Metadata for each BinaryProtocol statistics.
BinaryProtocolStatDefinition() - Constructor for class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
BINBoundary - Class in com.sleepycat.je.tree
Contains information about the BIN returned by a search.
BINBoundary() - Constructor for class com.sleepycat.je.tree.BINBoundary
 
BINDelta - Class in com.sleepycat.je.tree
BINDelta contains the information needed to create a partial (delta) BIN log entry.
BINDelta(BIN) - Constructor for class com.sleepycat.je.tree.BINDelta
Read a BIN and create the deltas.
BINDelta() - Constructor for class com.sleepycat.je.tree.BINDelta
For instantiating from the log.
BINDelta(SizeofMarker) - Constructor for class com.sleepycat.je.tree.BINDelta
For Sizeof.
BINDELTA_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
BINDeltaLogEntry - Class in com.sleepycat.je.log.entry
A BINDeltaLogEntry knows how to create a whole BIN from a delta entry.
BINDeltaLogEntry(Class<BINDelta>) - Constructor for class com.sleepycat.je.log.entry.BINDeltaLogEntry
 
BINDeltaLogEntry(BINDelta) - Constructor for class com.sleepycat.je.log.entry.BINDeltaLogEntry
Construct a log entry for writing to the log.
BINReference - Class in com.sleepycat.je.tree
A class that embodies a reference to a BIN that does not rely on a Java reference to the actual BIN.
BINReference(long, DatabaseId, byte[]) - Constructor for class com.sleepycat.je.tree.BINReference
 
BIPUSH - Static variable in interface com.sleepycat.asm.Opcodes
 
BitMap - Class in com.sleepycat.je.utilint
Bitmap which supports indexing with long arguments.
BitMap() - Constructor for class com.sleepycat.je.utilint.BitMap
 
Block - Class in com.sleepycat.je.rep.util.ldiff
 
Block(int) - Constructor for class com.sleepycat.je.rep.util.ldiff.Block
 
block - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.BlockInfo
 
BLOCK - Static variable in class com.sleepycat.je.txn.LockConflict
 
BLOCK_INFO - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
BLOCK_LIST_END - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
BLOCK_LIST_START - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
BlockBag - Class in com.sleepycat.je.rep.util.ldiff
A bag of Blocks used during the LDiff process.
BlockBag() - Constructor for class com.sleepycat.je.rep.util.ldiff.BlockBag
Instantiate a new BlockBag object.
BlockIterator<E> - Class in com.sleepycat.collections
An iterator that does not need closing because a cursor is not kept open across method calls.
BlockIterator(StoredCollection<E>, boolean, int) - Constructor for class com.sleepycat.collections.BlockIterator
Creates an iterator.
blockIterator() - Method in class com.sleepycat.collections.StoredCollection
 
blockSize - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.DbBlocks
 
blockTxnCompletion(CountDownLatch) - Method in class com.sleepycat.je.rep.impl.RepImpl
Installs the commit-blocking latch that is used to halt the commit/abort of transactions, in the final phase of a master transfer.
BOOLEAN - Static variable in class com.sleepycat.asm.Frame
The BOOLEAN type.
BOOLEAN - Static variable in class com.sleepycat.asm.Type
The sort of the boolean type.
BOOLEAN_TYPE - Static variable in class com.sleepycat.asm.Type
The boolean type.
BooleanBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a Boolean primitive wrapper or a boolean primitive.
BooleanBinding() - Constructor for class com.sleepycat.bind.tuple.BooleanBinding
 
BooleanConfigParam - Class in com.sleepycat.je.config
A JE configuration parameter with an boolean value.
BooleanConfigParam(String, boolean, boolean, boolean) - Constructor for class com.sleepycat.je.config.BooleanConfigParam
Set a boolean parameter w/default.
BooleanStat - Class in com.sleepycat.je.utilint
A boolean JE stat.
BooleanStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.BooleanStat
 
booleanToEntry(boolean, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.BooleanBinding
Converts a simple boolean value into an entry buffer.
bootstrapMethods - Variable in class com.sleepycat.asm.ClassWriter
The BootstrapMethods attribute.
bootstrapMethodsCount - Variable in class com.sleepycat.asm.ClassWriter
The number of entries in the BootstrapMethods attribute.
bracketFailure(long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
broadcastMessage(Set<InetSocketAddress>, String, TextProtocol.RequestMessage, ExecutorService) - Static method in class com.sleepycat.je.rep.elections.Utils
 
BSM - Static variable in class com.sleepycat.asm.ClassWriter
The type of BootstrapMethods items.
BTREE_BIN_COUNT - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_BIN_ENTRIES_HISTOGRAM - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_BINS_BYLEVEL - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_DELETED_LN_COUNT - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_IN_COUNT - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_INS_BYLEVEL - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_LN_COUNT - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_MAINTREE_MAXDEPTH - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_RECNUM_METHOD - Static variable in class com.sleepycat.compat.DbCompat
 
BTREE_RELATCHES_REQUIRED - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
BTREE_ROOT_SPLITS - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
btreeRecNumAccess - Variable in class com.sleepycat.collections.DataView
 
btreeRecNumDb - Variable in class com.sleepycat.collections.DataView
 
BTreeStatDefinition - Class in com.sleepycat.je.dbi
Per-stat Metadata for JE Btree statistics.
BTreeStatDefinition() - Constructor for class com.sleepycat.je.dbi.BTreeStatDefinition
 
BtreeStats - Class in com.sleepycat.je
The BtreeStats object is used to return Btree database statistics.
BtreeStats() - Constructor for class com.sleepycat.je.BtreeStats
 
bucketCache - Variable in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
BuddyLocker - Class in com.sleepycat.je.txn
Extends BasicLocker to share locks with another specific locker.
BuddyLocker(EnvironmentImpl, Locker) - Constructor for class com.sleepycat.je.txn.BuddyLocker
Creates a BuddyLocker.
buf - Variable in class com.sleepycat.util.FastInputStream
 
buffer - Variable in class com.sleepycat.je.log.LogItem
 
bump() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
bumpLsn(long) - Method in class com.sleepycat.je.log.FileManager
Increase the current log position by "size" bytes.
bumpVLSN() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
bumpVLSN() - Method in class com.sleepycat.je.rep.impl.RepImpl
Generate the next VLSN.
BUP_SUFFIX - Static variable in class com.sleepycat.je.log.FileManager
 
BYTE - Static variable in class com.sleepycat.asm.Frame
The BYTE type.
BYTE - Static variable in class com.sleepycat.asm.Type
The sort of the byte type.
BYTE_TYPE - Static variable in class com.sleepycat.asm.Type
The byte type.
ByteArrayBinding - Class in com.sleepycat.bind
A pass-through EntryBinding that uses the entry's byte array as the key or data object.
ByteArrayBinding() - Constructor for class com.sleepycat.bind.ByteArrayBinding
Creates a byte array binding.
byteArraySize(int) - Static method in class com.sleepycat.je.dbi.MemoryBudget
Returns the memory size occupied by a byte array of a given length.
ByteBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a Byte primitive wrapper or a byte primitive.
ByteBinding() - Constructor for class com.sleepycat.bind.tuple.ByteBinding
 
byteBuffer() - Method in enum com.sleepycat.je.rep.utilint.ServiceDispatcher.Response
 
BytecodeEnhancer - Class in com.sleepycat.persist.model
An ASM ClassVisitor that examines a class, throws NotPersistentException if it is not persistent, or enhances it if it is persistent.
BytecodeEnhancer(ClassVisitor) - Constructor for class com.sleepycat.persist.model.BytecodeEnhancer
 
BytecodeEnhancer.NotPersistentException - Exception in com.sleepycat.persist.model
Thrown when we determine that a class is not persistent.
BytecodeEnhancer.NotPersistentException() - Constructor for exception com.sleepycat.persist.model.BytecodeEnhancer.NotPersistentException
 
BYTES_READ_RATE - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
BYTES_WRITE_RATE - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
bytesSinceActivate - Variable in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Bytes written to the log since the cleaner was last awoken.
bytesToChars(byte[], int, char[], int, int, boolean) - Static method in class com.sleepycat.util.UtfOps
Converts byte arrays into character arrays.
bytesToObject(byte[], String, ClassLoader) - Static method in class com.sleepycat.je.dbi.DatabaseImpl
Converts an arbitrary serialized byte array to an object.
bytesToObject(byte[], int, int) - Method in class com.sleepycat.persist.impl.PersistKeyBinding
Binds bytes to an object for use by PersistComparator as well as entryToObject.
bytesToString(byte[], int, int) - Static method in class com.sleepycat.util.UtfOps
Converts byte arrays into strings.
byteToEntry(byte, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.ByteBinding
Converts a simple byte value into an entry buffer.
ByteVector - Class in com.sleepycat.asm
A dynamically extensible vector of bytes.
ByteVector() - Constructor for class com.sleepycat.asm.ByteVector
Constructs a new ByteVector with a default initial size.
ByteVector(int) - Constructor for class com.sleepycat.asm.ByteVector
Constructs a new ByteVector with the given initial size.

C

c - Variable in class com.sleepycat.je.dbi.TriggerManager.MapOver
 
CACHE_RECORD_VERSION - Static variable in class com.sleepycat.je.rep.impl.RepParams
Whether to cache the VLSN in the BIN after the LN has been stripped by eviction, unless caching is explicitly disabled using the CACHE_RECORD_VERSION setting.
CACHED_BINS - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
CACHED_IN_COMPACT_KEY - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
CACHED_IN_NO_TARGET - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
CACHED_IN_SPARSE_TARGET - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
CACHED_RECORD_VERSION_MIN_LENGTH - Static variable in class com.sleepycat.je.rep.impl.RepParams
The initial number of bytes per record version (per VLSN sequence) in the record version cach.
CACHED_UPPER_INS - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
CacheMode - Enum in com.sleepycat.je
Modes that can be specified for control over caching of records in the JE in-memory cache.
CacheModeStrategy - Interface in com.sleepycat.je
 
cacheSize - Variable in class com.sleepycat.je.EnvironmentMutableConfig
 
calBlockDiffSize(int) - Method in class com.sleepycat.je.rep.util.ldiff.DiffTracker
 
calcFileSummaryMap(EnvironmentImpl) - Static method in class com.sleepycat.je.log.UtilizationFileReader
Creates a UtilizationReader, reads the log, and returns the resulting Map of Long file number to FileSummary.
calculate() - Method in class com.sleepycat.utilint.LatencyStat
Generated the min, max, avg, 95th and 99th percentile for the collected measurements.
calculateAndClear() - Method in class com.sleepycat.utilint.LatencyStat
Generated the min, max, avg, 95th and 99th percentile for the collected measurements, then clear the measurement collection.
calculateCacheSizes() - Method in class com.sleepycat.je.util.DbCacheSize
Calculates estimated cache sizes.
calculateMemorySize() - Method in class com.sleepycat.je.tree.INArrayRep
Returns the current memory size of the underlying representation in bytes.
calculateMemorySize() - Method in class com.sleepycat.je.tree.INKeyRep.Default
 
calculateMemorySize() - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
calculateMemorySize() - Method in class com.sleepycat.je.tree.INTargetRep.Default
 
calculateMemorySize() - Method in class com.sleepycat.je.tree.INTargetRep.None
 
calculateMemorySize() - Method in class com.sleepycat.je.tree.INTargetRep.Sparse
 
callProcessLSNHandleExceptions(long, LogEntryType, Node, byte[]) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
CALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
cancel() - Method in class com.sleepycat.je.rep.impl.GroupService
 
cancel(String) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
Cancels the registration of a service.
cancel() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingService
 
cancel() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.LazyQueuingService
 
cancel() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.QueuingService
 
cancelSync() - Method in class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
 
cancelSync() - Method in class com.sleepycat.je.sync.mobile.MobileSyncProcessor
 
cancelSync() - Method in class com.sleepycat.je.sync.SyncProcessor
Cancels a sync operation being performed in another thread.
cancelTask() - Method in class com.sleepycat.je.rep.impl.node.LogFlusher
 
canDeriveKeyFromValue() - Method in class com.sleepycat.collections.DataView
Returns whether data keys can be derived from the value/entity binding of this view, which determines whether a value/entity object alone is sufficient for operations that require keys.
capacity() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
cardinality() - Method in class com.sleepycat.je.utilint.BitMap
 
CASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
catalog - Variable in class com.sleepycat.persist.impl.AbstractInput
 
Catalog - Interface in com.sleepycat.persist.impl
Catalog operation interface used by format classes.
catalog - Variable in class com.sleepycat.persist.impl.PersistEntityBinding
 
catalog - Variable in class com.sleepycat.persist.impl.PersistKeyBinding
 
CATCHUP_MASTER_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationMutableConfig
 
CBVLSN_PAD - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
cbvlsnTracker - Variable in class com.sleepycat.je.rep.impl.node.RepNode
 
CDB - Static variable in class com.sleepycat.compat.DbCompat
 
chainExceptionCause(Throwable, Throwable) - Static method in class com.sleepycat.je.rep.utilint.RepUtils
Chains an old outstanding exception to the tail of a new one, so it's not lost.
changeAndNotify(ReplicatedEnvironment.State, NameIdPair) - Method in class com.sleepycat.je.rep.impl.node.NodeState
Change to a new node state and release any threads waiting for a state transition.
changeMemorySize(long) - Method in class com.sleepycat.je.tree.IN
 
ChangeReader - Interface in com.sleepycat.je.sync
Retrieves all pending and unprocessed changes for one or more SyncDataSets; used only by SyncProcessor implementations and custom sources of change set information.
ChangeReader.Change - Interface in com.sleepycat.je.sync
A change operation that is part of a ChangeTxn; used only by SyncProcessor implementations and custom sources of change set information.
ChangeReader.ChangeTxn - Interface in com.sleepycat.je.sync
A transaction that contains one or more Changes; used only by SyncProcessor implementations and custom sources of change set information.
ChangeReader.ChangeType - Enum in com.sleepycat.je.sync
The operation type of a Change; used only by SyncProcessor implementations and custom sources of change set information.
channel - Variable in class com.sleepycat.je.rep.util.ldiff.LDiffService.LDiffServiceRunnable
 
channel - Variable in class com.sleepycat.je.rep.utilint.NamedChannel
 
channel - Variable in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingRunnable
 
CHANNEL_EOF_MARKER - Static variable in class com.sleepycat.je.rep.utilint.RepUtils
 
channelQueue - Variable in class com.sleepycat.je.rep.elections.ElectionAgentThread
 
ChannelTimeoutTask - Class in com.sleepycat.je.rep.impl.node
The ChannelTimeoutTask ensures that all channels registered with it are periodically checked to ensure that they are active.
ChannelTimeoutTask(Timer) - Constructor for class com.sleepycat.je.rep.impl.node.ChannelTimeoutTask
Creates and schedules the timer task.
CHAR - Static variable in class com.sleepycat.asm.Frame
The CHAR type.
CHAR - Static variable in class com.sleepycat.asm.Type
The sort of the char type.
CHAR_TYPE - Static variable in class com.sleepycat.asm.Type
The char type.
CharacterBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a Character primitive wrapper or a char primitive.
CharacterBinding() - Constructor for class com.sleepycat.bind.tuple.CharacterBinding
 
charsToBytes(char[], int, byte[], int, int) - Static method in class com.sleepycat.util.UtfOps
Converts character arrays into byte arrays.
charToEntry(char, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.CharacterBinding
Converts a simple char value into an entry buffer.
check(DatabaseEntry) - Method in class com.sleepycat.util.keyrange.KeyRange
Returns whether a given key is within range.
check(DatabaseEntry, boolean) - Method in class com.sleepycat.util.keyrange.KeyRange
Returns whether a given key is within range.
checkAndConvert(Object, Format) - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
checkArgsNoValRequired(DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.je.Cursor
Note that this flavor of checkArgs allows the key and data to be null.
checkArgsValRequired(DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.je.Cursor
Note that this flavor of checkArgs requires that the key and data are not null.
checkBegin(DatabaseEntry, boolean) - Method in class com.sleepycat.util.keyrange.KeyRange
Returns whether the given key is within range with respect to the beginning of the range.
CHECKCAST - Static variable in interface com.sleepycat.asm.Opcodes
 
checkCommit(long, long) - Method in class com.sleepycat.je.recovery.RollbackTracker
A TxnCommit showed up on the construction pass.
checkConsistency(RepImpl, ReplicaConsistencyPolicy) - Static method in class com.sleepycat.je.rep.txn.ReadonlyTxn
Utility method used here and by ReplicaThreadLocker.
checkCursorState(boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
Check that the cursor is open and optionally if it is initialized.
checkDesignatedPrimary() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Checks whether we're in a 2-node group and configured as the Designated Primary.
checkEnd(DatabaseEntry, boolean) - Method in class com.sleepycat.util.keyrange.KeyRange
Returns whether the given key is within range with respect to the end of the range.
checkEntitySubclassSecondaries(EntityMetadata, String) - Method in class com.sleepycat.persist.impl.Store
Checks that all secondary indexes defined in the given entity metadata are already open.
checkEnv() - Method in class com.sleepycat.je.Cursor
 
checkEnv() - Method in class com.sleepycat.je.Database
 
checkEnv() - Method in class com.sleepycat.je.dbi.CursorImpl
 
checkEnv() - Method in class com.sleepycat.je.dbi.DiskOrderedCursorImpl
 
checkEnv() - Method in class com.sleepycat.je.Environment
For internal use only.
checkEnv(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.Evictor
Only supported by SharedEvictor.
checkEnv(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.PrivateSelector
Only supported by SharedSelector.
checkEnv(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.SharedSelector
Returns true if the given environment is present in the set of subject environments.
checkEnv(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.TargetSelector
 
checkEnvHomePermissions(boolean) - Method in class com.sleepycat.je.log.FileManager
Ensure that if the environment home dir is on readonly media or in a readonly directory that the environment has been opened for readonly access.
checkErrorListener(Throwable) - Method in class com.sleepycat.je.utilint.DaemonThread
If Daemon Thread throws errors and exceptions, this function will catch it and throw a EnvironmentFailureException, and fail the test.
checkForConflicts(RepNodeImpl) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Checks for whether a new node definition is in conflict with the current members of the group.
checkForNullDbt(DatabaseEntry, String, boolean) - Static method in class com.sleepycat.je.utilint.DatabaseUtil
Throw an exception if the entry is null or the data field is not set.
checkForNullParam(Object, String) - Static method in class com.sleepycat.je.utilint.DatabaseUtil
Throw an exception if the parameter is null.
checkForPartialKey(DatabaseEntry) - Static method in class com.sleepycat.je.utilint.DatabaseUtil
Throw an exception if the key entry has the partial flag set.
checkForPrimaryUpdate(DatabaseEntry, DatabaseEntry, DatabaseEntry, int) - Method in class com.sleepycat.je.Cursor
Checks for a secondary corruption caused by a primary record update during a read-uncommitted read.
checkForPrimaryUpdate(DatabaseEntry, DatabaseEntry, DatabaseEntry, int) - Method in class com.sleepycat.je.SecondaryCursor
 
checkForZeroLengthArrayParam(Object[], String) - Static method in class com.sleepycat.je.utilint.DatabaseUtil
Throw an exception if the parameter is a null or 0-length array.
checkFutures(List<Future<TextProtocol.MessageExchange>>, Logger, EnvironmentImpl, Formatter) - Static method in class com.sleepycat.je.rep.elections.Utils
Utility to wait for completion of futures.
checkHandleIsValid() - Method in class com.sleepycat.je.Environment
For internal use only.
checkIfInvalid() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
checkImmutablePropsForEquality(Properties) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Throws an exception if an immutable property is changed.
checkImmutablePropsForEquality(EnvironmentMutableConfig, Properties) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentMutableConfig.checkImmutablePropsForEquality()
checkImmutablePropsForEquality(Properties) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Checks that the immutable values in the environment config used to open an environment match those in the config object saved by the underlying shared EnvironmentImpl.
checkInitialized() - Method in class com.sleepycat.persist.BasicCursor
 
checkIterAddAllowed() - Method in class com.sleepycat.collections.StoredCollection
 
checkIterAddAllowed() - Method in class com.sleepycat.collections.StoredList
 
checkLockModeWithoutTxn(Transaction, LockMode) - Method in class com.sleepycat.je.Database
 
checkLsns(Database) - Static method in class com.sleepycat.je.cleaner.VerifyUtils
Compare the LSNs referenced by a given Database to the lsns held in the utilization profile.
checkLsns(DatabaseImpl, PrintStream) - Static method in class com.sleepycat.je.cleaner.VerifyUtils
Compare the lsns referenced by a given Database to the lsns held in the utilization profile.
checkLsns - Variable in class com.sleepycat.je.util.DbVerify
 
checkMixedMode(boolean, boolean, boolean, Durability) - Static method in class com.sleepycat.je.TransactionConfig
Checks to catch mixing of deprecated and non-deprecated forms of the API.
checkNotClosed() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
checkOpen(String) - Method in class com.sleepycat.je.Database
 
checkOpen() - Method in class com.sleepycat.je.Transaction
 
checkpoint(CheckpointConfig) - Method in class com.sleepycat.je.Environment
Synchronously checkpoint the database environment.
CHECKPOINT_REFERENCE_SIZE - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
CheckpointConfig - Class in com.sleepycat.je
Specifies the attributes of a checkpoint operation invoked from Environment.checkpoint.
CheckpointConfig() - Constructor for class com.sleepycat.je.CheckpointConfig
An instance created using the default constructor is initialized with the system's default settings.
CheckpointConfigBeanInfo - Class in com.sleepycat.je
 
CheckpointConfigBeanInfo() - Constructor for class com.sleepycat.je.CheckpointConfigBeanInfo
 
CheckpointEnd - Class in com.sleepycat.je.recovery
CheckpointEnd encapsulates the information needed by a checkpoint end log entry.
CheckpointEnd(String, long, long, long, long, long, long, long, long, long, long, boolean, CleanerLogSummary) - Constructor for class com.sleepycat.je.recovery.CheckpointEnd
 
CheckpointEnd() - Constructor for class com.sleepycat.je.recovery.CheckpointEnd
 
checkpointEnd - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
checkpointEndLsn - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
Checkpointer - Class in com.sleepycat.je.recovery
The Checkpointer looks through the tree for internal nodes that must be flushed to the log.
Checkpointer(EnvironmentImpl, long, String) - Constructor for class com.sleepycat.je.recovery.Checkpointer
 
Checkpointer.CheckpointReference - Class in com.sleepycat.je.recovery
 
Checkpointer.CheckpointReference(DatabaseId, long, boolean, byte[]) - Constructor for class com.sleepycat.je.recovery.Checkpointer.CheckpointReference
 
Checkpointer.FlushStats - Class in com.sleepycat.je.recovery
A struct to hold log flushing stats for checkpoint and database sync.
Checkpointer.FlushStats() - Constructor for class com.sleepycat.je.recovery.Checkpointer.FlushStats
 
CHECKPOINTER_BYTES_INTERVAL - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CHECKPOINTER_BYTES_INTERVAL - Static variable in class com.sleepycat.je.EnvironmentConfig
Ask the checkpointer to run every time we write this many bytes to the log.
CHECKPOINTER_DEADLOCK_RETRY - Static variable in class com.sleepycat.je.EnvironmentConfig
The number of times to retry a checkpoint if it runs into a deadlock.
CHECKPOINTER_HIGH_PRIORITY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CHECKPOINTER_HIGH_PRIORITY - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, the checkpointer uses more resources in order to complete the checkpoint in a shorter time interval.
CHECKPOINTER_NAME - Static variable in class com.sleepycat.je.Environment
 
CHECKPOINTER_RETRY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CHECKPOINTER_WAKEUP_INTERVAL - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CHECKPOINTER_WAKEUP_INTERVAL - Static variable in class com.sleepycat.je.EnvironmentConfig
The checkpointer wakeup interval in microseconds.
CheckpointFileReader - Class in com.sleepycat.je.log
CheckpointFileReader searches for root and checkpoint entries.
CheckpointFileReader(EnvironmentImpl, int, boolean, long, long, long) - Constructor for class com.sleepycat.je.log.CheckpointFileReader
Create this reader to start at a given LSN.
CheckpointStart - Class in com.sleepycat.je.recovery
CheckpointStart creates a log entry that marks the beginning of a checkpoint.
CheckpointStart(long, String) - Constructor for class com.sleepycat.je.recovery.CheckpointStart
 
CheckpointStart() - Constructor for class com.sleepycat.je.recovery.CheckpointStart
 
checkpointStartLsn - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
CheckpointStatDefinition - Class in com.sleepycat.je.recovery
Per-stat Metadata for JE checkpointer statistics.
CheckpointStatDefinition() - Constructor for class com.sleepycat.je.recovery.CheckpointStatDefinition
 
checkPreempted(Locker) - Method in class com.sleepycat.je.txn.BuddyLocker
Forwards to the parent buddy locker, so the buddy can check itself and all of its child buddies.
checkPreempted(Locker) - Method in class com.sleepycat.je.txn.Locker
Called when obtaining a lock to cause a LockPreemptedException to be thrown if a lock was preempted earlier.
checkPreempted(Locker) - Method in class com.sleepycat.je.txn.ThreadLocker
Checks for preemption in all thread lockers for this thread.
checkPreempted(Locker) - Method in class com.sleepycat.je.txn.Txn
Checks for preemption in this locker and all its child buddies.
checkRawType(Catalog, Object, Format) - Static method in class com.sleepycat.persist.impl.RawAbstractInput
 
checkRecordNumber() - Method in class com.sleepycat.collections.MyRangeCursor
 
checkRecordNumber() - Method in class com.sleepycat.util.keyrange.RangeCursor
If the database is a RECNO or QUEUE database, we know its keys are record numbers.
checkRulesForExistingEnv(boolean, boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Check whether this environment can be opened on an existing environment directory.
checkRulesForExistingEnv(boolean, boolean) - Method in class com.sleepycat.je.rep.impl.RepImpl
Check whether this environment can be opened on an existing environment directory.
checkState(boolean) - Method in class com.sleepycat.je.Cursor
Checks the environment and cursor state.
checkState(DbEnvState[], DbEnvState) - Method in class com.sleepycat.je.dbi.DbEnvState
 
checkState(boolean) - Method in class com.sleepycat.je.txn.BasicLocker
 
checkState(boolean) - Method in class com.sleepycat.je.txn.Locker
 
checkState(boolean) - Method in class com.sleepycat.je.txn.ThreadLocker
Check that this locker is not used in the wrong thread.
checkState(boolean) - Method in class com.sleepycat.je.txn.Txn
Throw an exception if the transaction is not open.
CHECKSUM_BYTES - Static variable in class com.sleepycat.je.log.LogEntryHeader
 
ChecksumException - Exception in com.sleepycat.je.log
Indicates that a checksum validation failed.
ChecksumException(String) - Constructor for exception com.sleepycat.je.log.ChecksumException
 
ChecksumException(String, Exception) - Constructor for exception com.sleepycat.je.log.ChecksumException
 
ChecksumValidator - Class in com.sleepycat.je.log
Checksum validator is used to check checksums on log entries.
ChecksumValidator() - Constructor for class com.sleepycat.je.log.ChecksumValidator
 
checkTriggers(List<Trigger>) - Method in class com.sleepycat.je.DatabaseConfig
Checks that the triggers in the list have consistent definitions.
checkUpdatedVersion(String, Format, Format) - Method in class com.sleepycat.persist.impl.Evolver
 
checkUpdatesAllowed(String) - Method in class com.sleepycat.je.Cursor
 
checkWriteCache(ByteBuffer, long, long) - Method in class com.sleepycat.je.log.FileManager.LogEndFileDescriptor
 
checkWriteInReplicaUpgradeMode() - Method in class com.sleepycat.persist.impl.PersistCatalog
Metadata needs refreshing when a Replica with stale metadata is elected master, and then a user write operation is attempted.
childLsn - Variable in class com.sleepycat.je.tree.TreeLocation
 
childNotResident - Variable in class com.sleepycat.je.tree.SearchResult
 
ChildReference - Class in com.sleepycat.je.tree
A ChildReference is a reference in the tree from parent to child.
ChildReference() - Constructor for class com.sleepycat.je.tree.ChildReference
Construct an empty child reference, for reading from the log.
ChildReference(Node, byte[], long) - Constructor for class com.sleepycat.je.tree.ChildReference
Construct a ChildReference for inserting a new entry.
ChildReference(Node, byte[], long, byte) - Constructor for class com.sleepycat.je.tree.ChildReference
Construct a ChildReference for inserting an existing entry.
choosePhase2Value(Set<TextProtocol.MessageExchange>) - Method in class com.sleepycat.je.rep.elections.Proposer
Selects the value to be used during Phase2, which if it succeeds will become the "chosen value".
choosePhase2Value(Set<TextProtocol.MessageExchange>) - Method in class com.sleepycat.je.rep.elections.RankingProposer
Chooses a Value based on the relative ranking of all Promise responses.
CHOP_FRAME - Static variable in class com.sleepycat.asm.MethodWriter
Frame where current locals are the same as the locals in the previous frame, except that the k last locals are absent.
chosenValue - Variable in class com.sleepycat.je.rep.elections.Proposer.WinningProposal
 
CKPT_CHECKPOINTS - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
CKPT_DELTA_IN_FLUSH - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
CKPT_FULL_BIN_FLUSH - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
CKPT_FULL_IN_FLUSH - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
CKPT_LAST_CKPT_END - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
CKPT_LAST_CKPT_START - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
CKPT_LAST_CKPTID - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
cksumValidator - Variable in class com.sleepycat.je.log.FileReader
 
CLASS - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_Class constant pool items.
ClassCatalog - Interface in com.sleepycat.bind.serial
A catalog of class description information for use during object serialization.
ClassEnhancer - Class in com.sleepycat.persist.model
Enhances the bytecode of persistent classes to provide efficient access to fields and constructors, and to avoid special security policy settings for accessing non-public members.
ClassEnhancer() - Constructor for class com.sleepycat.persist.model.ClassEnhancer
Creates a class enhancer that searches all packages.
ClassEnhancer(Set<String>) - Constructor for class com.sleepycat.persist.model.ClassEnhancer
Creates a class enhancer that searches a given set of packages.
ClassEnhancerTask - Class in com.sleepycat.persist.model
An ant task for running the ClassEnhancer.
ClassEnhancerTask() - Constructor for class com.sleepycat.persist.model.ClassEnhancerTask
 
classForName(String) - Static method in class com.sleepycat.persist.model.EntityModel
Deprecated.
use EntityModel.resolveClass(java.lang.String) instead. This method does not use the environment's ClassLoader property.
ClassMetadata - Class in com.sleepycat.persist.model
The metadata for a persistent class.
ClassMetadata(String, int, String, boolean, PrimaryKeyMetadata, Map<String, SecondaryKeyMetadata>, List<FieldMetadata>) - Constructor for class com.sleepycat.persist.model.ClassMetadata
Used by an EntityModel to construct persistent class metadata.
ClassMetadata(String, int, String, boolean, PrimaryKeyMetadata, Map<String, SecondaryKeyMetadata>, List<FieldMetadata>, Collection<FieldMetadata>) - Constructor for class com.sleepycat.persist.model.ClassMetadata
Used by an EntityModel to construct persistent class metadata.
className - Variable in class com.sleepycat.je.jmx.JEMBean
 
ClassReader - Class in com.sleepycat.asm
A Java class parser to make a ClassVisitor visit an existing class.
ClassReader(byte[]) - Constructor for class com.sleepycat.asm.ClassReader
Constructs a new ClassReader object.
ClassReader(byte[], int, int) - Constructor for class com.sleepycat.asm.ClassReader
Constructs a new ClassReader object.
ClassReader(InputStream) - Constructor for class com.sleepycat.asm.ClassReader
Constructs a new ClassReader object.
ClassReader(String) - Constructor for class com.sleepycat.asm.ClassReader
Constructs a new ClassReader object.
classReaderLength - Variable in class com.sleepycat.asm.MethodWriter
If not zero, indicates that the code of this method must be copied from the ClassReader associated to this writer in cw.cr.
classReaderOffset - Variable in class com.sleepycat.asm.MethodWriter
If not zero, indicates that the code of this method must be copied from the ClassReader associated to this writer in cw.cr.
ClassResolver - Class in com.sleepycat.util
Implements policies for loading user-supplied classes.
ClassResolver() - Constructor for class com.sleepycat.util.ClassResolver
 
ClassResolver.Stream - Class in com.sleepycat.util
A specialized ObjectInputStream that supports use of a user-specified ClassLoader.
ClassResolver.Stream(InputStream, ClassLoader) - Constructor for class com.sleepycat.util.ClassResolver.Stream
 
ClassVisitor - Class in com.sleepycat.asm
A visitor to visit a Java class.
ClassVisitor(int) - Constructor for class com.sleepycat.asm.ClassVisitor
Constructs a new ClassVisitor.
ClassVisitor(int, ClassVisitor) - Constructor for class com.sleepycat.asm.ClassVisitor
Constructs a new ClassVisitor.
ClassWriter - Class in com.sleepycat.asm
A ClassVisitor that generates classes in bytecode form.
ClassWriter(int) - Constructor for class com.sleepycat.asm.ClassWriter
Constructs a new ClassWriter object.
ClassWriter(ClassReader, int) - Constructor for class com.sleepycat.asm.ClassWriter
Constructs a new ClassWriter object and enables optimizations for "mostly add" bytecode transformations.
CLEAN_IN - Static variable in class com.sleepycat.je.cleaner.Cleaner
 
CLEAN_LN - Static variable in class com.sleepycat.je.cleaner.Cleaner
 
CLEAN_MIGRATE_LN - Static variable in class com.sleepycat.je.cleaner.Cleaner
 
CLEAN_PENDING_LN - Static variable in class com.sleepycat.je.cleaner.Cleaner
 
cleaner - Variable in class com.sleepycat.je.cleaner.BaseUtilizationTracker
 
Cleaner - Class in com.sleepycat.je.cleaner
The Cleaner is responsible for effectively garbage collecting the JE log.
Cleaner(EnvironmentImpl, String) - Constructor for class com.sleepycat.je.cleaner.Cleaner
 
CLEANER_BACKGROUND_PROACTIVE_MIGRATION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_BACKGROUND_PROACTIVE_MIGRATION - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, the cleaner will fetch log entries (incurring the cost of random I/O) during checkpoints and other JE background thread activities, in order to migrate log entries and reduce the cleaner backlog.
CLEANER_BACKLOG - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_BIN_DELTAS_CLEANED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_BIN_DELTAS_DEAD - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_BIN_DELTAS_MIGRATED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_BIN_DELTAS_OBSOLETE - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_BYTES_INTERVAL - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_BYTES_INTERVAL - Static variable in class com.sleepycat.je.EnvironmentConfig
The cleaner checks disk utilization every time we write this many bytes to the log.
CLEANER_CALC_INITIAL_ADJUSTMENTS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_CALC_MAX_PROBE_SKIP_FILES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_CALC_MIN_PROBE_SKIP_FILES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_CALC_MIN_UNCOUNTED_LNS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_CALC_RECENT_LN_SIZES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_CLUSTER - Static variable in class com.sleepycat.je.config.EnvironmentParams
Experimental and may be removed in a future release -- not exposed in the public API.
CLEANER_CLUSTER_ALL - Static variable in class com.sleepycat.je.config.EnvironmentParams
Experimental and may be removed in a future release -- not exposed in the public API.
CLEANER_CLUSTER_LNS_PROCESSED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_DEADLOCK_RETRY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_DEADLOCK_RETRY - Static variable in class com.sleepycat.je.EnvironmentConfig
The number of times to retry cleaning if a deadlock occurs.
CLEANER_DELETIONS - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_DETAIL_MAX_MEMORY_PERCENTAGE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_DETAIL_MAX_MEMORY_PERCENTAGE - Static variable in class com.sleepycat.je.EnvironmentConfig
Tracking of detailed cleaning information will use no more than this percentage of the cache.
CLEANER_ENTRIES_READ - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_EXPUNGE - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, the cleaner deletes log files after successful cleaning.
CLEANER_FETCH_OBSOLETE_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_FETCH_OBSOLETE_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, the cleaner will fetch records to determine their size to more accurately calculate log utilization.
CLEANER_FILE_DELETION_BACKLOG - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_FORCE_CLEAN_FILES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_FORCE_CLEAN_FILES - Static variable in class com.sleepycat.je.EnvironmentConfig
Specifies a list of files or file ranges to be cleaned at a time when no other log cleaning is necessary.
CLEANER_FOREGROUND_PROACTIVE_MIGRATION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_FOREGROUND_PROACTIVE_MIGRATION - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, the cleaner will fetch log entries (incurring the cost of random I/O) during eviction, Btree splits, and other application foreground thread activities, in order to migrate log entries and reduce the cleaner backlog.
CLEANER_INS_CLEANED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_INS_DEAD - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_INS_MIGRATED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_INS_OBSOLETE - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LAZY_MIGRATION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_LAZY_MIGRATION - Static variable in class com.sleepycat.je.EnvironmentConfig
Controls whether log cleaner threads perform LN (leaf node or record) migration immediately when processing a log file, or lazily during eviction and checkpointing.
CLEANER_LN_SIZE_CORRECTION_FACTOR - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LNQUEUE_HITS - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LNS_CLEANED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LNS_DEAD - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LNS_LOCKED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LNS_MARKED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LNS_MIGRATED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LNS_OBSOLETE - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_LOCK_TIMEOUT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_LOCK_TIMEOUT - Static variable in class com.sleepycat.je.EnvironmentConfig
The lock timeout for cleaner transactions in microseconds.
CLEANER_LOOK_AHEAD_CACHE_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_LOOK_AHEAD_CACHE_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
The look ahead cache size for cleaning in bytes.
CLEANER_MARKED_LNS_PROCESSED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_MAX_BATCH_FILES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_MAX_BATCH_FILES - Static variable in class com.sleepycat.je.EnvironmentConfig
The maximum number of log files in the cleaner's backlog, or zero if there is no limit.
CLEANER_MIN_AGE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_MIN_AGE - Static variable in class com.sleepycat.je.EnvironmentConfig
The minimum age of a file (number of files between it and the active file) to qualify it for cleaning under any conditions.
CLEANER_MIN_FILE_UTILIZATION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_MIN_FILE_UTILIZATION - Static variable in class com.sleepycat.je.EnvironmentConfig
A log file will be cleaned if its utilization percentage is below this value, irrespective of total utilization.
CLEANER_MIN_FILES_TO_DELETE - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
As of 1.7.1, no longer used.
CLEANER_MIN_UTILIZATION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_MIN_UTILIZATION - Static variable in class com.sleepycat.je.EnvironmentConfig
The cleaner will keep the total disk space utilization percentage above this value.
CLEANER_NAME - Static variable in class com.sleepycat.je.Environment
 
CLEANER_PENDING_LNS_LOCKED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_PENDING_LNS_PROCESSED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_PROBE_RUNS - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_READ_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_READ_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
The read buffer size for cleaning.
CLEANER_REMOVE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_REPEAT_ITERATOR_READS - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_RESTART_RETRIES - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
As of 2.0, no longer used.
CLEANER_RETRIES - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
As of 2.0, no longer used.
CLEANER_RMW_FIX - Static variable in class com.sleepycat.je.config.EnvironmentParams
Not part of public API, since it applies to a very old bug.
CLEANER_RUNS - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_THREADS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_THREADS - Static variable in class com.sleepycat.je.EnvironmentConfig
The number of threads allocated by the cleaner for log file processing.
CLEANER_TO_BE_CLEANED_LNS_PROCESSED - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_TOTAL_LOG_SIZE - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
CLEANER_TRACK_DETAIL - Static variable in class com.sleepycat.je.config.EnvironmentParams
Not part of public API.
CLEANER_UPGRADE_TO_LOG_VERSION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
CLEANER_UPGRADE_TO_LOG_VERSION - Static variable in class com.sleepycat.je.EnvironmentConfig
All log files having a log version prior to the specified version will be cleaned at a time when no other log cleaning is necessary.
cleanerBytesInterval - Variable in class com.sleepycat.je.cleaner.Cleaner
 
CleanerFileReader - Class in com.sleepycat.je.log
CleanerFileReader scans log files for INs and LNs.
CleanerFileReader(EnvironmentImpl, int, long, Long, FileSummary, INSummary) - Constructor for class com.sleepycat.je.log.CleanerFileReader
Create this reader to start at a given LSN.
CleanerLogSummary - Class in com.sleepycat.je.cleaner
Persistent form of log summary information, which currently is only the utilization correction info maintained by UtilizationCalculator, and is logged as part of the CheckpointEnd log entry.
CleanerLogSummary(List<UtilizationCalculator.AverageSize>, long, int) - Constructor for class com.sleepycat.je.cleaner.CleanerLogSummary
 
CleanerLogSummary() - Constructor for class com.sleepycat.je.cleaner.CleanerLogSummary
 
CleanerStatDefinition - Class in com.sleepycat.je.cleaner
Per-stat Metadata for JE cleaner statistics.
CleanerStatDefinition() - Constructor for class com.sleepycat.je.cleaner.CleanerStatDefinition
 
cleanLog() - Method in class com.sleepycat.je.Environment
Synchronously invokes database environment log cleaning.
cleanup() - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
cleanup(Logger, EnvironmentImpl, Formatter, Socket, BufferedReader, PrintWriter) - Static method in class com.sleepycat.je.rep.elections.Utils
Cleans up the socket and its related streams after a request/response cycle.
cleanup() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
Invoked when a ReplayTxn is being abandoned on shutdown.
cleanup() - Method in class com.sleepycat.je.util.DbCacheSize
 
cleanup() - Method in class com.sleepycat.je.utilint.StoppableThread
Must be invoked upon, or soon after, exit from the thread to perform any cleanup, and ensure that any allocated resources are freed.
CLEANUP_DONE - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
cleanupDatabaseImpls(boolean) - Method in class com.sleepycat.je.txn.Txn
Cleanup leftover databaseImpls that are a by-product of database operations like removeDatabase(), truncateDatabase().
clear() - Method in class com.sleepycat.collections.DataView
Deletes all records in the current range.
clear() - Method in class com.sleepycat.collections.StoredContainer
Removes all mappings or elements from this map or collection (optional operation).
clear() - Method in class com.sleepycat.je.dbi.DbEnvPool
For unit testing only.
clear() - Method in class com.sleepycat.je.dbi.INList
Clear the entire list at shutdown and release its portion of the memory budget.
clear() - Method in class com.sleepycat.je.dbi.LSNAccumulator
 
clear() - Method in class com.sleepycat.je.evictor.TargetSelector.EvictProfile
 
clear() - Method in class com.sleepycat.je.latch.Latch
 
clear() - Method in class com.sleepycat.je.log.FileManager
Close all file handles and empty the cache.
clear() - Method in class com.sleepycat.je.rep.impl.node.DbCache
Clears out the cache releasing db handles as well
clear() - Method in class com.sleepycat.je.rep.utilint.IntRunningTotalStat
 
clear() - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
Deprecated.
clear(Exception) - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
Clears the underlying map and the latch map, after first counting them down, thus permitting them to make progress.
clear() - Method in class com.sleepycat.je.rep.vlsn.LogItemCache
For explicit release of references.
clear() - Method in class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
clear() - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
clear() - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
clear() - Method in class com.sleepycat.je.utilint.BooleanStat
 
clear() - Method in class com.sleepycat.je.utilint.FloatStat
 
clear() - Method in class com.sleepycat.je.utilint.IntStat
 
clear() - Method in class com.sleepycat.je.utilint.LongArrayStat
 
clear() - Method in class com.sleepycat.je.utilint.LongMaxStat
 
clear() - Method in class com.sleepycat.je.utilint.LongMinStat
 
clear() - Method in class com.sleepycat.je.utilint.LongStat
 
clear() - Method in class com.sleepycat.je.utilint.Stat
Initialize the stat to the proper value at startup, or reset the stat when copyAndClear() is called.
clear() - Method in class com.sleepycat.je.utilint.StatGroup
Clear all stats in a StatGroup.
clear() - Method in class com.sleepycat.je.utilint.StringStat
 
clear() - Method in class com.sleepycat.utilint.LatencyStat
 
clearClosingLocker() - Method in class com.sleepycat.je.dbi.CursorImpl
Called when a cursor move operation is complete.
clearDbTreeCache() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
clearEntries(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.DataValueAdapter
 
clearEntries(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.EntityValueAdapter
 
clearEntries(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.KeyValueAdapter
 
clearEntries(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.PrimaryKeyValueAdapter
 
clearEntries(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.persist.ValueAdapter
Sets the data array of the given entries to null, based on knowledge of which entries are non-null and are not NO_RETURN_ENTRY.
clearEntry(int) - Method in class com.sleepycat.je.tree.BIN
Overridden to account for VLSNCache entries.
clearEntry(int) - Method in class com.sleepycat.je.tree.IN
 
clearEnv() - Method in class com.sleepycat.je.cleaner.FileProcessor
 
clearEnv() - Method in class com.sleepycat.je.incomp.INCompressor
 
clearEnv() - Method in class com.sleepycat.je.recovery.Checkpointer
 
clearForeignKeyTrigger() - Method in class com.sleepycat.je.SecondaryDatabase
Should be called by the foreignKeyTrigger while holding a write lock on the trigger list.
clearKeyPrefixing() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
clearKnownDeleted(int) - Method in class com.sleepycat.je.tree.BIN
Clear the known deleted flag.
clearKnownDeleted(int) - Method in class com.sleepycat.je.tree.IN
Set knownDeleted to false.
clearLatch() - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
Clears the latch freeing any waiters.
clearLatency() - Method in class com.sleepycat.utilint.StatsTracker
Should be called after each interval latency stat collection, to reset for the next period's collection.
clearLsnCompaction() - Method in class com.sleepycat.je.tree.IN
Mutates the compact LSN representation to the expanded representation.
clearNotes() - Static method in class com.sleepycat.je.latch.LatchSupport
 
clearNotes() - Method in class com.sleepycat.je.latch.LatchTable
 
clearPendingDeleted(int) - Method in class com.sleepycat.je.tree.IN
Set pendingDeleted to false.
clearPrimary() - Method in class com.sleepycat.je.SecondaryDatabase
Should be called by the secondaryTrigger while holding a write lock on the trigger list.
clearTarget() - Method in class com.sleepycat.je.tree.ChildReference
Clear the target for this ChildReference.
clearTransactionAcks(Txn) - Method in class com.sleepycat.je.rep.stream.FeederTxns
 
clearUtilizationRepairDone() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Is public for unit testing.
clearWriteLocks(Set<Long>) - Method in class com.sleepycat.je.txn.Txn
Release any write locks that are not in the retainedNodes set.
CLIENT_VERSION - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
clone() - Method in class com.sleepycat.je.CheckpointConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.cleaner.FileSummary
 
clone() - Method in class com.sleepycat.je.CursorConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.DatabaseConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.EnvironmentConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
clone() - Method in class com.sleepycat.je.JoinConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.log.entry.BaseEntry
 
clone() - Method in interface com.sleepycat.je.log.entry.LogEntry
 
clone() - Method in class com.sleepycat.je.PreloadConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
 
clone() - Method in class com.sleepycat.je.rep.stream.MasterStatus
Returns a read-only snapshot of the object.
clone() - Method in class com.sleepycat.je.SecondaryConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.SequenceConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.StatsConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
clone() - Method in class com.sleepycat.je.TransactionConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.je.txn.LockInfo
 
clone() - Method in class com.sleepycat.je.VerifyConfig
Returns a copy of this configuration object.
clone() - Method in class com.sleepycat.persist.evolve.EvolveConfig
Returns a shallow copy of the configuration.
clone() - Method in class com.sleepycat.persist.StoreConfig
Returns a shallow copy of the configuration.
cloneConfig() - Method in class com.sleepycat.je.DatabaseConfig
Deprecated.
As of JE 4.0.13, replaced by DatabaseConfig.clone().

cloneConfig() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Clones the current configuration.
cloneConfig() - Method in class com.sleepycat.persist.evolve.EvolveConfig
Deprecated.
As of JE 4.0.13, replaced by EvolveConfig.clone().

cloneConfig() - Method in class com.sleepycat.persist.StoreConfig
Deprecated.
As of JE 4.0.13, replaced by StoreConfig.clone().

cloneCursor() - Method in class com.sleepycat.collections.DataCursor
Clones a cursor preserving the current position.
cloneCursor(boolean, CacheMode) - Method in class com.sleepycat.je.dbi.CursorImpl
Shallow copy.
cloneCursor(boolean, CacheMode, CursorImpl) - Method in class com.sleepycat.je.dbi.CursorImpl
Performs a shallow copy.
cloneCursorConfig(CursorConfig) - Static method in class com.sleepycat.compat.DbCompat
 
cloneDatabase() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Create a clone of this database that can be used as the new empty database when truncating this database.
cloneGroup(boolean) - Method in class com.sleepycat.je.utilint.StatGroup
 
cloneMutableConfig() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Clones the current mutable configuration.
cloneMutableConfig(EnvironmentMutableConfig) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentMutableConfig.cloneMutableConfig()
cloneMutableConfig() - Method in class com.sleepycat.je.EnvironmentMutableConfig
Used by Environment to create a copy of the application supplied configuration.
cloneRepConfig() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
cloneRepMutableConfig() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
close() - Method in interface com.sleepycat.bind.serial.ClassCatalog
Close a catalog database and release any cached resources.
close() - Method in class com.sleepycat.bind.serial.StoredClassCatalog
 
close() - Method in class com.sleepycat.collections.DataCursor
Closes the associated cursor.
close(Iterator<?>) - Static method in class com.sleepycat.collections.StoredIterator
Closes the given iterator using StoredIterator.close() if it is a StoredIterator.
close() - Method in class com.sleepycat.collections.StoredIterator
Closes this iterator.
close() - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Update memory budgets when this tracker is closed and will never be accessed again.
close() - Method in class com.sleepycat.je.cleaner.Cleaner
Release resources and update memory budget.
close(MemoryBudget) - Method in class com.sleepycat.je.cleaner.FileSelector
Update memory budgets when the environment is closed and will never be accessed again.
close() - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Update memory budgets when this tracker is closed and will never be accessed again.
close() - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Update memory budgets when this profile is closed and will never be accessed again.
close() - Method in class com.sleepycat.je.Cursor
Discards the cursor.
close() - Method in class com.sleepycat.je.Database
Discards the database handle.
close() - Method in class com.sleepycat.je.dbi.CursorImpl
 
close(CursorImpl) - Method in class com.sleepycat.je.dbi.CursorImpl
Close a cursor.
close() - Method in class com.sleepycat.je.dbi.DbTree
Release resources and update memory budget.
close() - Method in class com.sleepycat.je.dbi.DiskOrderedCursorImpl
 
close() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Decrements the reference count and closes the environment when it reaches zero.
close(boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Decrements the reference count and closes the environment when it reaches zero.
close() - Method in class com.sleepycat.je.DiskOrderedCursor
Discards the cursor.
close() - Method in class com.sleepycat.je.Environment
The Environment.close method closes the Berkeley DB environment.
close() - Method in interface com.sleepycat.je.ForwardCursor
Discards the cursor.
close() - Method in class com.sleepycat.je.jca.ra.JEConnection
 
close() - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
close() - Method in class com.sleepycat.je.JoinCursor
Closes the cursors that have been opened by this join cursor.
close() - Method in class com.sleepycat.je.log.FileHandle
 
close() - Method in class com.sleepycat.je.log.FileManager
Clear the file lock.
close() - Method in class com.sleepycat.je.log.FileManager.LogEndFileDescriptor
Close the end of the log file descriptor.
close() - Method in class com.sleepycat.je.rep.impl.node.Replay
Release all transactions, database handles, etc held by the replay unit.
close() - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
 
close() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Close this ReplicatedEnvironment and release any resources used by the handle.
close() - Method in class com.sleepycat.je.rep.stream.FeederTxns
 
close(boolean) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
close(Environment, Database) - Static method in class com.sleepycat.je.rep.util.ldiff.LDiffUtil
 
close() - Method in class com.sleepycat.je.rep.utilint.NamedChannel
 
close() - Method in class com.sleepycat.je.rep.utilint.NamedChannelWithTimeout
 
close() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
close() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
close(boolean) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
close() - Method in class com.sleepycat.je.SecondaryDatabase
Closes a secondary database and dis-associates it from its primary database.
close() - Method in class com.sleepycat.je.Sequence
Closes a sequence.
close() - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
close() - Method in interface com.sleepycat.je.trigger.PersistentTrigger
The trigger method associated with the close of the last writable Database handle.
close() - Method in class com.sleepycat.je.txn.BuddyLocker
 
close() - Method in class com.sleepycat.je.txn.Locker
Should be called by all subclasses when the locker is no longer used.
close() - Method in class com.sleepycat.je.txn.ThreadLocker
 
close(boolean) - Method in class com.sleepycat.je.txn.Txn
Close and unregister this txn.
close() - Method in class com.sleepycat.je.util.LogVerificationInputStream
close() - Method in class com.sleepycat.je.utilint.ConfiguredRedirectHandler
 
close() - Method in class com.sleepycat.je.utilint.FileRedirectHandler
 
close() - Method in class com.sleepycat.persist.BasicCursor
 
close() - Method in interface com.sleepycat.persist.EntityCursor
Closes the cursor.
close() - Method in class com.sleepycat.persist.EntityStore
Closes all databases and sequences that were opened via this store.
close() - Method in interface com.sleepycat.persist.ForwardCursor
Closes the cursor.
close() - Method in class com.sleepycat.persist.impl.PersistCatalog
Decrements the reference count and closes the catalog DB when it reaches zero.
close() - Method in class com.sleepycat.persist.impl.Store
 
close() - Method in class com.sleepycat.persist.raw.RawStore
Closes all databases and sequences that were opened by this model.
close() - Method in class com.sleepycat.util.keyrange.RangeCursor
 
closeAfterInvalid() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
closeClass(Class) - Method in class com.sleepycat.persist.EntityStore
Closes the primary and secondary databases for the given entity class that were opened via this store.
closeClass(Class) - Method in class com.sleepycat.persist.impl.Store
 
closeCursor(Cursor) - Method in class com.sleepycat.collections.CurrentTransaction
Closes a cursor.
closeCursor(Cursor) - Method in class com.sleepycat.collections.MyRangeCursor
 
closeCursor(DataCursor) - Method in class com.sleepycat.collections.StoredContainer
 
closeCursor(Cursor) - Method in class com.sleepycat.util.keyrange.RangeCursor
Closes the given cursor.
CLOSED - Static variable in class com.sleepycat.je.dbi.DbEnvState
 
closeEnv() - Method in class com.sleepycat.je.util.DbVerify
 
closeEnvironment(EnvironmentImpl, boolean, boolean) - Method in class com.sleepycat.je.dbi.DbEnvPool
Called by EnvironmentImpl.close to perform the close operation while synchronized on the DbEnvPool.
closeEnvironmentAfterInvalid(EnvironmentImpl) - Method in class com.sleepycat.je.dbi.DbEnvPool
Called by EnvironmentImpl.closeAfterInvalid to perform the close operation while synchronized on the DbEnvPool.
closeInternalHandle(Environment) - Static method in class com.sleepycat.je.DbInternal
Proxy to Environment.closeInternalHandle
closeInternalHandle() - Method in class com.sleepycat.je.Environment
Close an InternalEnvironment handle.
clusterAll - Variable in class com.sleepycat.je.cleaner.Cleaner
 
clusterResident - Variable in class com.sleepycat.je.cleaner.Cleaner
 
CmdUtil - Class in com.sleepycat.je.utilint
Convenience methods for command line utilities.
CmdUtil() - Constructor for class com.sleepycat.je.utilint.CmdUtil
 
codeVersion - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
CollectionProxy<E> - Class in com.sleepycat.persist.impl
Proxy for Collection types.
CollectionProxy() - Constructor for class com.sleepycat.persist.impl.CollectionProxy
 
CollectionProxy.ArrayListProxy<E> - Class in com.sleepycat.persist.impl
 
CollectionProxy.ArrayListProxy() - Constructor for class com.sleepycat.persist.impl.CollectionProxy.ArrayListProxy
 
CollectionProxy.HashSetProxy<E> - Class in com.sleepycat.persist.impl
 
CollectionProxy.HashSetProxy() - Constructor for class com.sleepycat.persist.impl.CollectionProxy.HashSetProxy
 
CollectionProxy.LinkedListProxy<E> - Class in com.sleepycat.persist.impl
 
CollectionProxy.LinkedListProxy() - Constructor for class com.sleepycat.persist.impl.CollectionProxy.LinkedListProxy
 
CollectionProxy.TreeSetProxy<E> - Class in com.sleepycat.persist.impl
 
CollectionProxy.TreeSetProxy() - Constructor for class com.sleepycat.persist.impl.CollectionProxy.TreeSetProxy
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.EnumFormat
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.FieldInfo
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.Format
Calls catalog.createFormat for formats that this format depends on, or that should also be persistent.
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.NonPersistentFormat
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
collectRelatedFormats(Catalog, Map<String, Format>) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
collectStats() - Method in class com.sleepycat.je.txn.BasicLocker
Stats.
collectStats() - Method in class com.sleepycat.je.txn.Locker
Get lock count, for per transaction lock stats, for internal debugging.
collectStats() - Method in class com.sleepycat.je.txn.Txn
stats
com.sleepycat.asm - package com.sleepycat.asm
 
com.sleepycat.bind - package com.sleepycat.bind
Bindings between database entries and Java objects.
com.sleepycat.bind.serial - package com.sleepycat.bind.serial
Bindings that use Java serialization.
com.sleepycat.bind.tuple - package com.sleepycat.bind.tuple
Bindings that use sequences of primitive fields, or tuples.
com.sleepycat.collections - package com.sleepycat.collections
Data access based on the standard Java collections API.
com.sleepycat.compat - package com.sleepycat.compat
 
com.sleepycat.je - package com.sleepycat.je
Foundation for creating environments, databases and transactions; provides cursor based data access.
com.sleepycat.je.cleaner - package com.sleepycat.je.cleaner
 
com.sleepycat.je.config - package com.sleepycat.je.config
Environment configuration parameter support.
com.sleepycat.je.dbi - package com.sleepycat.je.dbi
 
com.sleepycat.je.evictor - package com.sleepycat.je.evictor
Provides classes and interfaces for memory reclamation in JE.
com.sleepycat.je.incomp - package com.sleepycat.je.incomp
 
com.sleepycat.je.jca.ra - package com.sleepycat.je.jca.ra
Support for the Java Connector Architecture, which provides a standard for connecting the J2EE platform to legacy enterprise information systems (EIS), such as ERP systems, database systems, and legacy applications not written in Java.
com.sleepycat.je.jmx - package com.sleepycat.je.jmx
Implementations of JMX MBeans for JE.
com.sleepycat.je.jmx.plugin - package com.sleepycat.je.jmx.plugin
 
com.sleepycat.je.latch - package com.sleepycat.je.latch
Provides classes and interfaces for latches in JDB.
com.sleepycat.je.log - package com.sleepycat.je.log
Provides classes and interfaces for the JDB log subsystem.
com.sleepycat.je.log.entry - package com.sleepycat.je.log.entry
 
com.sleepycat.je.recovery - package com.sleepycat.je.recovery
 
com.sleepycat.je.rep - package com.sleepycat.je.rep
Berkeley DB Java Edition High Availability (JE HA) enables replication of JE environments.
com.sleepycat.je.rep.elections - package com.sleepycat.je.rep.elections
 
com.sleepycat.je.rep.impl - package com.sleepycat.je.rep.impl
 
com.sleepycat.je.rep.impl.networkRestore - package com.sleepycat.je.rep.impl.networkRestore
 
com.sleepycat.je.rep.impl.node - package com.sleepycat.je.rep.impl.node
 
com.sleepycat.je.rep.jmx - package com.sleepycat.je.rep.jmx
 
com.sleepycat.je.rep.jmx.plugin - package com.sleepycat.je.rep.jmx.plugin
 
com.sleepycat.je.rep.monitor - package com.sleepycat.je.rep.monitor
BDB JE HA support for applications that need to track the composition of a replication group, in order to do tasks such as load balancing and request routing.
com.sleepycat.je.rep.stream - package com.sleepycat.je.rep.stream
 
com.sleepycat.je.rep.txn - package com.sleepycat.je.rep.txn
 
com.sleepycat.je.rep.util - package com.sleepycat.je.rep.util
BDB JE High Availability command line utilities and helper classes.
com.sleepycat.je.rep.util.ldiff - package com.sleepycat.je.rep.util.ldiff
 
com.sleepycat.je.rep.utilint - package com.sleepycat.je.rep.utilint
 
com.sleepycat.je.rep.vlsn - package com.sleepycat.je.rep.vlsn
 
com.sleepycat.je.sync - package com.sleepycat.je.sync
Data synchronization framework that provides the basis for data transfer between JE Databases and external systems.
com.sleepycat.je.sync.impl - package com.sleepycat.je.sync.impl
 
com.sleepycat.je.sync.jdbc - package com.sleepycat.je.sync.jdbc
Data synchronization processor for data transfer between JE Databases and any RMDBS using JDBC.
com.sleepycat.je.sync.mobile - package com.sleepycat.je.sync.mobile
Data synchronization processor for data transfer between JE Databases and the Oracle RMDBS using Oracle Mobile Server.
com.sleepycat.je.tree - package com.sleepycat.je.tree
 
com.sleepycat.je.tree.dupConvert - package com.sleepycat.je.tree.dupConvert
 
com.sleepycat.je.trigger - package com.sleepycat.je.trigger
This package defines the trigger classes used in JE.
com.sleepycat.je.txn - package com.sleepycat.je.txn
Provides classes and interfaces for Transactions in JDB.
com.sleepycat.je.util - package com.sleepycat.je.util
Supporting utilities.
com.sleepycat.je.utilint - package com.sleepycat.je.utilint
 
com.sleepycat.persist - package com.sleepycat.persist
The Direct Persistence Layer (DPL) adds a persistent object model to the Berkeley DB transactional engine.
com.sleepycat.persist.evolve - package com.sleepycat.persist.evolve
Utilities for managing class evolution of persistent objects.
com.sleepycat.persist.impl - package com.sleepycat.persist.impl
 
com.sleepycat.persist.model - package com.sleepycat.persist.model
Annotations for defining a persistent object model.
com.sleepycat.persist.raw - package com.sleepycat.persist.raw
Raw data access for general purpose tools and manual conversions.
com.sleepycat.util - package com.sleepycat.util
General utilities used throughout Berkeley DB.
com.sleepycat.util.keyrange - package com.sleepycat.util.keyrange
 
com.sleepycat.utilint - package com.sleepycat.utilint
 
combine(DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.je.dbi.DupKeyData
Returns twoPartKey as: paramKey bytes, paramData bytes, reverse-packed len of paramKey bytes.
combine(byte[], byte[]) - Static method in class com.sleepycat.je.dbi.DupKeyData
 
combine(byte[], int, int, byte[], int, int) - Static method in class com.sleepycat.je.dbi.DupKeyData
 
combineConfig(DatabaseImpl, DatabaseConfig) - Static method in class com.sleepycat.je.DatabaseConfig
Combine the per-Database handle and Database-wide properties for a database handle.
combineDupKeyData() - Method in class com.sleepycat.je.log.entry.DeletedDupLNLogEntry
 
combineDupKeyData() - Method in class com.sleepycat.je.log.entry.LNLogEntry
Combine old key and old LN's data into a new key, and set the LN's data to empty.
comboToObjects - Variable in class com.sleepycat.je.jmx.plugin.Stats
 
comment - Variable in class com.sleepycat.je.utilint.EventTrace
 
commit() - Method in class com.sleepycat.je.jca.ra.JELocalTransaction
 
COMMIT - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
commit(Durability.SyncPolicy, ReplicationContext, int) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
Commits the txn being replayed.
commit() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
commit(Durability) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
commit(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
commit() - Method in class com.sleepycat.je.Transaction
End the transaction.
commit(Durability) - Method in class com.sleepycat.je.Transaction
End the transaction using the specified durability requirements.
commit(Transaction) - Method in interface com.sleepycat.je.trigger.TransactionTrigger
The trigger method invoked after a transaction has been committed.
commit(Xid) - Method in class com.sleepycat.je.txn.Txn
 
commit() - Method in class com.sleepycat.je.txn.Txn
Call commit() with the default sync configuration property.
commit(Durability) - Method in class com.sleepycat.je.txn.Txn
Commit this transaction; it involves the following logical steps: 1.
commit(Xid, boolean) - Method in class com.sleepycat.je.XAEnvironment
 
COMMIT_NO_SYNC - Static variable in class com.sleepycat.je.Durability
A convenience constant that defines a durability policy with COMMIT_NO_SYNC for local commit synchronization.
COMMIT_SYNC - Static variable in class com.sleepycat.je.Durability
A convenience constant that defines a durability policy with COMMIT_SYNC for local commit synchronization.
COMMIT_TO_NETWORK - Static variable in class com.sleepycat.je.rep.impl.RepParams
Changes the notion of an ack.
COMMIT_WRITE_NO_SYNC - Static variable in class com.sleepycat.je.Durability
A convenience constant that defines a durability policy with COMMIT_WRITE_NO_SYNC for local commit synchronization.
commitAutoCommit(boolean) - Method in class com.sleepycat.collections.StoredContainer
 
CommitFreezeLatch - Class in com.sleepycat.je.rep.impl.node
Ensures that a VLSN is not advanced at this node while an election is in progress.
CommitFreezeLatch() - Constructor for class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
 
commitLsn - Variable in class com.sleepycat.je.txn.Txn
 
commitNoSync() - Method in class com.sleepycat.je.Transaction
End the transaction, not writing to stable storage and not committing synchronously.
CommitPointConsistencyPolicy - Class in com.sleepycat.je.rep
A consistency policy which ensures that the environment on a Replica node is at least as current as denoted by the specified CommitToken.
CommitPointConsistencyPolicy(CommitToken, long, TimeUnit) - Constructor for class com.sleepycat.je.rep.CommitPointConsistencyPolicy
Defines how current a Replica needs to be in terms of a specific transaction that was committed on the Master.
commitSync() - Method in class com.sleepycat.je.Transaction
End the transaction, writing to stable storage and committing synchronously.
CommitToken - Class in com.sleepycat.je
Defines an opaque token that can be used to identify a specific transaction commit in a replicated environment.
CommitToken(UUID, long) - Constructor for class com.sleepycat.je.CommitToken
 
commitTransaction() - Method in class com.sleepycat.collections.CurrentTransaction
Commits the transaction that is active for the current thread for this environment and makes the parent transaction (if any) the current transaction.
commitWriteNoSync() - Method in class com.sleepycat.je.Transaction
End the transaction, writing to stable storage but not committing synchronously.
compact(IN) - Method in class com.sleepycat.je.tree.INArrayRep
Chooses a more compact representation, if that's possible, otherwise does nothing.
compact(IN) - Method in class com.sleepycat.je.tree.INKeyRep.Default
Evolves to the MaxKeySize representation if that is more efficient for the current set of keys.
compact(IN) - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
compact(IN) - Method in class com.sleepycat.je.tree.INTargetRep.Default
 
compact(IN) - Method in class com.sleepycat.je.tree.INTargetRep.None
 
compact(IN) - Method in class com.sleepycat.je.tree.INTargetRep.Sparse
 
compactMemory() - Method in class com.sleepycat.je.tree.IN
 
comparator() - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns null since comparators are not supported.
comparator() - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns null since comparators are not supported.
comparator() - Method in class com.sleepycat.collections.StoredSortedMap
Returns null since comparators are not supported.
comparator() - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns null since comparators are not supported.
comparator - Variable in class com.sleepycat.util.keyrange.KeyRange
 
ComparatorCatalog - Class in com.sleepycat.persist.impl
Read-only catalog used by a PersistComparator to return simple formats plus reconstituted enum formats.
ComparatorCatalog(ClassLoader, Map<String, Format>) - Constructor for class com.sleepycat.persist.impl.ComparatorCatalog
 
comparatorToBytes(Comparator<byte[]>, boolean, String) - Static method in class com.sleepycat.je.dbi.DatabaseImpl
Converts a comparator object to a serialized byte array, converting to a class name String object if byClassName is true.
compare(byte[], byte[]) - Method in class com.sleepycat.je.dbi.DupKeyData.NextNoDupComparator
 
compare(byte[], byte[]) - Method in class com.sleepycat.je.dbi.DupKeyData.PutNoOverwriteComparator
 
compare(byte[], byte[]) - Method in class com.sleepycat.je.dbi.DupKeyData.TwoPartKeyComparator
 
compare(LogEntryType, LogEntryType) - Method in class com.sleepycat.je.log.StatsFileReader.LogEntryTypeComparator
 
compare(byte[], byte[]) - Method in class com.sleepycat.persist.impl.PersistComparator
 
compare(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.util.keyrange.KeyRange
Compares two keys, using the user comparator if there is one.
compareBytes(byte[], int, int, byte[], int, int) - Static method in class com.sleepycat.util.keyrange.KeyRange
Compares two keys as unsigned byte arrays, which is the default comparison used by JE/DB.
compareDuplicates(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Database
Compares two data elements using either the default comparator if no duplicate comparator has been set or the duplicate comparator if one has been set.
compareEntries(DatabaseEntry, DatabaseEntry, boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
compareKeys(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Database
Compares two keys using either the default comparator if no BTree comparator has been set or the BTree comparator if one has been set.
compareKeys(byte[], int, int, byte[], int, int, Comparator<byte[]>) - Static method in class com.sleepycat.je.tree.Key
Compare keys with an optional comparator.
compareKeys(byte[], byte[], Comparator<byte[]>) - Static method in class com.sleepycat.je.tree.Key
Compare keys with an optional comparator.
compareMainKey(byte[], byte[], Comparator<byte[]>) - Static method in class com.sleepycat.je.dbi.DupKeyData
Compares the first part of the two keys.
compareMainKey(byte[], byte[], int, int, Comparator<byte[]>) - Static method in class com.sleepycat.je.dbi.DupKeyData
Compares the first part of the two keys.
compareTo(CommitToken) - Method in class com.sleepycat.je.CommitToken
Implements the Comparable interface.
compareTo(DatabaseId) - Method in class com.sleepycat.je.dbi.DatabaseId
see Comparable#compareTo
compareTo(JEVersion) - Method in class com.sleepycat.je.JEVersion
 
compareTo(IN) - Method in class com.sleepycat.je.tree.IN
Sort based on equality key.
compareTo(Key) - Method in class com.sleepycat.je.tree.Key
Compare two keys.
compareTo(TxnChain.CompareSlot) - Method in class com.sleepycat.je.txn.TxnChain.CompareSlot
 
compareTo(long, long) - Static method in class com.sleepycat.je.utilint.DbLsn
 
compareTo(Object) - Method in class com.sleepycat.je.utilint.StatDefinition
 
compareTo(VLSN) - Method in class com.sleepycat.je.utilint.VLSN
Compares this VLSN's sequence with the specified VLSN's sequence for order.
compareTo(FieldInfo) - Method in class com.sleepycat.persist.impl.FieldInfo
 
compareToKeyPrefix(byte[]) - Method in class com.sleepycat.je.tree.IN
 
compareTypeAndVersion(int, int, byte) - Method in class com.sleepycat.je.log.LogEntryType
Return true if the type of this LogEntryType is equivalent to typeB.
compareTypeAndVersion(int, byte, int, byte) - Static method in class com.sleepycat.je.log.LogEntryType
Return true if the two types are equal.
compareUnsignedBytes(byte[], int, int, byte[], int, int) - Static method in class com.sleepycat.je.tree.Key
Compare using a default unsigned byte comparison.
ComplexFormat - Class in com.sleepycat.persist.impl
Format for persistent complex classes that are not composite key classes.
ComplexFormat(Catalog, Class, ClassMetadata, EntityMetadata) - Constructor for class com.sleepycat.persist.impl.ComplexFormat
 
CompositeKeyFormat - Class in com.sleepycat.persist.impl
Format for a composite key class.
CompositeKeyFormat(Catalog, Class, ClassMetadata, List<FieldMetadata>) - Constructor for class com.sleepycat.persist.impl.CompositeKeyFormat
Creates a new composite key format.
CompositeKeyFormat(Catalog, Class, String[]) - Constructor for class com.sleepycat.persist.impl.CompositeKeyFormat
Reconsistitues a composite key format after a PersistComparator is deserialized.
compress() - Method in class com.sleepycat.je.Environment
Synchronously invokes the compressor mechanism which compacts in memory data structures after delete operations.
compress(LocalUtilizationTracker) - Method in class com.sleepycat.je.tree.BIN
Compress this BIN by removing any entries that are deleted.
COMPRESSOR_DEADLOCK_RETRY - Static variable in class com.sleepycat.je.EnvironmentConfig
The number of times to retry a compression run if a deadlock occurs.
COMPRESSOR_LOCK_TIMEOUT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
COMPRESSOR_LOCK_TIMEOUT - Static variable in class com.sleepycat.je.EnvironmentConfig
The lock timeout for compressor transactions in microseconds.
COMPRESSOR_PURGE_ROOT - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
as of 3.3.87. Compression of the root node no longer has any benefit and this feature has been removed. This parameter has no effect.
COMPRESSOR_RETRY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
COMPRESSOR_WAKEUP_INTERVAL - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
COMPRESSOR_WAKEUP_INTERVAL - Static variable in class com.sleepycat.je.EnvironmentConfig
The compressor thread wakeup interval in microseconds.
COMPUTE_FRAMES - Static variable in class com.sleepycat.asm.ClassWriter
Flag to automatically compute the stack map frames of methods from scratch.
COMPUTE_MAXS - Static variable in class com.sleepycat.asm.ClassWriter
Flag to automatically compute the maximum stack size and the maximum number of local variables of methods.
computeMemorySize() - Method in class com.sleepycat.je.tree.BIN
Adds VLSNCache size to computed memory size.
computeMemorySize() - Method in class com.sleepycat.je.tree.dupConvert.DIN
Count up the memory usage attributable to this node alone.
computeMemorySize() - Method in class com.sleepycat.je.tree.IN
Count up the memory usage attributable to this node alone.
concatByteArray(byte[], byte[]) - Static method in class com.sleepycat.je.rep.util.ldiff.LDiffUtil
 
concurrentDB - Variable in class com.sleepycat.persist.BasicIndex
 
config - Variable in class com.sleepycat.je.Cursor
The CursorConfig used to configure this cursor.
ConfigBeanInfoBase - Class in com.sleepycat.util
 
ConfigBeanInfoBase() - Constructor for class com.sleepycat.util.ConfigBeanInfoBase
 
configFlushTask(int) - Method in class com.sleepycat.je.rep.impl.node.LogFlusher
 
configLogFlusher(DbConfigManager) - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
configManager - Variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
ConfigParam - Class in com.sleepycat.je.config
A ConfigParam embodies the metadata about a JE configuration parameter: the parameter name, default value, and a validation method.
ConfigParam(String, String, boolean, boolean) - Constructor for class com.sleepycat.je.config.ConfigParam
 
configuration - Variable in class com.sleepycat.je.Database
 
configuredClone(CursorConfig) - Method in class com.sleepycat.collections.StoredContainer
Clones a container with a specified cursor configuration.
configuredCollection(Collection<E>, CursorConfig) - Static method in class com.sleepycat.collections.StoredCollections
Creates a configured collection from a given stored collection.
configuredList(List<E>, CursorConfig) - Static method in class com.sleepycat.collections.StoredCollections
Creates a configured list from a given stored list.
configuredMap(Map<K, V>, CursorConfig) - Static method in class com.sleepycat.collections.StoredCollections
Creates a configured map from a given stored map.
ConfiguredRedirectHandler - Class in com.sleepycat.je.utilint
Redirects logging messages to the owning environment's application configured handler, if one was specified through EnvironmentConfig.setLoggingHandler().
ConfiguredRedirectHandler() - Constructor for class com.sleepycat.je.utilint.ConfiguredRedirectHandler
 
configuredSet(Set<E>, CursorConfig) - Static method in class com.sleepycat.collections.StoredCollections
Creates a configured set from a given stored set.
configuredSortedMap(SortedMap<K, V>, CursorConfig) - Static method in class com.sleepycat.collections.StoredCollections
Creates a configured sorted map from a given stored sorted map.
configuredSortedSet(SortedSet<E>, CursorConfig) - Static method in class com.sleepycat.collections.StoredCollections
Creates a configured sorted set from a given stored sorted set.
configuredVersion - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
configuredView(CursorConfig) - Method in class com.sleepycat.collections.DataView
Returns a new view with a specified cursor configuration.
connection - Static variable in class com.sleepycat.je.jmx.plugin.Stats
 
CONSISTENCY_POLICY - Static variable in class com.sleepycat.je.rep.impl.RepParams
Identifies the default consistency policy used by a replica.
CONSISTENCY_POLICY - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The default consistency policy used by a replica.
consistencyPolicy - Variable in exception com.sleepycat.je.rep.ReplicaConsistencyException
 
CONSOLE_LOGGING_LEVEL - Static variable in class com.sleepycat.je.EnvironmentConfig
Trace messages equal and above this level will be logged to the console.
ConsoleHandler - Class in com.sleepycat.je.util
JE instances of java.util.logging.Logger are configured to use this implementation of java.util.logging.ConsoleHandler.
ConsoleHandler(Formatter, EnvironmentImpl) - Constructor for class com.sleepycat.je.util.ConsoleHandler
 
CONSOLEHANDLER_LEVEL - Static variable in class com.sleepycat.je.jmx.JEDiagnostics
 
ConsoleRedirectHandler - Class in com.sleepycat.je.utilint
Redirects logging messages to the owning environment's console handler, so that messages can be prefixed with an environment name.
ConsoleRedirectHandler() - Constructor for class com.sleepycat.je.utilint.ConsoleRedirectHandler
 
contains(Object) - Method in class com.sleepycat.collections.StoredEntrySet
Returns true if this set contains the specified element.
contains(Object) - Method in class com.sleepycat.collections.StoredKeySet
Returns true if this set contains the specified key.
contains(Object) - Method in class com.sleepycat.collections.StoredList
Returns true if this list contains the specified element.
contains(Object) - Method in class com.sleepycat.collections.StoredValueSet
Returns true if this set contains the specified element.
contains(Long) - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
 
contains(long) - Method in class com.sleepycat.je.cleaner.OffsetList
Returns whether this list contains the given offset.
contains(IN) - Method in class com.sleepycat.je.dbi.INList
 
contains(long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
This log entry belongs to this rollback period if it lies between the matchpoint and the RollbackStart.
contains(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
contains(T) - Method in class com.sleepycat.je.utilint.TinyHashSet
 
contains(K) - Method in class com.sleepycat.persist.BasicIndex
 
contains(Transaction, K, LockMode) - Method in class com.sleepycat.persist.BasicIndex
 
contains(K) - Method in interface com.sleepycat.persist.EntityIndex
Checks for existence of a key in this index.
contains(Transaction, K, LockMode) - Method in interface com.sleepycat.persist.EntityIndex
Checks for existence of a key in this index.
contains(PK) - Method in class com.sleepycat.persist.SubIndex
 
contains(Transaction, PK, LockMode) - Method in class com.sleepycat.persist.SubIndex
 
containsAll(Collection<?>) - Method in class com.sleepycat.collections.StoredCollection
Returns true if this collection contains all of the elements in the specified collection.
containsDuplicates() - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
containsDuplicates() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
containsDuplicates() - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
containsDuplicates() - Method in class com.sleepycat.je.tree.Node
Since DIN/DBIN/DupCountLN are no longer used in the Btree, this method should normally only be used by dup conversion or entities that do not access records via the Btree.
containsKey(Object) - Method in class com.sleepycat.collections.StoredContainer
 
containsKey(Object) - Method in class com.sleepycat.collections.StoredMap
Returns true if this map contains the specified key.
containsKey(Object) - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
containsLN(long, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
containsLsn(long, long) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
containsLsn(long) - Method in class com.sleepycat.je.log.LogBuffer
Support for reading out of a still-in-memory log.
containsNode(Integer, Long) - Method in class com.sleepycat.je.recovery.DirtyINMap
 
containsObsoleteOffset(long) - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Returns whether the given offset is present in the tracked offsets.
containsOffset(long) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
containsValue(Object) - Method in class com.sleepycat.collections.StoredContainer
 
containsValue(Object) - Method in class com.sleepycat.collections.StoredMap
Returns true if this map contains the specified value.
containsValue(Object) - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
continueAfterWriteException() - Static method in class com.sleepycat.je.log.FileManager
Returns whether we are in a test mode where we attempt to continue after a write IOException.
Conversion - Interface in com.sleepycat.persist.evolve
Converts an old version of an object value to conform to the current class or field definition.
convert() - Method in class com.sleepycat.je.rep.util.DbEnableReplication
Modify the log files in the environment directory to add a modicum of replication required metadata.
convert(Object) - Method in interface com.sleepycat.persist.evolve.Conversion
Converts an old version of an object value to conform to the current class or field definition.
convertCommitToAbort(ByteBuffer) - Method in class com.sleepycat.je.log.LogEntryHeader
For use in special case where commits are transformed to aborts because of i/o errors during a logBuffer flush.
convertDatabases() - Method in class com.sleepycat.je.tree.dupConvert.DupConvert
Converts all dup DBs that need conversion.
Converter - Class in com.sleepycat.persist.evolve
A mutation for converting an old version of an object value to conform to the current class or field definition.
Converter(String, int, Conversion) - Constructor for class com.sleepycat.persist.evolve.Converter
Creates a mutation for converting all instances of the given class version to the current version of the class.
Converter(String, int, String, Conversion) - Constructor for class com.sleepycat.persist.evolve.Converter
Creates a mutation for converting all values of the given field in the given class version to a type compatible with the current declared type of the field.
ConverterReader - Class in com.sleepycat.persist.impl
Reader for invoking a class Converter mutation.
ConverterReader(Converter) - Constructor for class com.sleepycat.persist.impl.ConverterReader
 
convertException(Exception) - Static method in class com.sleepycat.collections.StoredContainer
 
convertExternalToLocal(Object[], DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.je.sync.RecordConverter
Converts an array of external record values to a local raw data record.
convertExternalToLocal(Object[], DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.sync.RecordMapping
Called internally to convert an array of external record values to a local raw data record.
convertInKeys(DatabaseImpl, IN) - Static method in class com.sleepycat.je.tree.dupConvert.DupConvert
Changes all keys to "prefix keys" in the given IN.
convertIntFileOffsetToLong(int) - Static method in class com.sleepycat.je.utilint.DbLsn
 
convertLocalToExternal(DatabaseEntry, DatabaseEntry, Object[]) - Method in interface com.sleepycat.je.sync.RecordConverter
Converts the local raw data record to an array of external record values.
convertLocalToExternal(DatabaseEntry, DatabaseEntry, Object[]) - Method in class com.sleepycat.je.sync.RecordMapping
Called internally to convert the local raw data record to an array of external record values.
convertProxy() - Method in class com.sleepycat.persist.impl.CollectionProxy
 
convertProxy() - Method in class com.sleepycat.persist.impl.MapProxy
 
convertProxy() - Method in interface com.sleepycat.persist.model.PersistentProxy
Returns a new proxied class instance to which the state of this proxy instance has been copied.
convertRawObject(RawObject, IdentityHashMap) - Method in interface com.sleepycat.persist.impl.Catalog
 
convertRawObject(Catalog, boolean, RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
convertRawObject(Catalog, boolean, RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
convertRawObject(Catalog, boolean, RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.EnumFormat
 
convertRawObject(Catalog, boolean, RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.Format
Converts a RawObject to a current class object and adds the converted pair to the converted map.
convertRawObject(Catalog, boolean, RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
convertRawObject(RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.PersistCatalog
 
convertRawObject(Catalog, boolean, RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
convertRawObject(Catalog, boolean, RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
convertRawObject(RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
convertRawObject(RawObject, IdentityHashMap) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
convertRawObject(RawObject) - Method in class com.sleepycat.persist.model.EntityModel
Converts a given raw object to a live object according to the current class definitions.
convertToNodeState() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
coordinateEvictionWithCheckpoint(IN, IN) - Method in class com.sleepycat.je.recovery.Checkpointer
Coordinates an eviction with an in-progress checkpoint and returns whether provisional logging is needed.
coordinateEvictionWithCheckpoint(IN, IN) - Method in class com.sleepycat.je.recovery.DirtyINMap
Coordinates an eviction with an in-progress checkpoint and returns whether or not provisional logging is needed.
copy(int, int, int, IN) - Method in class com.sleepycat.je.tree.INArrayRep
Copies n elements at index denoted by "from" to the index denoted by "to".
copy(int, int, int, IN) - Method in class com.sleepycat.je.tree.INKeyRep.Default
 
copy(int, int, int, IN) - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
copy(int, int, int, IN) - Method in class com.sleepycat.je.tree.INTargetRep.Default
 
copy(int, int, int, IN) - Method in class com.sleepycat.je.tree.INTargetRep.None
 
copy(int, int, int, IN) - Method in class com.sleepycat.je.tree.INTargetRep.Sparse
 
copy(int, int, int) - Method in class com.sleepycat.je.tree.VLSNCache
 
copy(int, int, int) - Method in class com.sleepycat.je.tree.VLSNCache.DefaultCache
 
copy() - Method in class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
copy() - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
copy() - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
copy() - Method in class com.sleepycat.je.utilint.LongArrayStat
 
copy() - Method in class com.sleepycat.je.utilint.Stat
 
copy() - Method in class com.sleepycat.je.utilint.TinyHashSet
 
copy(DatabaseEntry) - Static method in class com.sleepycat.util.keyrange.KeyRange
Returns a copy of an entry.
copy(DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.util.keyrange.KeyRange
Copies one entry to another.
copyAbortInfo(WriteLockInfo) - Method in class com.sleepycat.je.txn.LockResult
 
copyAbortInfo(WriteLockInfo) - Method in class com.sleepycat.je.txn.WriteLockInfo
 
copyAndClear() - Method in class com.sleepycat.je.utilint.Stat
Return a copy of this stat, and clear the stat's value.
copyBytes(byte[]) - Static method in class com.sleepycat.util.keyrange.KeyRange
Copies a byte array.
copyElements(RecordInput, Format, Format, Set) - Static method in class com.sleepycat.persist.impl.CollectionProxy
 
copyEntries(int, int, int) - Method in class com.sleepycat.je.tree.BIN
Overridden to account for VLSNCache entries.
copyEntries(int, int, int) - Method in class com.sleepycat.je.tree.IN
 
copyEntry(int, IN, int) - Method in class com.sleepycat.je.tree.BIN
Overridden to account for VLSNCache entries.
copyEntry(int, IN, int) - Method in class com.sleepycat.je.tree.IN
Set the idx'th entry of this node using the specified entry of another node.
copyEntryData(DatabaseEntry) - Static method in class com.sleepycat.je.tree.LN
Returns a byte array that is a complete copy of the data in a non-partial entry.
copyHandlePropsTo(EnvironmentMutableConfig) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Copies the per-handle properties of this object to the given config object.
copyMutablePropsTo(EnvironmentMutableConfig, EnvironmentMutableConfig) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentMutableConfig.copyMutablePropsTo()
copyMutablePropsTo(EnvironmentMutableConfig) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Copies all mutable props to the given config object.
copyMutablePropsTo(ReplicationMutableConfig) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
 
copyObsoleteInfo(PackedObsoleteInfo) - Method in class com.sleepycat.je.cleaner.PackedObsoleteInfo
 
copyPool(ClassWriter) - Method in class com.sleepycat.asm.ClassReader
Copies the constant pool data into the given ClassWriter.
copySafeToDeleteFiles() - Method in class com.sleepycat.je.cleaner.FileSelector
Returns a copy of the SAFE_TO_DELETE files, or null if there are none.
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.EnumFormat
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.Format
Called after skipToSecKey() to copy the data bytes of a singular (XXX_TO_ONE) key field.
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigDec
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigInt
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDate
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
copySecKey(RecordInput, RecordOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FString
 
copySecMultiKey(RecordInput, Format, Set) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
copySecMultiKey(RecordInput, Format, Set) - Method in class com.sleepycat.persist.impl.Format
Called after skipToSecKey() to copy the data bytes of an array or collection (XXX_TO_MANY) key field.
copySecMultiKey(RecordInput, Format, Set) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
copySecMultiKey(RecordInput, Format, Set) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
copySecMultiKey(RecordInput, Format, Set) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
copySecMultiKeyPrimitiveArray(int, RecordInput, Set) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
copyWriteLockInfo(LockResult) - Method in class com.sleepycat.je.txn.LockResult
 
copyWriteLockInfo(WriteLockInfo) - Method in class com.sleepycat.je.txn.LockResult
Used to copy write lock info when an LSN is changed.
correctionFactor - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.TestAdjustment
 
count() - Method in class com.sleepycat.collections.DataCursor
Calls Cursor.count(), no join cursor allowed.
count() - Method in class com.sleepycat.collections.StoredIterator
Returns the number of elements having the same key value as the key value of the element last returned by next() or previous().
count - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.AverageSize
 
count() - Method in class com.sleepycat.je.Cursor
Returns a count of the number of data items for the key to which the cursor refers.
count() - Method in class com.sleepycat.je.Database
Counts the key/data pairs in the database.
count() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Count entries in the database including dups, but don't dirty the cache.
count(IN) - Method in class com.sleepycat.je.evictor.TargetSelector.EvictProfile
 
count - Variable in class com.sleepycat.je.log.StatsFileReader.EntryInfo
 
count(DatabaseImpl, CursorImpl, boolean, CursorImpl, boolean) - Static method in class com.sleepycat.je.tree.CountEstimator
Returns an estimate of the number of records between two end points specified by begin/end cursor positions.
count() - Method in class com.sleepycat.persist.BasicCursor
 
count() - Method in class com.sleepycat.persist.BasicIndex
 
count() - Method in interface com.sleepycat.persist.EntityCursor
Returns the number of values (duplicates) for the key at the cursor position, or returns zero if all values for the key have been deleted.
count() - Method in interface com.sleepycat.persist.EntityIndex
Returns a non-transactional count of the entities in this index.
count() - Method in class com.sleepycat.persist.SubIndex
 
count() - Method in class com.sleepycat.util.keyrange.RangeCursor
 
counter - Variable in class com.sleepycat.je.utilint.LongStat
 
countEstimate() - Method in class com.sleepycat.je.Cursor
Returns a rough estimate of the count of the number of data items for the key to which the cursor refers.
countEstimate() - Method in class com.sleepycat.persist.BasicCursor
 
countEstimate() - Method in interface com.sleepycat.persist.EntityCursor
Returns a rough estimate of the number of values (duplicates) for the key at the cursor position, or returns zero if all values for the key have been deleted.
countEstimateInternal() - Method in class com.sleepycat.je.Cursor
Estimates duplicate count without parameter checking.
CountEstimator - Class in com.sleepycat.je.tree
Estimates the number of non-deleted BIN entries between two end points, using information returned in TrackingInfo from Tree.getParentINForChildIN.
CountEstimator.KeyRatios - Class in com.sleepycat.je.tree
 
CountEstimator.KeyRatios(double, double, double) - Constructor for class com.sleepycat.je.tree.CountEstimator.KeyRatios
 
countInternal() - Method in class com.sleepycat.je.Cursor
Counts duplicates without parameter checking.
countLatchesHeld() - Static method in class com.sleepycat.je.latch.LatchSupport
Only call under the assert system.
countLatchesHeld() - Method in class com.sleepycat.je.latch.LatchTable
Only call under the assert system.
countNew(long, Object, LogEntryType, int) - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Counts the addition of all new log entries including LNs, and returns whether the cleaner should be woken.
countNewLogEntry(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.cleaner.LocalUtilizationTracker
Counts the addition of all new log entries including LNs.
countNewLogEntry(long, LogEntryType, int, DatabaseId) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Counts the addition of all new log entries including LNs.
countNewLogEntry(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.cleaner.UtilizationTracker
Counts the addition of all new log entries including LNs, and returns whether the cleaner should be woken.
countObsolete(long, Object, LogEntryType, int, boolean, boolean, boolean, boolean) - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Counts an obsolete node by incrementing the obsolete count and size.
countObsolete() - Method in class com.sleepycat.je.log.CleanerFileReader
Records the current log entry as obsolete in the FileSummary used to count true utilization.
countObsoleteDb(DbFileSummaryMap, long) - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Counts all active LSNs in a database as obsolete in the per-file utilization summaries.
countObsoleteDb(BaseUtilizationTracker, long) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Counts all active LSNs in a database as obsolete.
countObsoleteDb(DatabaseImpl) - Method in class com.sleepycat.je.log.LogManager
 
countObsoleteDb(DatabaseImpl) - Method in class com.sleepycat.je.log.SyncedLogManager
 
countObsoleteDbInternal(DatabaseImpl) - Method in class com.sleepycat.je.log.LogManager
 
countObsoleteIfUncounted(long, long, LogEntryType, int, DatabaseId, boolean) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Counts the oldLsn of a node obsolete if it has not already been counted at the point of newLsn in the log.
countObsoleteInfo(UtilizationTracker, DatabaseImpl) - Method in class com.sleepycat.je.cleaner.PackedObsoleteInfo
 
countObsoleteNode(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.cleaner.LocalUtilizationTracker
Counts a node that has become obsolete and tracks the LSN offset, if non-zero, to avoid a lookup during cleaning.
countObsoleteNode(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.cleaner.UtilizationTracker
Counts a node that has become obsolete and tracks the LSN offset, if non-zero, to avoid a lookup during cleaning.
countObsoleteNode(long, LogEntryType, int, DatabaseImpl, boolean) - Method in class com.sleepycat.je.log.LogManager
Count node as obsolete under the log write latch.
countObsoleteNode(long, LogEntryType, int, DatabaseImpl, boolean) - Method in class com.sleepycat.je.log.SyncedLogManager
 
countObsoleteNodeDupsAllowed(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.cleaner.UtilizationTracker
Counts as countObsoleteNode does, tracks the obsolete LSN offset, but does not fire an assert if the offset has already been counted.
countObsoleteNodeDupsAllowed(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.log.LogManager
A flavor of countObsoleteNode which does not fire an assert if the offset has already been counted.
countObsoleteNodeDupsAllowed(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.log.SyncedLogManager
 
countObsoleteNodeDupsAllowedInternal(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.log.LogManager
 
countObsoleteNodeInexact(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.cleaner.LocalUtilizationTracker
Counts as countObsoleteNode does, but since the LSN may be inexact, does not track the obsolete LSN offset.
countObsoleteNodeInexact(long, LogEntryType, int, DatabaseImpl) - Method in class com.sleepycat.je.cleaner.UtilizationTracker
Counts as countObsoleteNode does, but since the LSN may be inexact, does not track the obsolete LSN offset.
countObsoleteNodeInternal(long, LogEntryType, int, DatabaseImpl, boolean) - Method in class com.sleepycat.je.log.LogManager
 
countObsoleteUnconditional(long, LogEntryType, int, DatabaseId, boolean) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Counts the LSN of a node obsolete unconditionally.
cr - Variable in class com.sleepycat.asm.ClassWriter
The class reader from which this class writer was constructed, if any.
create(RepNode, Replay) - Static method in class com.sleepycat.je.rep.impl.node.ReplicaFactory
 
create(EnvironmentImpl, TransactionConfig, NameIdPair) - Static method in class com.sleepycat.je.rep.txn.MasterTxn
 
create(EnvironmentImpl, TransactionConfig, NameIdPair) - Method in interface com.sleepycat.je.rep.txn.MasterTxn.MasterTxnFactory
 
createAutoTxn(EnvironmentImpl, TransactionConfig, ReplicationContext) - Static method in class com.sleepycat.je.txn.Txn
 
createBasicLocker(EnvironmentImpl) - Static method in class com.sleepycat.je.txn.BasicLocker
 
createBasicLocker(EnvironmentImpl, boolean) - Static method in class com.sleepycat.je.txn.BasicLocker
 
createBlockBag(Database) - Method in class com.sleepycat.je.rep.util.ldiff.LDiff
Create a bag of blocks from the records in a given database, using the configuration parameters specified when the LDiff object was created.
createBuddyLocker(EnvironmentImpl, Locker) - Static method in class com.sleepycat.je.txn.BuddyLocker
 
createConnectionFactory(ConnectionManager) - Method in class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
createConnectionFactory() - Method in class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
createDatabasePreemptedException(String, String, Database) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; only the overridden method should ever be called.
createDatabasePreemptedException(String, String, Database) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
createDb(Locker, String, DatabaseConfig, HandleLocker) - Method in class com.sleepycat.je.dbi.DbTree
Creates a new database object given a database name.
createDbCache() - Method in class com.sleepycat.je.evictor.Evictor
 
createDbCache() - Method in class com.sleepycat.je.evictor.PrivateEvictor
PrivateEvictor implements a DbCache simply using a HashMap, like cleaner.FileProcessor and other components.
createDbCache() - Method in class com.sleepycat.je.evictor.SharedEvictor
SharedEvictor, unlike PrivateEvictor, must maintain a cache map for each EnvironmentImpl, since each cache map is logically associated with a single DbTree instance.
createDeletedLN(EnvironmentImpl) - Method in enum com.sleepycat.je.dbi.DbType
Creates a deleted LN for use in an optimization in CursorImpl.delete.
createDetachedEnv(File, ReplicationConfig, EnvironmentConfig) - Static method in class com.sleepycat.je.rep.RepInternal
 
createdNode(long) - Method in class com.sleepycat.je.txn.BasicLocker
Always false for this txn.
createdNode(long) - Method in class com.sleepycat.je.txn.Locker
 
createdNode(long) - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Forwards this method to the transactional buddy.
createdNode(long) - Method in class com.sleepycat.je.txn.Txn
 
createFormat(String, Map<String, Format>) - Method in interface com.sleepycat.persist.impl.Catalog
 
createFormat(Class, Map<String, Format>) - Method in interface com.sleepycat.persist.impl.Catalog
 
createFormat(String, Map<String, Format>) - Method in class com.sleepycat.persist.impl.PersistCatalog
Convenience method that gets the class for the given class name and calls createFormat with the class object.
createFormat(Class, Map<String, Format>) - Method in class com.sleepycat.persist.impl.PersistCatalog
If the given class format is not already present in the given map and a format for this class name does not already exist, creates an uninitialized format, adds it to the map, and also collects related formats in the map.
createFormat(String, Map<String, Format>) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
createFormat(Class, Map<String, Format>) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
createFormat(String, Map<String, Format>) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
createFormat(Class, Map<String, Format>) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
createGroupDb() - Method in class com.sleepycat.je.rep.impl.RepImpl
Called when a node has identified itself as the master, which is when the RepNode.selfElect is called.
createHandleLocker(EnvironmentImpl, Locker) - Static method in class com.sleepycat.je.txn.HandleLocker
 
createInternalDb(Locker, String, DatabaseConfig) - Method in class com.sleepycat.je.dbi.DbTree
Create a database for internal use.
createInternalEnvHandle(File, ReplicationConfig, EnvironmentConfig) - Static method in class com.sleepycat.je.rep.RepInternal
 
createInternalEnvironment() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Is overridden in RepImpl to create a ReplicatedEnvironment.
createInternalEnvironment() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
createKeyPrefix(byte[], byte[]) - Static method in class com.sleepycat.je.tree.Key
 
createLocalAutoTxn(EnvironmentImpl, TransactionConfig) - Static method in class com.sleepycat.je.txn.Txn
 
createLocalTxn(EnvironmentImpl, TransactionConfig) - Static method in class com.sleepycat.je.txn.Txn
 
createLockPreemptedException(Locker, Throwable) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; only the overridden method should ever be called.
createLockPreemptedException(Locker, Throwable) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
createLogEntry(LogEntryType, DatabaseImpl, byte[], long, boolean, Txn, ReplicationContext) - Method in class com.sleepycat.je.tree.LN
 
createLogEntry(LogEntryType, DatabaseImpl, byte[], long, boolean, Txn, ReplicationContext) - Method in class com.sleepycat.je.tree.NameLN
 
createLogger() - Method in class com.sleepycat.je.utilint.DaemonThread
 
createLogOverwriteException(String) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; only the overridden method should ever be called.
createLogOverwriteException(String) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
createManagedConnection(Subject, ConnectionRequestInfo) - Method in class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
createNewInstance(byte[], int, int) - Method in class com.sleepycat.je.tree.BIN
Create a new BIN.
createNewInstance(byte[], int, int) - Method in class com.sleepycat.je.tree.IN
Create a new IN.
createPreparedTxn(EnvironmentImpl, TransactionConfig, long) - Static method in class com.sleepycat.je.txn.PreparedTxn
 
createReadCommittedLocker(EnvironmentImpl, Locker) - Static method in class com.sleepycat.je.txn.ReadCommittedLocker
 
createReference() - Method in class com.sleepycat.je.tree.BIN
Create a holder object that encapsulates information about this BIN for the INCompressor.
createReplayTxn(long) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; only the overridden method should ever be called.
createReplayTxn(long) - Method in class com.sleepycat.je.rep.impl.RepImpl
Create a ReplayTxn for recovery processing.
createReplicaDb(Locker, String, DatabaseConfig, NameLN, ReplicationContext) - Method in class com.sleepycat.je.dbi.DbTree
Create a replicated database on this client node.
createRepThreadLocker() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; only the overridden method should ever be called.
createRepThreadLocker() - Method in class com.sleepycat.je.rep.impl.RepImpl
Create an appropriate type of ThreadLocker.
createRepTxn(TransactionConfig, long) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; only the overridden method should ever be called.
createRepUserTxn(TransactionConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; only the overridden method should ever be called.
createRepUserTxn(TransactionConfig) - Method in class com.sleepycat.je.rep.impl.RepImpl
Create an appropriate type of Replicated transaction.
createSecondaryKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.bind.serial.SerialSerialKeyCreator
 
createSecondaryKey(PK, D) - Method in class com.sleepycat.bind.serial.SerialSerialKeyCreator
Creates the index key object from primary key and data objects.
createSecondaryKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.bind.serial.TupleSerialKeyCreator
 
createSecondaryKey(TupleInput, D, TupleOutput) - Method in class com.sleepycat.bind.serial.TupleSerialKeyCreator
Creates the index key entry from primary key tuple entry and deserialized data entry.
createSecondaryKey(TupleInput, D, TupleOutput) - Method in class com.sleepycat.bind.serial.TupleSerialMarshalledKeyCreator
 
createSecondaryKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleTupleKeyCreator
 
createSecondaryKey(TupleInput, TupleInput, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleTupleKeyCreator
Creates the index key from primary key tuple and data tuple.
createSecondaryKey(TupleInput, TupleInput, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleTupleMarshalledKeyCreator
 
createSecondaryKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.je.SecondaryKeyCreator
Creates a secondary key entry, given a primary key and data entry.
createSecondaryKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistKeyCreator
 
createSecondaryKeys(SecondaryDatabase, DatabaseEntry, DatabaseEntry, Set<DatabaseEntry>) - Method in interface com.sleepycat.je.SecondaryMultiKeyCreator
Creates a secondary key entry, given a primary key and data entry.
createSecondaryKeys(SecondaryDatabase, DatabaseEntry, DatabaseEntry, Set) - Method in class com.sleepycat.persist.impl.PersistKeyCreator
 
createThreadLocker(EnvironmentImpl) - Static method in class com.sleepycat.je.txn.ThreadLocker
 
createUpdatedLN(EnvironmentImpl, byte[]) - Method in enum com.sleepycat.je.dbi.DbType
Creates an updated LN for use in an optimization in CursorImpl.putCurrentAlreadyLatchedAndLocked.
createUserTxn(EnvironmentImpl, TransactionConfig) - Static method in class com.sleepycat.je.txn.Txn
 
criticalEviction() - Method in class com.sleepycat.je.dbi.CursorImpl
 
criticalEviction(boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Performs critical eviction if necessary.
current() - Method in class com.sleepycat.persist.BasicCursor
 
current(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
current() - Method in interface com.sleepycat.persist.EntityCursor
Returns the value at the cursor position, or null if the value at the cursor position has been deleted.
current(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Returns the value at the cursor position, or null if the value at the cursor position has been deleted.
CURRENT_VERSION - Static variable in class com.sleepycat.je.JEVersion
Release version.
CURRENT_VERSION - Static variable in interface com.sleepycat.persist.impl.Catalog
 
currentClass - Variable in class com.sleepycat.je.jmx.JEMBean
 
currentEntryHeader - Variable in class com.sleepycat.je.log.FileReader
 
currentEntryOffset - Variable in class com.sleepycat.je.log.FileReader
 
currentEntryPrevOffset - Variable in class com.sleepycat.je.log.FileReader
 
currentEvent - Static variable in class com.sleepycat.je.utilint.EventTrace
 
currentFeedRecord - Variable in class com.sleepycat.je.rep.stream.VLSNReader
 
currentFileNum() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
currentTimeMillis() - Method in class com.sleepycat.je.rep.impl.node.RepNode.Clock
 
CurrentTransaction - Class in com.sleepycat.collections
Provides access to the current transaction for the current thread within the context of a Berkeley DB environment.
CurrentTransaction.CdbCursors - Class in com.sleepycat.collections
 
CurrentTransaction.CdbCursors() - Constructor for class com.sleepycat.collections.CurrentTransaction.CdbCursors
 
currentTxn - Variable in class com.sleepycat.collections.DataView
 
currentTxnEndVLSN(VLSN) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Notes the VLSN associated with the latest commit or abort.
currentVLSN - Variable in class com.sleepycat.je.rep.stream.VLSNReader
 
Cursor - Class in com.sleepycat.je
A database cursor.
Cursor(Database, Transaction, CursorConfig) - Constructor for class com.sleepycat.je.Cursor
Creates a cursor for a given user transaction with retainNonTxnLocks=false.
Cursor(Database, Locker, CursorConfig) - Constructor for class com.sleepycat.je.Cursor
Creates a cursor for a given locker with retainNonTxnLocks=false.
Cursor(Database, Locker, CursorConfig, boolean) - Constructor for class com.sleepycat.je.Cursor
Creates a cursor for a given locker and retainNonTxnLocks parameter.
Cursor(DatabaseImpl, Locker, CursorConfig, boolean) - Constructor for class com.sleepycat.je.Cursor
Creates a cursor for internal use, without a Database handle.
Cursor(Cursor, boolean) - Constructor for class com.sleepycat.je.Cursor
Copy constructor.
cursor - Variable in class com.sleepycat.persist.BasicCursor
 
cursorConfig - Variable in class com.sleepycat.collections.DataView
 
CursorConfig - Class in com.sleepycat.je
Specifies the attributes of database cursor.
CursorConfig() - Constructor for class com.sleepycat.je.CursorConfig
An instance created using the default constructor is initialized with the system's default settings.
CursorConfigBeanInfo - Class in com.sleepycat.je
 
CursorConfigBeanInfo() - Constructor for class com.sleepycat.je.CursorConfigBeanInfo
 
cursorImpl - Variable in class com.sleepycat.je.Cursor
The underlying cursor.
CursorImpl - Class in com.sleepycat.je.dbi
A CursorImpl is the internal implementation of the cursor.
CursorImpl(DatabaseImpl, Locker) - Constructor for class com.sleepycat.je.dbi.CursorImpl
Creates a cursor with retainNonTxnLocks=true.
CursorImpl(DatabaseImpl, Locker, boolean) - Constructor for class com.sleepycat.je.dbi.CursorImpl
Creates a cursor.
CursorImpl.LockStanding - Class in com.sleepycat.je.dbi
Holds the result of a lockLN operation.
CursorImpl.LockStanding() - Constructor for class com.sleepycat.je.dbi.CursorImpl.LockStanding
 
CursorImpl.SearchMode - Enum in com.sleepycat.je.dbi
 
CursorImpl.WithCursor - Interface in com.sleepycat.je.dbi
Callback object for traverseDbWithCursor.
CURSORS_EXIST - Static variable in exception com.sleepycat.je.tree.CursorsExistException
 
CursorsExistException - Exception in com.sleepycat.je.tree
Error to indicate that a bottom level BIN has cursors on it during a delete subtree operation.
CursorsExistException() - Constructor for exception com.sleepycat.je.tree.CursorsExistException
 
cv - Variable in class com.sleepycat.asm.ClassVisitor
The class visitor to which this visitor must delegate method calls.
cw - Variable in class com.sleepycat.asm.MethodWriter
The class writer to which this method must be added.

D

D2F - Static variable in interface com.sleepycat.asm.Opcodes
 
D2I - Static variable in interface com.sleepycat.asm.Opcodes
 
D2L - Static variable in interface com.sleepycat.asm.Opcodes
 
DADD - Static variable in interface com.sleepycat.asm.Opcodes
 
daemonEviction(boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Do eviction if the memory budget is over.
DaemonRunner - Interface in com.sleepycat.je.utilint
An object capable of running (run/pause/shutdown/etc) a daemon thread.
DaemonThread - Class in com.sleepycat.je.utilint
A daemon thread.
DaemonThread(long, String, EnvironmentImpl) - Constructor for class com.sleepycat.je.utilint.DaemonThread
 
DALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
DASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
data - Variable in class com.sleepycat.asm.ByteVector
The content of this vector.
data - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
data - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
data - Variable in class com.sleepycat.persist.BasicCursor
 
Database - Class in com.sleepycat.je
A database handle.
Database(Environment) - Constructor for class com.sleepycat.je.Database
Creates a database but does not open or fully initialize it.
Database.DbState - Enum in com.sleepycat.je
 
DATABASE_COUNT - Static variable in class com.sleepycat.compat.DbCompat
 
DATABASE_END - Static variable in class com.sleepycat.je.rep.util.ldiff.DiffRecordAnalyzer
 
DatabaseComparator - Interface in com.sleepycat.je
Implemented by btree and duplicate comparators that need to be initialized before they are used or need access to the environment's ClassLoader property.
DatabaseConfig - Class in com.sleepycat.je
Specifies the attributes of a database.
DatabaseConfig() - Constructor for class com.sleepycat.je.DatabaseConfig
An instance created using the default constructor is initialized with the system's default settings.
DatabaseConfigBeanInfo - Class in com.sleepycat.je
 
DatabaseConfigBeanInfo() - Constructor for class com.sleepycat.je.DatabaseConfigBeanInfo
 
DatabaseEntry - Class in com.sleepycat.je
Encodes database key and data items as a byte array.
DatabaseEntry() - Constructor for class com.sleepycat.je.DatabaseEntry
Constructs a DatabaseEntry with null data.
DatabaseEntry(byte[]) - Constructor for class com.sleepycat.je.DatabaseEntry
Constructs a DatabaseEntry with a given byte array.
DatabaseEntry(byte[], int, int) - Constructor for class com.sleepycat.je.DatabaseEntry
Constructs a DatabaseEntry with a given byte array, offset and size.
DatabaseException - Exception in com.sleepycat.je
The root of all BDB JE-defined exceptions.
DatabaseException(Throwable) - Constructor for exception com.sleepycat.je.DatabaseException
For internal use only.
DatabaseException(String) - Constructor for exception com.sleepycat.je.DatabaseException
For internal use only.
DatabaseException(String, Throwable) - Constructor for exception com.sleepycat.je.DatabaseException
For internal use only.
databaseExists(Environment, String, String) - Static method in class com.sleepycat.compat.DbCompat
 
DatabaseExistsException - Exception in com.sleepycat.je
Thrown by Environment.openDatabase and Environment.openSecondaryDatabase if the database already exists and the DatabaseConfig ExclusiveCreate parameter is true.
DatabaseExistsException(String) - Constructor for exception com.sleepycat.je.DatabaseExistsException
For internal use only.
DatabaseId - Class in com.sleepycat.je.dbi
DatabaseImpl Ids are wrapped in a class so they can be logged.
DatabaseId(long) - Constructor for class com.sleepycat.je.dbi.DatabaseId
 
DatabaseId() - Constructor for class com.sleepycat.je.dbi.DatabaseId
Uninitialized database id, for logging.
DatabaseImpl - Class in com.sleepycat.je.dbi
The underlying object for a given database.
DatabaseImpl(Locker, String, DatabaseId, EnvironmentImpl, DatabaseConfig) - Constructor for class com.sleepycat.je.dbi.DatabaseImpl
Create a database object for a new database.
DatabaseImpl() - Constructor for class com.sleepycat.je.dbi.DatabaseImpl
Create an empty database object for initialization from the log.
databaseImpl - Variable in class com.sleepycat.je.tree.IN
 
DatabaseImpl.ComparatorReader - Class in com.sleepycat.je.dbi
Utility class for converting bytes to compartor or Class.
DatabaseImpl.ComparatorReader(byte[], String, ClassLoader) - Constructor for class com.sleepycat.je.dbi.DatabaseImpl.ComparatorReader
 
DatabaseImpl.StatsAccumulator - Class in com.sleepycat.je.dbi
 
DatabaseImpl.StatsAccumulator(PrintStream, int) - Constructor for class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
databaseKeyToDatabaseImpl(Object) - Method in class com.sleepycat.je.cleaner.BaseLocalUtilizationTracker
Returns the DatabaseImpl from the database key, which is either the DatabaseId or DatabaseImpl.
databaseKeyToDatabaseImpl(Object) - Method in class com.sleepycat.je.cleaner.LocalUtilizationTracker
Returns the DatabaseImpl from the database key, which in this case is the DatabaseImpl.
databaseKeyToDatabaseImpl(Object) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Returns the DatabaseImpl from the database key, which in this case is the DatabaseId.
DatabaseNamer - Interface in com.sleepycat.persist
 
DatabaseNotFoundException - Exception in com.sleepycat.je
Thrown when an operation requires a database and that database does not exist.
DatabaseNotFoundException(String) - Constructor for exception com.sleepycat.je.DatabaseNotFoundException
For internal use only.
DatabasePreemptedException - Exception in com.sleepycat.je.rep
Thrown when attempting to use a Database handle that was forcibly closed by replication.
DatabasePreemptedException(String, String, Database) - Constructor for exception com.sleepycat.je.rep.DatabasePreemptedException
For internal use only.
DatabaseStats - Class in com.sleepycat.je
Statistics for a single database.
DatabaseStats() - Constructor for class com.sleepycat.je.DatabaseStats
 
DatabaseTrigger - Interface in com.sleepycat.je
Implemented to receive database update notifications.
databaseUpdated(Database, Locker, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.je.DatabaseTrigger
Notifies the trigger that a put or delete operation has been performed on the database.
databaseUpdated(Database, Locker, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.ForeignKeyTrigger
 
databaseUpdated(Database, Locker, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryTrigger
 
DatabaseUtil - Class in com.sleepycat.je.utilint
Utils for use in the db package.
DatabaseUtil() - Constructor for class com.sleepycat.je.utilint.DatabaseUtil
 
dataBinding - Variable in class com.sleepycat.bind.serial.SerialSerialKeyCreator
 
dataBinding - Variable in class com.sleepycat.bind.serial.TupleSerialBinding
 
dataBinding - Variable in class com.sleepycat.bind.serial.TupleSerialKeyCreator
 
DataCursor - Class in com.sleepycat.collections
Represents a Berkeley DB cursor and adds support for indices, bindings and key ranges.
DataCursor(DataView, boolean) - Constructor for class com.sleepycat.collections.DataCursor
Creates a cursor for a given view.
DataCursor(DataView, boolean, CursorConfig) - Constructor for class com.sleepycat.collections.DataCursor
Creates a cursor for a given view.
DataCursor(DataView, boolean, Object) - Constructor for class com.sleepycat.collections.DataCursor
Creates a cursor for a given view and single key range.
DataCursor(DataView, boolean, Object, boolean, Object, boolean) - Constructor for class com.sleepycat.collections.DataCursor
Creates a cursor for a given view and key range.
DataCursor(DataView, DataCursor[], JoinConfig, boolean) - Constructor for class com.sleepycat.collections.DataCursor
Creates a join cursor.
DataValueAdapter<V> - Class in com.sleepycat.persist
A ValueAdapter where the "value" is the data, although the data in this case is the primary key in a KeysIndex.
DataValueAdapter(Class<V>, EntryBinding) - Constructor for class com.sleepycat.persist.DataValueAdapter
 
DataView - Class in com.sleepycat.collections
Represents a Berkeley DB database and adds support for indices, bindings and key ranges.
DataView(Database, EntryBinding, EntryBinding, EntityBinding, boolean, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.DataView
Creates a view for a given database and bindings.
db - Variable in class com.sleepycat.collections.DataView
 
db - Variable in class com.sleepycat.je.txn.UndoReader
 
db - Variable in class com.sleepycat.persist.BasicIndex
 
DB_BLOCKS - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
DB_ID - Static variable in class com.sleepycat.je.rep.impl.RepGroupDB
 
DB_MISMATCH - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
DbBackup - Class in com.sleepycat.je.util
DbBackup is a helper class for stopping and restarting JE background activity in an open environment in order to simplify backup operations.
DbBackup(Environment) - Constructor for class com.sleepycat.je.util.DbBackup
Creates a DbBackup helper for a full backup.
DbBackup(Environment, long) - Constructor for class com.sleepycat.je.util.DbBackup
Creates a DbBackup helper for an incremental backup.
DbBackup(EnvironmentImpl) - Constructor for class com.sleepycat.je.util.DbBackup
 
DbCache - Class in com.sleepycat.je.rep.impl.node
Cache used to maintain DatabaseImpl handles.
DbCache(DbTree, int, int) - Constructor for class com.sleepycat.je.rep.impl.node.DbCache
Creates an instance of a DbCache.
dbCacheClearCount - Variable in class com.sleepycat.je.cleaner.Cleaner
 
dbCacheClearCount - Variable in class com.sleepycat.je.evictor.Evictor
 
DbCacheSize - Class in com.sleepycat.je.util
Estimates the in-memory cache size needed to hold a specified data set.
DbCacheSize() - Constructor for class com.sleepycat.je.util.DbCacheSize
 
DbCacheSizeRepEnv - Class in com.sleepycat.je.rep.utilint
Class for opening a ReplicatedEnvironment from a JE standalone utility, DbCacheSize.
DbCacheSizeRepEnv() - Constructor for class com.sleepycat.je.rep.utilint.DbCacheSizeRepEnv
 
DbCacheSizeRepEnv - Interface in com.sleepycat.je.utilint
Interface for opening a ReplicatedEnvironment from a JE standalone utility, DbCacheSize.
DbCompat - Class in com.sleepycat.compat
A minimal set of BDB DB-JE compatibility constants and static methods, for internal use only.
DbCompat() - Constructor for class com.sleepycat.compat.DbCompat
 
DbConfigManager - Class in com.sleepycat.je.dbi
DbConfigManager holds the configuration parameters for an environment.
DbConfigManager(EnvironmentConfig) - Constructor for class com.sleepycat.je.dbi.DbConfigManager
 
DbDump - Class in com.sleepycat.je.util
Dump the contents of a database.
DbDump(Environment, String, PrintStream, String, boolean) - Constructor for class com.sleepycat.je.util.DbDump
Deprecated.
Please use the 4-arg ctor without outputDirectory instead.
DbDump(Environment, String, PrintStream, boolean) - Constructor for class com.sleepycat.je.util.DbDump
Create a DbDump object for a specific environment and database.
DbDumpGroup - Class in com.sleepycat.je.rep.utilint
 
DbEnableReplication - Class in com.sleepycat.je.rep.util
A utility to convert an existing, non replicated JE environment for replication.
DbEnableReplication(File, String, String, String) - Constructor for class com.sleepycat.je.rep.util.DbEnableReplication
Create a DbEnableReplication object for this node.
DbEnvPool - Class in com.sleepycat.je.dbi
Singleton collection of environments.
DbEnvState - Class in com.sleepycat.je.dbi
DbEnvState implements a typesafe enumeration of environment states and does state change validation.
DbEnvState(String) - Constructor for class com.sleepycat.je.dbi.DbEnvState
 
DbFeederPrintLog - Class in com.sleepycat.je.rep.utilint
 
DbFeederPrintLog() - Constructor for class com.sleepycat.je.rep.utilint.DbFeederPrintLog
 
DbFileSummary - Class in com.sleepycat.je.cleaner
Per-DB-per-file utilization counters.
DbFileSummary() - Constructor for class com.sleepycat.je.cleaner.DbFileSummary
Creates an empty summary.
DBFILESUMMARY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DbFileSummaryMap - Class in com.sleepycat.je.cleaner
 
DbFileSummaryMap(boolean) - Constructor for class com.sleepycat.je.cleaner.DbFileSummaryMap
Creates a map of Long file number to DbFileSummary.
DbGroupAdmin - Class in com.sleepycat.je.rep.util
DbGroupAdmin supplies the functionality of the administrative class ReplicationGroupAdmin in a convenient command line utility.
DbGroupAdmin(String, Set<InetSocketAddress>) - Constructor for class com.sleepycat.je.rep.util.DbGroupAdmin
Create a DbGroupAdmin instance for programmatic use.
DbGroupAdmin.Command - Enum in com.sleepycat.je.rep.util
 
dbId - Variable in class com.sleepycat.je.recovery.Checkpointer.CheckpointReference
 
dbImpls - Variable in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
DBIN - Class in com.sleepycat.je.tree.dupConvert
A DBIN represents an Duplicate Bottom Internal Node in the JE tree.
DBIN() - Constructor for class com.sleepycat.je.tree.dupConvert.DBIN
 
DBIN(SizeofMarker) - Constructor for class com.sleepycat.je.tree.dupConvert.DBIN
For Sizeof, set all array fields to null, since they are not part of the fixed overhead.
DBIN_FIXED_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DbInternal - Class in com.sleepycat.je
 
DbInternal() - Constructor for class com.sleepycat.je.DbInternal
 
DbiStatDefinition - Class in com.sleepycat.je.dbi
Per-stat Metadata for JE EnvironmentImpl and MemoryBudget statistics.
DbiStatDefinition() - Constructor for class com.sleepycat.je.dbi.DbiStatDefinition
 
DbLoad - Class in com.sleepycat.je.util
Loads a database from a dump file generated by DbDump.
DbLoad() - Constructor for class com.sleepycat.je.util.DbLoad
Creates a DbLoad object.
DbLsn - Class in com.sleepycat.je.utilint
DbLsn is a class that operates on Log Sequence Numbers (LSNs).
DBMAP_LEVEL - Static variable in class com.sleepycat.je.tree.IN
 
dbMapTree - Variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
dbName - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.DbBlocks
 
dbName - Variable in class com.sleepycat.je.util.DbDump
 
dbName - Variable in class com.sleepycat.je.util.DbVerify
 
DbNullNode - Class in com.sleepycat.je.rep.utilint
 
DbNullNode() - Constructor for class com.sleepycat.je.rep.utilint.DbNullNode
 
DbOperationType - Enum in com.sleepycat.je.log.entry
DbOperationType is a persistent enum used in NameLNLogEntries.
DbOpReplicationContext - Class in com.sleepycat.je.log
This subclass of ReplicationContext adds information specific to database operations to the replication context passed from operation-aware code down the the logging layer.
DbOpReplicationContext(boolean, DbOperationType) - Constructor for class com.sleepycat.je.log.DbOpReplicationContext
Create a replication context for logging a database operation NameLN on the master.
DbOpReplicationContext(VLSN, NameLNLogEntry) - Constructor for class com.sleepycat.je.log.DbOpReplicationContext
Create a repContext for executing a databaseOperation on the client.
DbPing - Class in com.sleepycat.je.rep.util
This class provides the utility to request the current state of a replica in a JE replication group, see more details in NodeState.
DbPing(ReplicationNode, String, int) - Constructor for class com.sleepycat.je.rep.util.DbPing
Create a DbPing instance for programmatic use.
DbPrintLog - Class in com.sleepycat.je.util
Dumps the contents of the log in XML format to System.out.
DbPrintLog() - Constructor for class com.sleepycat.je.util.DbPrintLog
 
dbRemove(Locker, String, DatabaseId) - Method in class com.sleepycat.je.dbi.DbTree
Stand alone and Master invocations.
dbRename(Locker, String, String) - Method in class com.sleepycat.je.dbi.DbTree
Stand alone and Master invocations.
DbRepRunAction - Class in com.sleepycat.je.rep.utilint
 
DbRepRunAction() - Constructor for class com.sleepycat.je.rep.utilint.DbRepRunAction
 
DbResetRepGroup - Class in com.sleepycat.je.rep.util
A utility to reset the members of a replication group, replacing the group with a new group consisting of a single new member as described by the arguments supplied to the utility.
DbResetRepGroup(File, String, String, String) - Constructor for class com.sleepycat.je.rep.util.DbResetRepGroup
Create a DbResetRepGroup object for this node.
DbRunAction - Class in com.sleepycat.je.util
 
DbRunAction() - Constructor for class com.sleepycat.je.util.DbRunAction
 
DbScavenger - Class in com.sleepycat.je.util
Used to retrieve as much data as possible from a corrupted environment.
DbScavenger(Environment, String, boolean, boolean, boolean) - Constructor for class com.sleepycat.je.util.DbScavenger
Create a DbScavenger object for a specific environment.
DbSpace - Class in com.sleepycat.je.util
DbSpace displays the disk space utilization for an environment.
DbSpace(Environment, boolean, boolean, boolean) - Constructor for class com.sleepycat.je.util.DbSpace
 
DbSpace(EnvironmentImpl, boolean, boolean, boolean) - Constructor for class com.sleepycat.je.util.DbSpace
 
DbStat - Class in com.sleepycat.je.util
 
DbStat() - Constructor for class com.sleepycat.je.util.DbStat
 
DbStat(Environment, String) - Constructor for class com.sleepycat.je.util.DbStat
 
DbStreamVerify - Class in com.sleepycat.je.rep.utilint
For internal use only.
DbSync - Class in com.sleepycat.je.rep.utilint
DbSync is a utility for ensuring that a group of replication nodes have fully caught up on the replication stream.
DbSync(String, EnvironmentConfig, ReplicationConfig, String, long) - Constructor for class com.sleepycat.je.rep.utilint.DbSync
Create a DbSync object for the purposed of syncing up a specific replication group.
DBSYNC_ENV - Static variable in class com.sleepycat.je.rep.utilint.DbSync
 
DBSYNC_GROUP_NAME - Static variable in class com.sleepycat.je.rep.utilint.DbSync
 
DBSYNC_HELPER_HOST - Static variable in class com.sleepycat.je.rep.utilint.DbSync
 
DBSYNC_NODE_HOST - Static variable in class com.sleepycat.je.rep.utilint.DbSync
 
DBSYNC_NODE_NAME - Static variable in class com.sleepycat.je.rep.utilint.DbSync
 
DBSYNC_TIMEOUT - Static variable in class com.sleepycat.je.rep.utilint.DbSync
 
DbTree - Class in com.sleepycat.je.dbi
DbTree represents the database directory for this environment.
DbTree() - Constructor for class com.sleepycat.je.dbi.DbTree
Create a dbTree from the log.
DbTree(EnvironmentImpl, boolean, boolean) - Constructor for class com.sleepycat.je.dbi.DbTree
Create a new dbTree for a new environment.
DbTree.GetRepContext - Interface in com.sleepycat.je.dbi
Used by lockNameLN to get the rep context, which is needed for calling checkReplicaWrite.
DbTree.TruncateDbResult - Class in com.sleepycat.je.dbi
 
DbTree.TruncateDbResult(DatabaseImpl, DatabaseImpl, long) - Constructor for class com.sleepycat.je.dbi.DbTree.TruncateDbResult
 
DBTREE_CACHE_CLEAR_COUNT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
DbTruncateLog - Class in com.sleepycat.je.util
DbTruncateLog is a utility that lets the user truncate JE log starting at a specified file and offset to the last log file, inclusive.
DbTruncateLog() - Constructor for class com.sleepycat.je.util.DbTruncateLog
 
DbType - Enum in com.sleepycat.je.dbi
Classifies all databases as specific internal databases or user databases.
DbVerify - Class in com.sleepycat.je.util
Verifies the internal structures of a database.
DbVerify() - Constructor for class com.sleepycat.je.util.DbVerify
 
DbVerify(Environment, String, boolean) - Constructor for class com.sleepycat.je.util.DbVerify
Creates a DbVerify object for a specific environment and database.
DbVerifyLog - Class in com.sleepycat.je.util
Verifies the checksums in one or more log files.
DbVerifyLog(Environment) - Constructor for class com.sleepycat.je.util.DbVerifyLog
Creates a utility object for verifying the checksums in log files.
DbVerifyLog(Environment, int) - Constructor for class com.sleepycat.je.util.DbVerifyLog
Creates a utility object for verifying log files.
DCMPG - Static variable in interface com.sleepycat.asm.Opcodes
 
DCMPL - Static variable in interface com.sleepycat.asm.Opcodes
 
DCONST_0 - Static variable in interface com.sleepycat.asm.Opcodes
 
DCONST_1 - Static variable in interface com.sleepycat.asm.Opcodes
 
DDIV - Static variable in interface com.sleepycat.asm.Opcodes
 
DeadlockException - Exception in com.sleepycat.je
Deprecated.
temporarily until true deadlock detection is implemented. Presently, {code DeadlockException} is replaced by LockConflictException as the common base class for lock conflict exceptions.
DeadlockException(String) - Constructor for exception com.sleepycat.je.DeadlockException
Deprecated.
For internal use only.
DeadlockException(Locker, String) - Constructor for exception com.sleepycat.je.DeadlockException
Deprecated.
For internal use only.
DeadlockException(String, DeadlockException) - Constructor for exception com.sleepycat.je.DeadlockException
Deprecated.
For internal use only.
DEBUG - Static variable in class com.sleepycat.asm.Label
Indicates if this label is only used for debug attributes.
DEBUG_ADMIN - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DEBUG_LOCK - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DEBUG_PRINT_THREAD - Static variable in class com.sleepycat.je.rep.utilint.RepUtils
 
DEBUG_PRINT_TIME - Static variable in class com.sleepycat.je.rep.utilint.RepUtils
 
DEBUG_TREE - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DEBUG_TREEADMIN - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DEBUG_TXN - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
decBackupCount() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
decOpenCount() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns true if the environment should be closed.
decrement() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
decrement() - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
decrementFreezeCounter() - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNTracker
 
decrementUseCount() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Decrements the use count of this DB, allowing it to be evicted if the use count reaches zero.
decrementVLSN() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
decrementVLSN() - Method in class com.sleepycat.je.rep.impl.RepImpl
If the log entry wasn't successfully logged, decrement the VLSN to reclaim the slot.
decThreadLocalReferenceCount() - Static method in class com.sleepycat.je.dbi.EnvironmentImpl
 
DEFAULT - Static variable in class com.sleepycat.je.CheckpointConfig
Default configuration used if null is passed to Environment.checkpoint.
DEFAULT - Static variable in class com.sleepycat.je.CursorConfig
Default configuration used if null is passed to methods that create a cursor.
DEFAULT - Static variable in class com.sleepycat.je.DatabaseConfig
An instance created using the default constructor is initialized with the system's default settings.
DEFAULT - Static variable in class com.sleepycat.je.DiskOrderedCursorConfig
Default configuration used if null is passed to methods that create a cursor.
DEFAULT - Static variable in class com.sleepycat.je.EnvironmentConfig
 
DEFAULT - Static variable in class com.sleepycat.je.JoinConfig
Default configuration used if null is passed to Database.join.
DEFAULT - Static variable in class com.sleepycat.je.rep.monitor.MonitorConfig
An instance created using the default constructor is initialized with the default settings.
DEFAULT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
 
DEFAULT - Static variable in class com.sleepycat.je.SecondaryConfig
 
DEFAULT - Static variable in class com.sleepycat.je.SequenceConfig
Default configuration used if null is passed to methods that create a cursor.
DEFAULT - Static variable in class com.sleepycat.je.StatsConfig
A convenience instance embodying the default configuration.
DEFAULT - Static variable in class com.sleepycat.je.sync.ExportConfig
 
DEFAULT - Static variable in class com.sleepycat.je.sync.ImportConfig
 
DEFAULT - Static variable in class com.sleepycat.je.TransactionConfig
Default configuration used if null is passed to methods that create a transaction.
DEFAULT - Static variable in class com.sleepycat.je.VerifyConfig
 
DEFAULT - Static variable in interface com.sleepycat.persist.DatabaseNamer
The default database namer.
DEFAULT - Static variable in class com.sleepycat.persist.StoreConfig
The default store configuration containing properties as if the configuration were constructed and not modified.
DEFAULT_BUMP_SIZE - Static variable in class com.sleepycat.util.FastOutputStream
The default amount that the buffer is increased when it is full.
DEFAULT_INIT_SIZE - Static variable in class com.sleepycat.util.FastOutputStream
The default initial size of the buffer if no initialSize parameter is specified.
DEFAULT_ITERATOR_BLOCK_SIZE - Static variable in class com.sleepycat.collections.StoredCollection
The default number of records read at one time by iterators.
DEFAULT_KEYVALS_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DEFAULT_MAX_KEY_LENGTH - Static variable in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
DEFAULT_MAX_RETRIES - Static variable in class com.sleepycat.collections.TransactionRunner
The default maximum number of retries.
DEFAULT_PORT - Static variable in class com.sleepycat.je.rep.impl.RepParams
The port used for replication.
DEFAULT_PORT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The default port used for replication.
DEFAULT_TARGET_ENTRY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DEFAULT_VLSN_CACHE_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
defaultNoWait - Variable in class com.sleepycat.je.txn.Locker
 
definition - Variable in class com.sleepycat.je.utilint.Stat
 
DEL_SUFFIX - Static variable in class com.sleepycat.je.log.FileManager
 
DEL_SUFFIXES - Static variable in class com.sleepycat.je.log.FileManager
 
delete() - Method in class com.sleepycat.collections.DataCursor
Perform an arbitrary database 'delete' operation.
delete() - Method in class com.sleepycat.je.Cursor
Deletes the key/data pair to which the cursor refers.
delete(Transaction, DatabaseEntry) - Method in class com.sleepycat.je.Database
Removes key/data pairs from the database.
delete(ReplicationContext) - Method in class com.sleepycat.je.dbi.CursorImpl
Delete the item pointed to by the cursor.
delete() - Method in class com.sleepycat.je.SecondaryCursor
Delete the key/data pair to which the cursor refers from the primary database and all secondary indices.
delete(Transaction, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryDatabase
Deletes the primary key/data pair associated with the specified secondary key.
delete(Transaction, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
delete() - Method in class com.sleepycat.je.tree.LN
 
delete(byte[], LocalUtilizationTracker) - Method in class com.sleepycat.je.tree.Tree
Deletes a BIN specified by key from the tree.
delete(Transaction, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.je.trigger.Trigger
The trigger method invoked after a successful delete, that is, one that actually resulted in a key/value pair being removed.
delete() - Method in class com.sleepycat.persist.BasicCursor
 
delete(K) - Method in class com.sleepycat.persist.BasicIndex
 
delete(Transaction, K) - Method in class com.sleepycat.persist.BasicIndex
 
delete() - Method in interface com.sleepycat.persist.EntityCursor
Deletes the entity at the cursor position.
delete(K) - Method in interface com.sleepycat.persist.EntityIndex
Deletes all entities with a given index key.
delete(Transaction, K) - Method in interface com.sleepycat.persist.EntityIndex
Deletes all entities with a given index key.
delete(PK) - Method in class com.sleepycat.persist.SubIndex
 
delete(Transaction, PK) - Method in class com.sleepycat.persist.SubIndex
 
delete() - Method in class com.sleepycat.util.keyrange.RangeCursor
 
DeleteAction - Enum in com.sleepycat.persist.model
Specifies the action to take when a related entity is deleted having a primary key value that exists as a secondary key value for this entity.
DeleteConstraintException - Exception in com.sleepycat.je
Thrown when an attempt is made to delete a key from a foreign key database, when that key is referenced by a secondary database, and the secondary is configured to cause an abort in this situation.
DeleteConstraintException(Locker, String, String, DatabaseEntry, DatabaseEntry) - Constructor for exception com.sleepycat.je.DeleteConstraintException
For internal use only.
DeletedClassException - Exception in com.sleepycat.persist.evolve
While reading from an index, an instance of a deleted class version was encountered.
DeletedClassException(String) - Constructor for exception com.sleepycat.persist.evolve.DeletedClassException
For internal use only.
deletedDatabases - Variable in class com.sleepycat.je.txn.Txn
 
DeletedDupLNLogEntry - Class in com.sleepycat.je.log.entry
DupDeletedLNEntry encapsulates a deleted dupe LN entry.
DeletedDupLNLogEntry() - Constructor for class com.sleepycat.je.log.entry.DeletedDupLNLogEntry
Constructor to read an entry.
deleteEntry(byte[], boolean) - Method in class com.sleepycat.je.tree.IN
Deletes the ChildReference with the key arg from this IN.
deleteEntry(int, boolean) - Method in class com.sleepycat.je.tree.IN
Deletes the ChildReference at index from this IN.
deleteFile(long) - Method in class com.sleepycat.je.log.FileManager
Delete log file NNNNNNNN.
deleteInfo - Variable in class com.sleepycat.je.txn.Locker
 
deleteInternal(ReplicationContext) - Method in class com.sleepycat.je.Cursor
Internal version of delete() that does no parameter checking.
deleteInternal(Locker, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Database
Internal version of delete() that does no parameter checking.
deleteInternal(Cursor, ReplicationContext) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.deleteInternal()
deleteMapLN(DatabaseId) - Method in class com.sleepycat.je.dbi.DbTree
 
deleteNoNotify(ReplicationContext) - Method in class com.sleepycat.je.Cursor
Delete at current position.
Deleter - Class in com.sleepycat.persist.evolve
A mutation for deleting an entity class or field.
Deleter(String, int) - Constructor for class com.sleepycat.persist.evolve.Deleter
Creates a mutation for deleting an entity class.
Deleter(String, int, String) - Constructor for class com.sleepycat.persist.evolve.Deleter
Creates a mutation for deleting the given field from all instances of the given class version.
deleteSafeToDeleteFiles() - Method in class com.sleepycat.je.cleaner.Cleaner
Deletes all files that are safe-to-delete and which are not protected by a DbBackup or replication.
deleteSecondaryDatabase(String, String) - Method in class com.sleepycat.persist.impl.Evolver
Called by ComplexFormat when a secondary key is dropped.
DELTAINENTRY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
DeltaInfo - Class in com.sleepycat.je.tree
DeltaInfo holds the delta for one BIN entry in a partial BIN log entry.
DeltaInfo(byte[], long, byte) - Constructor for class com.sleepycat.je.tree.DeltaInfo
 
DeltaInfo() - Constructor for class com.sleepycat.je.tree.DeltaInfo
For reading from the log only.
DELTAINFO_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
demote(long, Locker) - Method in class com.sleepycat.je.txn.DummyLockManager
 
demote(Locker) - Method in interface com.sleepycat.je.txn.Lock
Downgrade a write lock to a read lock.
demote(Locker) - Method in class com.sleepycat.je.txn.LockImpl
Downgrade a write lock to a read lock.
demote(long, Locker) - Method in class com.sleepycat.je.txn.LockManager
Demote a lock from write to read.
demote(long, Locker) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
demote(Locker) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
demoteInternal(long, Locker, int) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of demote.
demoteLock(long) - Method in class com.sleepycat.je.txn.Locker
Revert this lock from a write lock to a read lock.
desc - Variable in class com.sleepycat.asm.Handle
The descriptor of the field or method designated by this handle.
desc - Variable in class com.sleepycat.asm.Handler
Internal name of the type of exceptions handled by this handler, or null to catch any exceptions.
DESCRIPTION - Variable in class com.sleepycat.je.jmx.JEMBean
 
deserialize(ByteBuffer, BinaryProtocol) - Static method in class com.sleepycat.je.rep.impl.node.NameIdPair
Serializes from a ByteBuffer for a given protocol.
deserialize(TupleInput) - Static method in class com.sleepycat.je.rep.impl.node.NameIdPair
Serializes from a TupleInput after retrieving from storage.
deserializeHex(String[], int) - Static method in class com.sleepycat.je.rep.impl.RepGroupImpl
De-serializes an array of tokens into a Rep group object and its nodes.
deserializeNode(byte[]) - Static method in class com.sleepycat.je.rep.impl.RepGroupImpl
Deserialize the mode from its byte representation.
DESIGNATED_PRIMARY - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
DESIGNATED_PRIMARY - Static variable in class com.sleepycat.je.rep.ReplicationMutableConfig
Identifies the Primary node in a two node group.
destroy() - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
diff(Environment, Environment) - Method in class com.sleepycat.je.rep.util.ldiff.LDiff
A mechanism for efficiently comparing all databases in two quiescent environments.
diff(Database, Database) - Method in class com.sleepycat.je.rep.util.ldiff.LDiff
A mechanism for efficiently comparing two quiescent databases.
diff(Environment, InetSocketAddress) - Method in class com.sleepycat.je.rep.util.ldiff.LDiff
A mechanism for efficiently comparing two quiescent environments, one local and one on a remote machine.
diff(Database, InetSocketAddress) - Method in class com.sleepycat.je.rep.util.ldiff.LDiff
A mechanism for efficiently comparing two quiescent databases, one of which resides on a remote machine.
diff(Database, BlockBag) - Method in class com.sleepycat.je.rep.util.ldiff.LDiff
A mechanism for efficiently comparing two quiescent databases, typically residing on different machines connected by a network.
DIFF_AREA_END - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
DIFF_AREA_START - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
DiffRecordAnalyzer - Class in com.sleepycat.je.rep.util.ldiff
 
DiffRecordAnalyzer() - Constructor for class com.sleepycat.je.rep.util.ldiff.DiffRecordAnalyzer
 
diffSize - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
DiffTracker - Class in com.sleepycat.je.rep.util.ldiff
 
DiffTracker(long) - Constructor for class com.sleepycat.je.rep.util.ldiff.DiffTracker
 
DIM - Static variable in class com.sleepycat.asm.Frame
Mask to get the dimension of a frame type.
DIN - Class in com.sleepycat.je.tree.dupConvert
An DIN represents an Duplicate Internal Node in the JE tree.
DIN() - Constructor for class com.sleepycat.je.tree.dupConvert.DIN
Create an empty DIN, with no node ID, to be filled in from the log.
DIN(SizeofMarker) - Constructor for class com.sleepycat.je.tree.dupConvert.DIN
For Sizeof, set all array fields to null, since they are not part of the fixed overhead.
DIN_FIXED_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
dirty - Variable in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
DirtyINMap - Class in com.sleepycat.je.recovery
Manages the by-level map of checkpoint references that are to be flushed by a checkpoint or Database.sync, the MapLNs to be flushed, the highest level by database to be flushed, and the state of the checkpoint.
DirtyINMap(EnvironmentImpl) - Constructor for class com.sleepycat.je.recovery.DirtyINMap
 
DirtyINMap.CkptState - Enum in com.sleepycat.je.recovery
 
disableEvents - Static variable in class com.sleepycat.je.utilint.EventTrace
 
disableLeaveGroupEvent() - Method in class com.sleepycat.je.rep.impl.node.MonitorEventManager
 
disableNotify(boolean) - Method in class com.sleepycat.je.rep.monitor.Monitor
 
disableParameterValidation(EnvironmentMutableConfig) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentMutableConfig.validateParams.
disableParameterValidation(ReplicationMutableConfig) - Static method in class com.sleepycat.je.rep.RepInternal
Proxy to ReplicationMutableConfig.validateParams.
disallowReplicaWrite() - Method in class com.sleepycat.je.rep.txn.ReadonlyTxn
Unconditionally throws ReplicaWriteException because this locker was created on a replica.
disallowReplicaWrite() - Method in class com.sleepycat.je.rep.txn.ReplicaThreadLocker
Unconditionally throws ReplicaWriteException because this locker was created on a replica.
disallowReplicaWrite() - Method in class com.sleepycat.je.txn.Locker
Throws ReplicaWriteException if called for a locker on a Replica.
discardChanges(Transaction) - Method in interface com.sleepycat.je.sync.ChangeReader.ChangeTxn
Called when the changes in this transaction have been transferred to the external system, and they can be discarded locally.
discardChanges(Transaction) - Method in interface com.sleepycat.je.sync.ChangeReader
Called when the changes in all transactions returned by the getChangeTxns iterator have been transferred to the external system, and they can be discarded locally.
discardChanges(Transaction) - Method in class com.sleepycat.je.sync.impl.LogChangeReader
 
discardChanges(Transaction) - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChangeTxn
 
discardFutures(List<Future<TextProtocol.MessageExchange>>) - Static method in class com.sleepycat.je.rep.elections.Utils
Discard futures computations, since we no longer care about their outcomes.
DiskOrderedCursor - Class in com.sleepycat.je
DiskOrderedCursor returns records in unsorted order in exchange for generally faster retrieval times.
DiskOrderedCursor(Database, DiskOrderedCursorConfig) - Constructor for class com.sleepycat.je.DiskOrderedCursor
 
DiskOrderedCursorConfig - Class in com.sleepycat.je
Specifies the attributes of a DiskOrderedCursor.
DiskOrderedCursorConfig() - Constructor for class com.sleepycat.je.DiskOrderedCursorConfig
An instance created using the default constructor is initialized with the system's default settings.
DiskOrderedCursorConfigBeanInfo - Class in com.sleepycat.je
 
DiskOrderedCursorConfigBeanInfo() - Constructor for class com.sleepycat.je.DiskOrderedCursorConfigBeanInfo
 
DiskOrderedCursorImpl - Class in com.sleepycat.je.dbi
This class implements the DiskOrderedCursor.
DiskOrderedCursorImpl(DatabaseImpl, DiskOrderedCursorConfig) - Constructor for class com.sleepycat.je.dbi.DiskOrderedCursorImpl
 
DiskOrderedCursorProducerException - Exception in com.sleepycat.je
Thrown by ForwardCursor.getNext when a DiskOrderedCursor producer thread throws an exception.
DiskOrderedCursorProducerException(String, Throwable) - Constructor for exception com.sleepycat.je.DiskOrderedCursorProducerException
For internal use only.
DISPLAY_COLUMNS - Static variable in class com.sleepycat.je.dbi.StartupTracker.Counter
 
displayStats(PrintStream, StartupTracker.Phase) - Method in class com.sleepycat.je.dbi.StartupTracker
Display all information that has been tracked for this family of phases.
dispose() - Method in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
DISPOSED_COUNT - Static variable in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackupStatDefinition
 
DLOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
DMUL - Static variable in interface com.sleepycat.asm.Opcodes
 
DNEG - Static variable in interface com.sleepycat.asm.Opcodes
 
DO_CRITICAL_EVICTION - Static variable in class com.sleepycat.je.cleaner.Cleaner
Whether the cleaner should participate in critical eviction.
DO_LEADER_FSYNC - Static variable in class com.sleepycat.je.log.FSyncManager.FSyncGroup
 
DO_TIMEOUT_FSYNC - Static variable in class com.sleepycat.je.log.FSyncManager.FSyncGroup
 
doAggressiveScavengerRun - Variable in class com.sleepycat.je.util.DbDump
 
doAnalysis(Database, Protocol, SocketChannel, DiffTracker, boolean) - Static method in class com.sleepycat.je.rep.util.ldiff.DiffRecordAnalyzer
 
doAnalysis(Database, Database, DiffTracker, boolean) - Static method in class com.sleepycat.je.rep.util.ldiff.DiffRecordAnalyzer
 
doCheckpoint(CheckpointConfig, String) - Method in class com.sleepycat.je.recovery.Checkpointer
The real work to do a checkpoint.
doClean(boolean, boolean) - Method in class com.sleepycat.je.cleaner.Cleaner
Cleans selected files and returns the number of files cleaned.
doClean(boolean, boolean, boolean) - Method in class com.sleepycat.je.cleaner.FileProcessor
Cleans selected files and returns the number of files cleaned.
doClose(boolean, boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Closes the environment, optionally performing a checkpoint and checking for resource leaks.
doCloseAfterInvalid() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
This method must be called while synchronized on DbEnvPool.
doCloseAfterInvalid() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
doCompress() - Method in class com.sleepycat.je.incomp.INCompressor
The real work to doing a compress.
doCriticalEviction(boolean) - Method in class com.sleepycat.je.evictor.Evictor
Do some eviction before proceeding on with another operation.
doDaemonEviction(boolean) - Method in class com.sleepycat.je.evictor.Evictor
Do a check on whether synchronous eviction is needed.
doEvict(Evictor.EvictionSource, boolean) - Method in class com.sleepycat.je.evictor.Evictor
Can execute concurrently, called by app threads or by background evictor
doEvictOneIN(IN, Evictor.EvictionSource) - Method in class com.sleepycat.je.evictor.Evictor
Evict a specific IN, used by cache modes.
doHook() - Method in interface com.sleepycat.je.rep.stream.ReplicaFeederSyncup.TestHook
 
doHook() - Method in interface com.sleepycat.je.utilint.TestHook
 
doHook(T) - Method in interface com.sleepycat.je.utilint.TestHook
 
doHook() - Method in class com.sleepycat.je.utilint.TestHookAdapter
 
doHook(T) - Method in class com.sleepycat.je.utilint.TestHookAdapter
 
doHookIfSet(TestHook<?>) - Static method in class com.sleepycat.je.utilint.TestHookExecute
 
doHookIfSet(TestHook<T>, T) - Static method in class com.sleepycat.je.utilint.TestHookExecute
 
doHookSetupIfSet(TestHook<?>) - Static method in class com.sleepycat.je.utilint.TestHookExecute
 
doInBackground() - Method in class com.sleepycat.je.jmx.plugin.StatsSwingWorker
 
doIOHook() - Method in interface com.sleepycat.je.utilint.TestHook
 
doIOHook() - Method in class com.sleepycat.je.utilint.TestHookAdapter
 
doManualEvict() - Method in class com.sleepycat.je.evictor.Evictor
 
done() - Method in class com.sleepycat.je.jmx.plugin.StatsSwingWorker
 
DONE - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
DONE - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
DONT_JOIN_REP_GROUP - Static variable in class com.sleepycat.je.rep.impl.RepParams
If true, the replica runs with this property will not join the replication group.
doRegister(Environment) - Method in interface com.sleepycat.je.dbi.EnvironmentImpl.MBeanRegistrar
 
doRegister(Environment) - Method in class com.sleepycat.je.jmx.JEMBean
For EnvironmentImpl.MBeanRegistrar interface.
doRegisterMBean(Environment) - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
doRegisterMBean(Environment) - Method in class com.sleepycat.je.jmx.JEMBean
 
doRegisterMBean(Environment) - Method in class com.sleepycat.je.jmx.JEMonitor
 
doRegisterMBean(Environment) - Method in class com.sleepycat.je.rep.jmx.RepJEDiagnostics
 
doRegisterMBean(Environment) - Method in class com.sleepycat.je.rep.jmx.RepJEMonitor
 
doRunReplicaLoopInternalWork() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
DOS_PRODUCER_QUEUE_TIMEOUT - Static variable in class com.sleepycat.je.config.EnvironmentParams
DiskOrderedScan
DOS_PRODUCER_QUEUE_TIMEOUT - Static variable in class com.sleepycat.je.EnvironmentConfig
The timeout for Disk Ordered Scan producer thread queue offers in milliseconds.
doScavengerRun - Variable in class com.sleepycat.je.util.DbDump
 
doServiceHandshake(SocketChannel, String) - Static method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
A variation on the method above.
doSetMutableConfig(EnvironmentMutableConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
This method must be called while synchronized on DbEnvPool.
doTruncateDb(Locker, String, boolean, NameLN, DbOpReplicationContext) - Method in class com.sleepycat.je.dbi.DbTree
To truncate, remove the database named by databaseName and create a new database in its place.
DOUBLE - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_Double constant pool items.
DOUBLE - Static variable in class com.sleepycat.asm.Frame
The DOUBLE type.
DOUBLE - Static variable in interface com.sleepycat.asm.Opcodes
 
DOUBLE - Static variable in class com.sleepycat.asm.Type
The sort of the double type.
DOUBLE_TYPE - Static variable in class com.sleepycat.asm.Type
The double type.
DoubleBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for an unsorted Double primitive wrapper or an unsorted double primitive.
DoubleBinding() - Constructor for class com.sleepycat.bind.tuple.DoubleBinding
 
doubleToEntry(double, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.DoubleBinding
Converts a simple double value into an entry buffer.
doubleToEntry(double, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedDoubleBinding
Converts a simple double value into an entry buffer.
doUnregister() - Method in interface com.sleepycat.je.dbi.EnvironmentImpl.MBeanRegistrar
 
doUnregister() - Method in class com.sleepycat.je.jmx.JEMBean
For EnvironmentImpl.MBeanRegistrar interface.
doUpdate(VLSN, String) - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNUpdater
 
doWork() - Method in interface com.sleepycat.collections.TransactionWorker
Perform the work for a single transaction.
doWork(ChildReference) - Method in interface com.sleepycat.je.tree.WithRootLatched
doWork is called while the tree's root latch is held.
DREM - Static variable in interface com.sleepycat.asm.Opcodes
 
DRETURN - Static variable in interface com.sleepycat.asm.Opcodes
 
DSTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
DSUB - Static variable in interface com.sleepycat.asm.Opcodes
 
DummyLockManager - Class in com.sleepycat.je.txn
DummyLockManager performs no locking for DS mode.
DummyLockManager(EnvironmentImpl, LockManager) - Constructor for class com.sleepycat.je.txn.DummyLockManager
 
dummyValue - Variable in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareBlockingQueue
 
dump(boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
Dump the cursor for debugging purposes.
dump() - Method in class com.sleepycat.je.dbi.CursorImpl
dump the cursor for debugging purposes.
dump() - Method in class com.sleepycat.je.dbi.DbTree
For debugging.
dump() - Method in class com.sleepycat.je.dbi.INList
 
dump() - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
Dump the contents.
dump(PrintStream) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
For debugging and tracing.
dump(int) - Method in class com.sleepycat.je.tree.Node
 
dump() - Method in class com.sleepycat.je.tree.Tree
 
dump() - Method in class com.sleepycat.je.txn.LockInfo
Debugging
dump() - Method in class com.sleepycat.je.txn.LockManager
Debugging
dump() - Method in class com.sleepycat.je.util.DbDump
Perform the dump.
dump(File, String, String, long, long, boolean, boolean, boolean, boolean, boolean, boolean, String) - Method in class com.sleepycat.je.util.DbPrintLog
Dump a JE log into human readable form.
dump() - Method in class com.sleepycat.je.util.DbScavenger
Start the scavenger run.
DUMP_TYPE - Static variable in class com.sleepycat.je.tree.Key
 
dumpBoolean(ByteBuffer, StringBuilder, String) - Static method in class com.sleepycat.je.log.LogUtils
 
dumpByteArray(byte[]) - Method in class com.sleepycat.je.tree.Key.DumpType
 
dumpByteArrayInternal(StringBuilder, byte[]) - Method in class com.sleepycat.je.tree.Key.DumpType
 
dumpCurrentHeader() - Method in class com.sleepycat.je.log.LNFileReader
 
dumpData() - Method in class com.sleepycat.je.DatabaseEntry
Dumps the data as a byte array, for tracing purposes
dumpDb(boolean) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
For debugging and unit tests
dumpDeletedState(StringBuilder, byte) - Static method in class com.sleepycat.je.tree.IN
Utility method for output of knownDeleted and pendingDelete.
dumpEntry(StringBuilder, boolean) - Method in class com.sleepycat.je.log.entry.BaseEntry
 
dumpEntry(StringBuilder, boolean) - Method in class com.sleepycat.je.log.entry.DeletedDupLNLogEntry
Extends super class to dump out extra key.
dumpEntry(StringBuilder, boolean) - Method in class com.sleepycat.je.log.entry.INLogEntry
Print out the contents of an entry.
dumpEntry(StringBuilder, boolean) - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
dumpEntry(StringBuilder, boolean) - Method in interface com.sleepycat.je.log.entry.LogEntry
Print out the contents of an entry.
dumpEntry(StringBuilder, boolean) - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
Extends its super class to dump database operation information.
dumpEntry(StringBuilder, boolean) - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
dumpEvents() - Static method in class com.sleepycat.je.utilint.EventTrace
 
dumpEvents(PrintStream) - Static method in class com.sleepycat.je.utilint.EventTrace
 
dumpFeederState() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Dumps the state associated with all active Feeders.
dumpFeederState() - Method in class com.sleepycat.je.rep.impl.RepImpl
Dumps the state associated with all active Feeders alone with identifying information about the node and its current HA state.
DumpFileReader - Class in com.sleepycat.je.log
The DumpFileReader prints every log entry to stdout.
DumpFileReader(EnvironmentImpl, int, long, long, long, String, String, boolean, boolean, boolean) - Constructor for class com.sleepycat.je.log.DumpFileReader
Create this reader to start at a given LSN.
dumpFlags(StringBuilder, boolean, byte) - Static method in class com.sleepycat.je.dbi.DatabaseImpl
 
dumpGroup() - Method in class com.sleepycat.je.rep.util.DbGroupAdmin
Display group information.
dumpKey(StringBuilder, byte[]) - Method in class com.sleepycat.je.tree.FileSummaryLN
 
dumpKey(StringBuilder, byte[]) - Method in class com.sleepycat.je.tree.LN
 
dumpKeys() - Method in class com.sleepycat.je.tree.IN
 
dumpLatchesHeld() - Static method in class com.sleepycat.je.latch.LatchSupport
 
dumpLockTable(StatGroup, boolean) - Method in class com.sleepycat.je.txn.DummyLockManager
 
dumpLockTable() - Method in class com.sleepycat.je.txn.Locker
Dump lock table, for debugging
dumpLockTable(StatGroup, boolean) - Method in class com.sleepycat.je.txn.LockManager
Dump the lock table to the lock stats.
dumpLockTable(StatGroup, boolean) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
dumpLockTableInternal(StatGroup, int, boolean) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of dumpLockTableInternal.
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.cleaner.DbFileSummary
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.cleaner.FileSummary
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.cleaner.PackedOffsets
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.dbi.DatabaseId
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.dbi.DbTree
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
 
dumpLog(StringBuilder, boolean) - Method in enum com.sleepycat.je.log.entry.DbOperationType
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.log.FileHeader
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.log.LogEntryHeader
 
dumpLog(StringBuilder, boolean) - Method in interface com.sleepycat.je.log.Loggable
Write the object into the string buffer for log dumping.
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.log.Trace
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.recovery.CheckpointStart
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.BINDelta
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.ChildReference
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.DeltaInfo
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.IN
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.LN
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.Node
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.Tree
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.txn.RollbackEnd
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.txn.RollbackStart
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.txn.Txn
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.txn.TxnEnd
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.txn.TxnPrepare
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.utilint.Matchpoint
 
dumpLog(StringBuilder, boolean) - Method in class com.sleepycat.je.utilint.VLSN
 
dumpLogAdditional(StringBuilder) - Method in class com.sleepycat.je.tree.dupConvert.DBIN
DBINS need to dump their dup key
dumpLogAdditional(StringBuilder) - Method in class com.sleepycat.je.tree.dupConvert.DIN
DINS need to dump their dup key
dumpLogAdditional(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
Dump additional fields
dumpLogAdditional(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.FileSummaryLN
Dump additional fields.
dumpLogAdditional(StringBuilder) - Method in class com.sleepycat.je.tree.IN
Allows subclasses to add additional fields before the end tag.
dumpLogAdditional(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.LN
 
dumpLogAdditional(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.MapLN
Dump additional fields.
dumpLogAdditional(StringBuilder, boolean) - Method in class com.sleepycat.je.tree.NameLN
Dump additional fields.
dumpLogEntry() - Method in class com.sleepycat.je.rep.stream.InputWireRecord
Convert the full version of the log entry to a string.
dumpLogNoTag(StringBuilder, boolean) - Method in class com.sleepycat.je.log.LogEntryHeader
Dump the header without enclosing
tags.
dumpOne(PrintStream, byte[], boolean) - Method in class com.sleepycat.je.util.DbDump
 
dumpPassedTxns() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
Display the saved transaction information.
dumpRep(StringBuilder) - Method in class com.sleepycat.je.log.entry.INLogEntry
Never replicated.
dumpRep(StringBuilder) - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
dumpRep(StringBuilder) - Method in interface com.sleepycat.je.log.entry.LogEntry
Dump the contents of the log entry that are interesting for replication.
dumpRep(StringBuilder) - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
 
dumpRep(StringBuilder) - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
dumpRep(StringBuilder) - Method in class com.sleepycat.je.log.LogEntryHeader
 
dumpState() - Method in class com.sleepycat.je.rep.impl.node.Feeder
For debugging and exception messages.
dumpState() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
dumpState() - Method in class com.sleepycat.je.rep.impl.node.Replay
 
dumpState() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Dumps the states associated with any active Feeders as well as information pertaining to the group CBVLSN and the composition of the group itself.
dumpState() - Method in class com.sleepycat.je.rep.impl.RepImpl
Dump interesting aspects of the node's state.
dumpState() - Method in class com.sleepycat.je.rep.stream.FeederReader
 
dumpState() - Method in interface com.sleepycat.je.rep.stream.FeederSource
 
dumpState() - Method in class com.sleepycat.je.rep.stream.MasterFeederSource
 
dumpString(int) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
dumpString(int) - Method in class com.sleepycat.je.dbi.DbTree
 
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.ChildReference
 
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.dupConvert.DBIN
For unit test support:
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.dupConvert.DIN
For unit test support:
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.FileSummaryLN
 
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.IN
For unit test support:
dumpString(byte[], int) - Static method in class com.sleepycat.je.tree.Key
 
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.LN
 
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.MapLN
 
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.NameLN
 
dumpString(int, boolean) - Method in class com.sleepycat.je.tree.Node
 
dumpString(int) - Method in class com.sleepycat.je.tree.Tree
 
dumpString(long, int) - Static method in class com.sleepycat.je.utilint.DbLsn
 
dumpToString(boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
 
dumpToString() - Method in class com.sleepycat.je.txn.LockManager
 
dumpTree() - Method in class com.sleepycat.je.dbi.CursorImpl
 
dumpTriggers(StringBuilder, byte[][], List<Trigger>) - Static method in class com.sleepycat.je.dbi.TriggerUtils
Dumps an XML representation of the triggers into the StringBuilder.
DUP - Static variable in interface com.sleepycat.asm.Opcodes
 
dup() - Method in class com.sleepycat.collections.BaseIterator
 
dup() - Method in class com.sleepycat.collections.BlockIterator
 
dup() - Method in class com.sleepycat.collections.StoredIterator
 
dup(boolean) - Method in class com.sleepycat.je.Cursor
Returns a new cursor with the same transaction and locker ID as the original cursor.
dup(boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
Return a new copy of the cursor.
dup(boolean) - Method in class com.sleepycat.je.SecondaryCursor
Returns a new SecondaryCursor for the same transaction as the original cursor.
dup() - Method in class com.sleepycat.persist.BasicCursor
 
dup() - Method in interface com.sleepycat.persist.EntityCursor
Duplicates the cursor at the cursor position.
dup() - Method in class com.sleepycat.persist.SubIndexCursor
 
dup(boolean) - Method in class com.sleepycat.util.keyrange.RangeCursor
Create a cloned range cursor.
DUP2 - Static variable in interface com.sleepycat.asm.Opcodes
 
DUP2_X1 - Static variable in interface com.sleepycat.asm.Opcodes
 
DUP2_X2 - Static variable in interface com.sleepycat.asm.Opcodes
 
DUP_NODE_REJECT - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
DUP_X1 - Static variable in interface com.sleepycat.asm.Opcodes
 
DUP_X2 - Static variable in interface com.sleepycat.asm.Opcodes
 
DupConvert - Class in com.sleepycat.je.tree.dupConvert
Performs post-recovery conversion of all dup DBs during Environment construction, when upgrading from JE 4.1 and earlier.
DupConvert(EnvironmentImpl, DbTree) - Constructor for class com.sleepycat.je.tree.dupConvert.DupConvert
Creates a conversion object.
DupCountLN - Class in com.sleepycat.je.tree.dupConvert
A DupCountLN represents the transactional part of the root of a duplicate tree, specifically the count of dupes in the tree.
DupCountLN() - Constructor for class com.sleepycat.je.tree.dupConvert.DupCountLN
Create an empty DupCountLN, to be filled in from the log.
DUPCOUNTLN_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
dupCursor(Cursor, boolean, boolean) - Method in class com.sleepycat.collections.CurrentTransaction
Duplicates a cursor for a given database.
dupCursor(Cursor, boolean) - Method in class com.sleepycat.collections.MyRangeCursor
 
dupCursor(Cursor, boolean) - Method in class com.sleepycat.util.keyrange.RangeCursor
Dups the given cursor.
DupKeyData - Class in com.sleepycat.je.dbi
Utility methods for combining, splitting and comparing two-part key values for duplicates databases.
DupKeyData() - Constructor for class com.sleepycat.je.dbi.DupKeyData
 
DupKeyData.NextNoDupComparator - Class in com.sleepycat.je.dbi
Used to perform the getNextNoDup operation.
DupKeyData.NextNoDupComparator(Comparator<byte[]>) - Constructor for class com.sleepycat.je.dbi.DupKeyData.NextNoDupComparator
 
DupKeyData.PutNoOverwriteComparator - Class in com.sleepycat.je.dbi
Used to perform the putNoOverwrite operation.
DupKeyData.PutNoOverwriteComparator(Comparator<byte[]>) - Constructor for class com.sleepycat.je.dbi.DupKeyData.PutNoOverwriteComparator
 
DupKeyData.TwoPartKeyComparator - Class in com.sleepycat.je.dbi
Comparator that compares the combined key/data two-part key, calling the user-defined btree and duplicate comparator as needed.
DupKeyData.TwoPartKeyComparator(Comparator<byte[]>, Comparator<byte[]>) - Constructor for class com.sleepycat.je.dbi.DupKeyData.TwoPartKeyComparator
 
DuplicateDataException - Exception in com.sleepycat.je
Thrown by Cursor.putCurrent if the old and new data are not equal according to the configured duplicate comparator or default comparator.
DuplicateDataException(String) - Constructor for exception com.sleepycat.je.DuplicateDataException
For internal use only.
duplicates(K) - Method in class com.sleepycat.collections.StoredMap
Returns a new collection containing the values mapped to the given key in this map.
duplicates - Variable in class com.sleepycat.je.sync.impl.LogChangeReader.DbInfo
 
duplicatesMap(K, EntryBinding) - Method in class com.sleepycat.collections.StoredMap
Returns a new map from primary key to value for the subset of records having a given secondary key (duplicates).
duplicatesView(Object, EntryBinding) - Method in class com.sleepycat.collections.DataView
Return a new duplicates view for a given secondary key.
dupsAllowed - Variable in class com.sleepycat.collections.DataView
 
dupSecondary(boolean) - Method in class com.sleepycat.je.SecondaryCursor
Deprecated.
As of JE 4.0.13, replaced by Cursor.dup(boolean).

dupsKey - Variable in class com.sleepycat.collections.DataView
 
dupsOrdered - Variable in class com.sleepycat.collections.DataView
 
dupsRange - Variable in class com.sleepycat.collections.DataView
 
dupsView - Variable in class com.sleepycat.collections.DataView
 
Durability - Class in com.sleepycat.je
Durability defines the overall durability characteristics associated with a transaction.
Durability(Durability.SyncPolicy, Durability.SyncPolicy, Durability.ReplicaAckPolicy) - Constructor for class com.sleepycat.je.Durability
Creates an instance of a Durability specification.
Durability.ReplicaAckPolicy - Enum in com.sleepycat.je
A replicated environment makes it possible to increase an application's transaction commit guarantees by committing changes to its replicas on the network.
Durability.SyncPolicy - Enum in com.sleepycat.je
Defines the synchronization policy to be used when committing a transaction.
DurationConfigParam - Class in com.sleepycat.je.config
A JE configuration parameter with a duration integer value in milliseconds.
DurationConfigParam(String, String, String, String, boolean, boolean) - Constructor for class com.sleepycat.je.config.DurationConfigParam
 
durationToMillis(long, TimeUnit) - Static method in class com.sleepycat.je.utilint.PropUtil
Converts the given duration (interval value plus unit) to milliseconds, ensuring that any given value greater than zero converts to at least one millisecond to avoid a zero millisecond result, since Object.wait(0) waits forever.

E

Edge - Class in com.sleepycat.asm
An edge in the control flow graph of a method body.
Edge() - Constructor for class com.sleepycat.asm.Edge
 
elapsedTime() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
Returns the elapsed time associated with this transaction.
ELECTABLE_GROUP_SIZE_OVERRIDE - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
ELECTABLE_GROUP_SIZE_OVERRIDE - Static variable in class com.sleepycat.je.rep.ReplicationMutableConfig
An escape mechanism to modify the way in which the number of electable nodes, and consequently the quorum requirements for elections and commit acknowledgments, is calculated.
ElectionAgentThread - Class in com.sleepycat.je.rep.elections
ElectionAgentThread is the base class for the election agent threads underlying the Acceptor and Learner agents.
ElectionAgentThread(RepNode, Protocol, String) - Constructor for class com.sleepycat.je.rep.elections.ElectionAgentThread
 
electionInProgress() - Method in class com.sleepycat.je.rep.elections.Elections
Predicate to determine whether an election is currently in progress.
Elections - Class in com.sleepycat.je.rep.elections
Represents the environment in which elections are run on behalf of a node.
Elections(RepNode, Learner.Listener, Acceptor.SuggestionGenerator) - Constructor for class com.sleepycat.je.rep.elections.Elections
Creates an instance of Elections.
elections - Variable in class com.sleepycat.je.rep.elections.Proposer
 
Elections.ElectionListener - Class in com.sleepycat.je.rep.elections
Used to short-circuit Proposal retries if a new election has completed since the time this election was initiated.
Elections.ElectionListener() - Constructor for class com.sleepycat.je.rep.elections.Elections.ElectionListener
 
Elections.RetryPredicate - Class in com.sleepycat.je.rep.elections
Implements the retry policy
Elections.RetryPredicate(RepNode, int, CountDownLatch) - Constructor for class com.sleepycat.je.rep.elections.Elections.RetryPredicate
 
ELECTIONS_OPEN_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
ELECTIONS_PRIMARY_RETRIES - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
ELECTIONS_PRIMARY_RETRIES - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The number of times an unsuccessful election will be retried by a designated Primary in a two node group before it is activated and becomes the Master.
ELECTIONS_READ_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
ELECTIONS_REBROADCAST_PERIOD - Static variable in class com.sleepycat.je.rep.impl.RepParams
The master re-broadcasts the results of an election with this period.
ELECTIONS_REBROADCAST_PERIOD - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The time interval between rebroadcasts of election results by the master node to all nodes not currently connected to it.
ELEMENT_OF - Static variable in class com.sleepycat.asm.Frame
Constant to be added to a type to get a type with one less dimension.
empty() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
EMPTY - Static variable in class com.sleepycat.je.rep.vlsn.VLSNRange
 
EMPTY_CACHE - Static variable in class com.sleepycat.je.tree.VLSNCache
An EMPTY_CACHE is used initially for each BIN until the need arises to add to the cache.
EMPTY_KEY - Static variable in class com.sleepycat.je.tree.Key
 
emptyGroup - Variable in class com.sleepycat.je.rep.impl.RepGroupDB
 
emptyRange - Variable in class com.sleepycat.persist.BasicIndex
 
enable() - Method in class com.sleepycat.je.dbi.INList
Enable the INList during recovery.
end - Variable in class com.sleepycat.asm.Handler
End of the exception handler's scope (exclusive).
end(Xid, int) - Method in class com.sleepycat.je.XAEnvironment
 
endBackup() - Method in class com.sleepycat.je.util.DbBackup
End backup mode, thereby re-enabling normal deletion of log files by the JE log cleaner.
endCkptLsn - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
endFileNum - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.TestAdjustment
 
endInclusive - Variable in class com.sleepycat.util.keyrange.KeyRange
 
endKey - Variable in class com.sleepycat.util.keyrange.KeyRange
 
endOffset - Variable in class com.sleepycat.je.log.FileReader.ReadWindow
 
endTag() - Method in class com.sleepycat.je.tree.BIN
 
endTag() - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
endTag() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
endTag() - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
endTag() - Method in class com.sleepycat.je.tree.FileSummaryLN
 
endTag() - Method in class com.sleepycat.je.tree.IN
 
endTag() - Method in class com.sleepycat.je.tree.LN
 
endTag() - Method in class com.sleepycat.je.tree.MapLN
 
endTag() - Method in class com.sleepycat.je.tree.NameLN
 
enhance(String, byte[]) - Method in class com.sleepycat.persist.model.ClassEnhancer
Enhances the given class bytes if the class is annotated with Entity or Persistent.
Enhanced - Interface in com.sleepycat.persist.impl
Interface implemented by a persistent class via bytecode enhancement.
EnhancedAccessor - Class in com.sleepycat.persist.impl
Implements Accessor for a complex persistent class.
EnhancedAccessor(Catalog, Class, ComplexFormat) - Constructor for class com.sleepycat.persist.impl.EnhancedAccessor
Creates an accessor for a complex type.
EnhancedAccessor(Catalog, Class, List<FieldInfo>) - Constructor for class com.sleepycat.persist.impl.EnhancedAccessor
Creates an accessor for a composite key type.
enhanceFile(File) - Method in class com.sleepycat.persist.model.ClassEnhancer
 
enqueueWrite(long, byte[], long, int, int) - Method in class com.sleepycat.je.log.FileManager.LogEndFileDescriptor
 
ENSURE_NODE - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
ENSURE_OK - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
ensureConsistency(EnvironmentImpl) - Method in class com.sleepycat.je.rep.CommitPointConsistencyPolicy
 
ensureConsistency(EnvironmentImpl) - Method in class com.sleepycat.je.rep.impl.PointConsistencyPolicy
Ensures that the replica has replayed the replication stream to the point identified by the commit token.
ensureConsistency(EnvironmentImpl) - Method in class com.sleepycat.je.rep.NoConsistencyRequiredPolicy
 
ensureConsistency(EnvironmentImpl) - Method in class com.sleepycat.je.rep.TimeConsistencyPolicy
 
ensureConsistency(EnvironmentImpl) - Method in interface com.sleepycat.je.ReplicaConsistencyPolicy
 
ensureMember(Protocol.NodeGroupInfo) - Method in class com.sleepycat.je.rep.impl.RepGroupDB
Ensures that the membership info for the replica is in the database.
ensureMember(RepNodeImpl) - Method in class com.sleepycat.je.rep.impl.RepGroupDB
 
ensureMonitor(RepNodeImpl) - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
 
ensureReplicasForCommit(MasterTxn, Durability.ReplicaAckPolicy, int, int) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Ensures that the required number of replicas are active if the node is currently the master.
entities() - Method in class com.sleepycat.persist.BasicIndex
 
entities(Transaction, CursorConfig) - Method in class com.sleepycat.persist.BasicIndex
 
entities(K, boolean, K, boolean) - Method in class com.sleepycat.persist.BasicIndex
 
entities(Transaction, K, boolean, K, boolean, CursorConfig) - Method in class com.sleepycat.persist.BasicIndex
 
entities() - Method in interface com.sleepycat.persist.EntityIndex
Opens a cursor for traversing all entities in this index.
entities(Transaction, CursorConfig) - Method in interface com.sleepycat.persist.EntityIndex
Opens a cursor for traversing all entities in this index.
entities(K, boolean, K, boolean) - Method in interface com.sleepycat.persist.EntityIndex
Opens a cursor for traversing entities in a key range.
entities(Transaction, K, boolean, K, boolean, CursorConfig) - Method in interface com.sleepycat.persist.EntityIndex
Opens a cursor for traversing entities in a key range.
entities() - Method in class com.sleepycat.persist.EntityJoin
Opens a cursor that returns the entities qualifying for the join.
entities(Transaction, CursorConfig) - Method in class com.sleepycat.persist.EntityJoin
Opens a cursor that returns the entities qualifying for the join.
entities() - Method in class com.sleepycat.persist.SubIndex
 
entities(Transaction, CursorConfig) - Method in class com.sleepycat.persist.SubIndex
 
entities(PK, boolean, PK, boolean) - Method in class com.sleepycat.persist.SubIndex
 
entities(Transaction, PK, boolean, PK, boolean, CursorConfig) - Method in class com.sleepycat.persist.SubIndex
 
Entity - Annotation Type in com.sleepycat.persist.model
Indicates a persistent entity class.
entityAdapter - Variable in class com.sleepycat.persist.BasicIndex
 
EntityBinding<E> - Interface in com.sleepycat.bind
A binding between a key-value entry pair and an entity object.
entityBinding - Variable in class com.sleepycat.collections.DataView
 
EntityConverter - Class in com.sleepycat.persist.evolve
A subclass of Converter that allows specifying keys to be deleted.
EntityConverter(String, int, Conversion, Set<String>) - Constructor for class com.sleepycat.persist.evolve.EntityConverter
Creates a mutation for converting all instances of the given entity class version to the current version of the class.
EntityCursor<V> - Interface in com.sleepycat.persist
Traverses entity values or key values and allows deleting or updating the entity at the current cursor position.
entityFormat - Variable in class com.sleepycat.persist.impl.PersistEntityBinding
 
EntityIndex<K,V> - Interface in com.sleepycat.persist
The interface for accessing keys and entities via a primary or secondary index.
EntityInput - Interface in com.sleepycat.persist.impl
Used for reading object fields.
EntityJoin<PK,E> - Class in com.sleepycat.persist
Performs an equality join on two or more secondary keys.
EntityJoin(PrimaryIndex<PK, E>) - Constructor for class com.sleepycat.persist.EntityJoin
Creates a join object for a given primary index.
EntityMetadata - Class in com.sleepycat.persist.model
The metadata for a persistent entity class.
EntityMetadata(String, PrimaryKeyMetadata, Map<String, SecondaryKeyMetadata>) - Constructor for class com.sleepycat.persist.model.EntityMetadata
Used by an EntityModel to construct entity metadata.
EntityModel - Class in com.sleepycat.persist.model
The base class for classes that provide entity model metadata.
EntityModel() - Constructor for class com.sleepycat.persist.model.EntityModel
The default constructor for use by subclasses.
EntityOutput - Interface in com.sleepycat.persist.impl
Used for writing object fields.
EntityStore - Class in com.sleepycat.persist
A store for managing persistent entity objects.
EntityStore(Environment, String, StoreConfig) - Constructor for class com.sleepycat.persist.EntityStore
Opens an entity store in a given environment.
EntityValueAdapter<V> - Class in com.sleepycat.persist
A ValueAdapter where the "value" is the entity.
EntityValueAdapter(Class<V>, EntityBinding, boolean) - Constructor for class com.sleepycat.persist.EntityValueAdapter
 
entries - Variable in class com.sleepycat.je.tree.TrackingInfo
 
entry - Variable in class com.sleepycat.je.log.LogItem
Object to be marshaled and logged.
ENTRY - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
ENTRY_NOTFOUND - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
ENTRY_REQUEST - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
EntryBinding<E> - Interface in com.sleepycat.bind
A binding between a key or data entry and a key or data object.
entryBuffer - Variable in class com.sleepycat.je.rep.stream.OutputWireRecord
 
entryIsReplicated() - Method in class com.sleepycat.je.log.FileReader
 
entrySet() - Method in class com.sleepycat.collections.StoredMap
Returns a set view of the mappings contained in this map.
entrySet() - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
 
entrySet() - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
entrySet() - Method in class com.sleepycat.je.utilint.IdentityHashMap
 
entrySize() - Static method in class com.sleepycat.je.log.FileHeader
A header is always a known size.
entryToBigDecimal(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.BigDecimalBinding
Converts an entry buffer into a BigDecimal value.
entryToBigDecimal(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedBigDecimalBinding
Converts an entry buffer into a BigDecimal value.
entryToBigInteger(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.BigIntegerBinding
Converts an entry buffer into a BigInteger value.
entryToBoolean(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.BooleanBinding
Converts an entry buffer into a simple boolean value.
entryToByte(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.ByteBinding
Converts an entry buffer into a simple byte value.
entryToChar(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.CharacterBinding
Converts an entry buffer into a simple char value.
entryToDouble(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.DoubleBinding
Converts an entry buffer into a simple double value.
entryToDouble(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedDoubleBinding
Converts an entry buffer into a simple double value.
entryToFloat(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.FloatBinding
Converts an entry buffer into a simple float value.
entryToFloat(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedFloatBinding
Converts an entry buffer into a simple float value.
entryToInput(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.TupleBase
Utility method to create a new tuple input object for reading the data from a given buffer.
entryToInt(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.IntegerBinding
Converts an entry buffer into a simple int value.
entryToInt(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.PackedIntegerBinding
Converts an entry buffer into a simple int value.
entryToInt(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedPackedIntegerBinding
Converts an entry buffer into a simple int value.
entryToLong(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.LongBinding
Converts an entry buffer into a simple long value.
entryToLong(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.PackedLongBinding
Converts an entry buffer into a simple Long value.
entryToLong(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedPackedLongBinding
Converts an entry buffer into a simple Long value.
entryToObject(DatabaseEntry) - Method in class com.sleepycat.bind.ByteArrayBinding
 
entryToObject(DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.bind.EntityBinding
Converts key and data entry buffers into an entity Object.
entryToObject(DatabaseEntry) - Method in interface com.sleepycat.bind.EntryBinding
Converts a entry buffer into an Object.
entryToObject(DatabaseEntry) - Method in class com.sleepycat.bind.RecordNumberBinding
 
entryToObject(DatabaseEntry) - Method in class com.sleepycat.bind.serial.SerialBinding
Deserialize an object from an entry buffer.
entryToObject(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.bind.serial.SerialSerialBinding
 
entryToObject(K, D) - Method in class com.sleepycat.bind.serial.SerialSerialBinding
Constructs an entity object from deserialized key and data objects.
entryToObject(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.bind.serial.TupleSerialBinding
 
entryToObject(TupleInput, D) - Method in class com.sleepycat.bind.serial.TupleSerialBinding
Constructs an entity object from TupleInput key entry and deserialized data entry objects.
entryToObject(TupleInput, E) - Method in class com.sleepycat.bind.serial.TupleSerialMarshalledBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.BigDecimalBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.BigIntegerBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.BooleanBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.ByteBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.CharacterBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.DoubleBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.FloatBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.IntegerBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.LongBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.PackedIntegerBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.PackedLongBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.ShortBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.SortedBigDecimalBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.SortedDoubleBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.SortedFloatBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.SortedPackedIntegerBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.SortedPackedLongBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.StringBinding
 
entryToObject(DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.TupleBinding
Constructs a key or data object from a TupleInput entry.
entryToObject(DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleInputBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.bind.tuple.TupleMarshalledBinding
 
entryToObject(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleTupleBinding
 
entryToObject(TupleInput, TupleInput) - Method in class com.sleepycat.bind.tuple.TupleTupleBinding
Constructs an entity object from TupleInput key and data entries.
entryToObject(TupleInput, TupleInput) - Method in class com.sleepycat.bind.tuple.TupleTupleMarshalledBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.je.rep.impl.RepGroupDB.GroupBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.je.rep.impl.RepGroupDB.NodeBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange.VLSNRangeBinding
 
entryToObject(TupleInput) - Method in class com.sleepycat.je.sync.impl.LogChangeSet.LogChangeSetBinding
 
entryToObject(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistEntityBinding
 
entryToObject(DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistKeyBinding
 
entryToObjectWithPriKey(Object, DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistEntityBinding
This method will be used in PrimaryIndex.get, where the primary key is known to DPL.
entryToRecordNumber(DatabaseEntry) - Static method in class com.sleepycat.bind.RecordNumberBinding
Utility method for use by bindings to translate a entry buffer to an record number integer.
entryToShort(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.ShortBinding
Converts an entry buffer into a simple short value.
entryToString(DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.StringBinding
Converts an entry buffer into a simple String value.
entryToValue(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.DataValueAdapter
 
entryToValue(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.EntityValueAdapter
 
entryToValue(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.KeyValueAdapter
 
entryToValue(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.PrimaryKeyValueAdapter
 
entryToValue(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.persist.ValueAdapter
Returns the appropriate "value" (key, primary key, or entity) using the appropriate bindings for that purpose.
entryType - Variable in class com.sleepycat.je.log.entry.BaseEntry
 
ENTRYTYPE_OFFSET - Static variable in class com.sleepycat.je.log.LogEntryHeader
 
entryZeroKeyComparesLow() - Method in class com.sleepycat.je.tree.BIN
Indicates whether entry 0's key is "special" in that it always compares less than any other key.
entryZeroKeyComparesLow() - Method in class com.sleepycat.je.tree.IN
Indicates whether whether entry 0's key is "special" in that it always compares less than any other key.
EnumConfigParam<T extends java.lang.Enum<T>> - Class in com.sleepycat.je.rep.impl
A JE configuration parameter with an enumerated value
EnumConfigParam(String, Enum<T>, boolean, boolean, Class<T>) - Constructor for class com.sleepycat.je.rep.impl.EnumConfigParam
 
EnumFormat - Class in com.sleepycat.persist.impl
Format for all enum types.
EnumFormat(Catalog, Class) - Constructor for class com.sleepycat.persist.impl.EnumFormat
 
EnumFormat(Catalog, Class, String[]) - Constructor for class com.sleepycat.persist.impl.EnumFormat
For use in a deserialized CompositeKeyFormat.
env - Variable in class com.sleepycat.je.cleaner.BaseUtilizationTracker
 
env - Variable in class com.sleepycat.je.jmx.JEMBean
 
env - Variable in class com.sleepycat.je.sync.SyncProcessor
 
env - Variable in class com.sleepycat.je.util.DbDump
 
env - Variable in class com.sleepycat.je.util.DbLoad
 
env - Variable in class com.sleepycat.je.util.DbVerify
 
ENV_BACKGROUND_READ_LIMIT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_BACKGROUND_READ_LIMIT - Static variable in class com.sleepycat.je.EnvironmentConfig
The maximum number of read operations performed by JE background activities (e.g., cleaning) before sleeping to ensure that application threads can perform I/O.
ENV_BACKGROUND_SLEEP_INTERVAL - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_BACKGROUND_SLEEP_INTERVAL - Static variable in class com.sleepycat.je.EnvironmentConfig
The duration that JE background activities will sleep when the EnvironmentConfig.ENV_BACKGROUND_WRITE_LIMIT or EnvironmentConfig.ENV_BACKGROUND_WRITE_LIMIT is reached.
ENV_BACKGROUND_WRITE_LIMIT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_BACKGROUND_WRITE_LIMIT - Static variable in class com.sleepycat.je.EnvironmentConfig
The maximum number of write operations performed by JE background activities (e.g., checkpointing and eviction) before sleeping to ensure that application threads can perform I/O.
ENV_CHECK_LEAKS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_CHECK_LEAKS - Static variable in class com.sleepycat.je.EnvironmentConfig
Debugging support: check leaked locks and txns at env close.
ENV_COMPARATORS_REQUIRED - Static variable in class com.sleepycat.je.config.EnvironmentParams
Used by utilities, not exposed in the API.
ENV_CONSISTENCY_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
ENV_CONSISTENCY_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The amount of time to wait for a Replica to become consistent with the Master, when a ReplicatedEnvironment handle is created and no ConsistencyPolicy is specified.
ENV_DB_CACHE_CLEAR_COUNT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_DB_EVICTION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_DB_EVICTION - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, enable eviction of metadata for closed databases.
ENV_DIFF - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
ENV_DUP_CONVERT_PRELOAD_ALL - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_DUP_CONVERT_PRELOAD_ALL - Static variable in class com.sleepycat.je.EnvironmentConfig
If true (the default) preload all duplicates databases at once when upgrading from JE 4.1 and earlier.
ENV_FAIR_LATCHES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_FAIR_LATCHES - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, use latches instead of synchronized blocks to implement the lock table and log write mutexes.
ENV_FORCED_YIELD - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_FORCED_YIELD - Static variable in class com.sleepycat.je.EnvironmentConfig
Debugging support: call Thread.yield() at strategic points.
ENV_GROUP_DESC - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
ENV_GROUP_NAME - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
ENV_INFO - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
ENV_INIT_LOCKING - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_INIT_TXN - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_IS_LOCKING - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, create the environment with record locking.
ENV_IS_TRANSACTIONAL - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, create an environment that is capable of performing transactions.
ENV_RDONLY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_READ_ONLY - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, open the environment read-only.
ENV_RECOVERY - Static variable in class com.sleepycat.je.config.EnvironmentParams
Used by utilities, not exposed in the API.
ENV_RECOVERY_FORCE_CHECKPOINT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_RECOVERY_FORCE_CHECKPOINT - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, a checkpoint is forced following recovery, even if the log ends with a checkpoint.
ENV_RUN_CHECKPOINTER - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_RUN_CHECKPOINTER - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, starts up the checkpointer thread.
ENV_RUN_CLEANER - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_RUN_CLEANER - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, starts up the cleaner thread.
ENV_RUN_EVICTOR - Static variable in class com.sleepycat.je.config.EnvironmentParams
If true, eviction is also done by a pool of evictor threads, as well as being done inline by application threads.
ENV_RUN_EVICTOR - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, eviction is also done by a pool of evictor threads, as well as being done inline by application threads.
ENV_RUN_IN_COMPRESSOR - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, starts up the INCompressor thread.
ENV_RUN_INCOMPRESSOR - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_SETUP_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
ENV_SETUP_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The maximum amount of time for the internal housekeeping, like elections, syncup with the master, etc.
ENV_SHARED_CACHE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
ENV_SHARED_LATCHES - Static variable in class com.sleepycat.je.config.EnvironmentParams
Not part of the public API.
ENV_UNKNOWN_STATE_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
ENV_UNKNOWN_STATE_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
Permits opening of a ReplicatedEnvironment handle in the ReplicatedEnvironment.State.UNKNOWN state, if a Master cannot be determined within this timeout period.
EnvConfigObserver - Interface in com.sleepycat.je.dbi
Implemented by observers of mutable config changes.
envConfigUpdate(DbConfigManager, EnvironmentMutableConfig) - Method in class com.sleepycat.je.cleaner.Cleaner
Process notifications of mutable property changes.
envConfigUpdate(DbConfigManager, EnvironmentMutableConfig) - Method in class com.sleepycat.je.dbi.DiskOrderedCursorImpl
Process notifications of mutable property changes.
envConfigUpdate(DbConfigManager, EnvironmentMutableConfig) - Method in interface com.sleepycat.je.dbi.EnvConfigObserver
Notifies the observer that one or more mutable properties have been changed.
envConfigUpdate(DbConfigManager, EnvironmentMutableConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Respond to config updates.
envConfigUpdate(DbConfigManager, EnvironmentMutableConfig) - Method in class com.sleepycat.je.dbi.MemoryBudget
Respond to config updates.
envConfigUpdate(DbConfigManager, EnvironmentMutableConfig) - Method in class com.sleepycat.je.evictor.Evictor
Respond to config updates.
envConfigUpdate(DbConfigManager, EnvironmentMutableConfig) - Method in class com.sleepycat.je.recovery.Checkpointer
Process notifications of mutable property changes.
envConfigUpdate(DbConfigManager, EnvironmentMutableConfig) - Method in class com.sleepycat.je.txn.LockManager
Process notifications of mutable property changes.
envHandle - Variable in class com.sleepycat.je.Database
 
envHome - Variable in class com.sleepycat.je.util.DbDump
 
envHome - Variable in class com.sleepycat.je.util.DbVerify
 
envImpl - Variable in class com.sleepycat.je.dbi.NodeSequence
 
envImpl - Variable in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
envImpl - Variable in class com.sleepycat.je.Environment
 
envImpl - Variable in class com.sleepycat.je.evictor.Evictor
 
envImpl - Variable in class com.sleepycat.je.log.FileReader
 
envImpl - Variable in class com.sleepycat.je.log.FileReader.ReadWindow
 
envImpl - Variable in class com.sleepycat.je.log.LogManager
 
envImpl - Variable in class com.sleepycat.je.rep.impl.TextProtocol
 
envImpl - Variable in class com.sleepycat.je.rep.stream.OutputWireRecord
 
envImpl - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
envImpl - Variable in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareBlockingQueue
 
envImpl - Variable in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareCountDownLatch
 
envImpl - Variable in class com.sleepycat.je.sync.SyncProcessor
 
envImpl - Variable in class com.sleepycat.je.txn.Locker
 
envImpl - Variable in class com.sleepycat.je.utilint.DaemonThread
 
envImpl - Variable in class com.sleepycat.je.utilint.StoppableThread
 
ENVIMPL_RELATCHES_REQUIRED - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
envInternal - Variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
Environment - Class in com.sleepycat.je
A database environment.
Environment(File, EnvironmentConfig) - Constructor for class com.sleepycat.je.Environment
Creates a database environment handle.
Environment(File, EnvironmentConfig, RepConfigProxy, EnvironmentImpl) - Constructor for class com.sleepycat.je.Environment
 
Environment(File) - Constructor for class com.sleepycat.je.Environment
Gets an Environment for an existing EnvironmentImpl.
Environment(File, EnvironmentConfig, boolean, RepConfigProxy, EnvironmentImpl) - Constructor for class com.sleepycat.je.Environment
 
EnvironmentConfig - Class in com.sleepycat.je
Specifies the attributes of an environment.
EnvironmentConfig() - Constructor for class com.sleepycat.je.EnvironmentConfig
Creates an EnvironmentConfig initialized with the system default settings.
EnvironmentConfig(Properties) - Constructor for class com.sleepycat.je.EnvironmentConfig
Creates an EnvironmentConfig which includes the properties specified in the properties parameter.
EnvironmentConfigBeanInfo - Class in com.sleepycat.je
 
EnvironmentConfigBeanInfo() - Constructor for class com.sleepycat.je.EnvironmentConfigBeanInfo
 
EnvironmentFailureException - Exception in com.sleepycat.je
Indicates that a failure has occurred that could impact the Environment as a whole.
EnvironmentFailureException(EnvironmentImpl, EnvironmentFailureReason) - Constructor for exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
EnvironmentFailureException(EnvironmentImpl, EnvironmentFailureReason, Throwable) - Constructor for exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
EnvironmentFailureException(EnvironmentImpl, EnvironmentFailureReason, String) - Constructor for exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
EnvironmentFailureException(EnvironmentImpl, EnvironmentFailureReason, String, Throwable) - Constructor for exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
EnvironmentFailureException(String, EnvironmentFailureException) - Constructor for exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
EnvironmentFailureReason - Enum in com.sleepycat.je.dbi
 
EnvironmentImpl - Class in com.sleepycat.je.dbi
Underlying Environment implementation.
EnvironmentImpl(File, EnvironmentConfig, EnvironmentImpl) - Constructor for class com.sleepycat.je.dbi.EnvironmentImpl
 
EnvironmentImpl(File, EnvironmentConfig, EnvironmentImpl, RepConfigProxy) - Constructor for class com.sleepycat.je.dbi.EnvironmentImpl
Create a database environment to represent the data in envHome.
EnvironmentImpl.MBeanRegistrar - Interface in com.sleepycat.je.dbi
Because the Android platform does not have any javax.management classes, we load JEMonitor dynamically to ensure that there are no explicit references to com.sleepycat.je.jmx.*.
EnvironmentLockedException - Exception in com.sleepycat.je
Thrown by the Environment constructor when an environment cannot be opened for write access because another process has the same environment open for write access.
EnvironmentLockedException(EnvironmentImpl, String) - Constructor for exception com.sleepycat.je.EnvironmentLockedException
For internal use only.
EnvironmentMutableConfig - Class in com.sleepycat.je
Specifies the environment attributes that may be changed after the environment has been opened.
EnvironmentMutableConfig() - Constructor for class com.sleepycat.je.EnvironmentMutableConfig
An instance created using the default constructor is initialized with the system's default settings.
EnvironmentMutableConfig(Properties) - Constructor for class com.sleepycat.je.EnvironmentMutableConfig
Used by EnvironmentConfig to construct from properties.
EnvironmentMutableConfigBeanInfo - Class in com.sleepycat.je
 
EnvironmentMutableConfigBeanInfo() - Constructor for class com.sleepycat.je.EnvironmentMutableConfigBeanInfo
 
EnvironmentNotFoundException - Exception in com.sleepycat.je
Thrown by the Environment constructor when EnvironmentConfig AllowCreate property is false (environment creation is not permitted), but there are no log files in the environment directory.
EnvironmentNotFoundException(EnvironmentImpl, String) - Constructor for exception com.sleepycat.je.EnvironmentNotFoundException
For internal use only.
EnvironmentParams - Class in com.sleepycat.je.config
 
EnvironmentParams() - Constructor for class com.sleepycat.je.config.EnvironmentParams
 
EnvironmentStats - Class in com.sleepycat.je
Statistics for a single environment.
EnvironmentStats() - Constructor for class com.sleepycat.je.EnvironmentStats
 
envLogger - Variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
envLogMsg(Level, EnvironmentImpl, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Use the environment logger.
envMap - Static variable in class com.sleepycat.je.utilint.LoggerUtils
 
eof - Variable in class com.sleepycat.je.log.FileReader
 
equal - Variable in class com.sleepycat.je.tree.CountEstimator.KeyRatios
 
equalBytes(byte[], int, int, byte[], int, int) - Static method in class com.sleepycat.util.keyrange.KeyRange
Compares two byte arrays for equality.
equalBytes(DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.util.keyrange.KeyRange
Returns the two DatabaseEntry objects have the same data value.
equals(Object) - Method in class com.sleepycat.asm.Handle
 
equals(Object) - Method in class com.sleepycat.asm.Type
Tests if the given object is equal to this type.
equals(Object) - Method in class com.sleepycat.collections.MapEntryParameter
Compares this entry to a given entry as specified by Map.Entry.equals(java.lang.Object).
equals(Object) - Method in class com.sleepycat.collections.StoredCollection
Compares the specified object with this collection for equality.
equals(Object) - Method in class com.sleepycat.collections.StoredList
Compares the specified object with this list for equality.
equals(Object) - Method in class com.sleepycat.collections.StoredMap
Compares the specified object with this map for equality.
equals(Object) - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
equals(Object) - Method in class com.sleepycat.je.cleaner.UtilizationCalculator.AverageSize
 
equals(Object) - Method in class com.sleepycat.je.CommitToken
 
equals(Object) - Method in class com.sleepycat.je.DatabaseEntry
Compares the data of two entries for byte-by-byte equality.
equals(Object) - Method in class com.sleepycat.je.dbi.DatabaseId
Compare two DatabaseImpl Id's.
equals(Object) - Method in class com.sleepycat.je.Durability
 
equals(Object) - Method in class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
equals(Object) - Method in class com.sleepycat.je.jca.ra.JERequestInfo
 
equals(Object) - Method in class com.sleepycat.je.JEVersion
 
equals(Object) - Method in class com.sleepycat.je.log.LogEntryType
 
equals(Object) - Method in class com.sleepycat.je.log.LogUtils.XidImpl
 
equals(Object) - Method in class com.sleepycat.je.log.Trace
Override Object.equals
equals(Object) - Method in class com.sleepycat.je.recovery.Checkpointer.CheckpointReference
 
equals(Object) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
equals(Object) - Method in class com.sleepycat.je.rep.CommitPointConsistencyPolicy
 
equals(Object) - Method in class com.sleepycat.je.rep.elections.MasterValue
 
equals(Object) - Method in class com.sleepycat.je.rep.elections.Protocol.Accept
 
equals(Object) - Method in class com.sleepycat.je.rep.elections.Protocol.Accepted
 
equals(Object) - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
equals(Object) - Method in class com.sleepycat.je.rep.elections.Protocol.Propose
 
equals(Object) - Method in class com.sleepycat.je.rep.elections.Protocol.Reject
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.PointConsistencyPolicy
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl.BarrierState
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.TextProtocol.Fail
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.TextProtocol.RequestMessage
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.TextProtocol.ResponseMessage
 
equals(Object) - Method in class com.sleepycat.je.rep.impl.TextProtocol.StringFormatable
 
equals(Object) - Method in class com.sleepycat.je.rep.NoConsistencyRequiredPolicy
 
equals(Object) - Method in class com.sleepycat.je.rep.TimeConsistencyPolicy
 
equals(Object) - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
equals(Object) - Method in class com.sleepycat.je.rep.util.ldiff.Record
 
equals(Object) - Method in class com.sleepycat.je.Transaction
For internal use.
equals(Object) - Method in class com.sleepycat.je.tree.BINReference
Compare two BINReferences.
equals(Object) - Method in class com.sleepycat.je.tree.IN
 
equals(Object) - Method in class com.sleepycat.je.tree.Key
Support Set of Key in BINReference.
equals(Object) - Method in class com.sleepycat.je.txn.TxnChain.CompareSlot
 
equals(Object) - Method in class com.sleepycat.je.utilint.StatDefinition
 
equals(Timestamp) - Method in class com.sleepycat.je.utilint.Timestamp
 
equals(Object) - Method in class com.sleepycat.je.utilint.Timestamp
 
equals(Object) - Method in class com.sleepycat.je.utilint.VLSN
 
equals(VLSN) - Method in class com.sleepycat.je.utilint.VLSN
 
equals(Object) - Method in interface com.sleepycat.persist.evolve.Conversion
The standard equals method that must be implemented by conversion class.
equals(Object) - Method in class com.sleepycat.persist.evolve.Converter
Returns true if the conversion objects are equal in this object and given object, and if the Mutation.equals(java.lang.Object) superclass method returns true.
equals(Object) - Method in class com.sleepycat.persist.evolve.EntityConverter
Returns true if the deleted and renamed keys are equal in this object and given object, and if the Converter.equals(java.lang.Object) superclass method returns true.
equals(Object) - Method in class com.sleepycat.persist.evolve.Mutation
Returns true if the class name, class version and field name are equal in this object and given object.
equals(Object) - Method in class com.sleepycat.persist.evolve.Mutations
Returns true if this collection has the same set of mutations as the given collection and all mutations are equal.
equals(Object) - Method in class com.sleepycat.persist.evolve.Renamer
Returns true if the new class name is equal in this object and given object, and if the Mutation.equals(java.lang.Object) method returns true.
equals(Object) - Method in class com.sleepycat.persist.impl.FieldInfo
 
equals(Object) - Method in class com.sleepycat.persist.model.ClassMetadata
 
equals(Object) - Method in class com.sleepycat.persist.model.EntityMetadata
 
equals(Object) - Method in class com.sleepycat.persist.model.FieldMetadata
 
equals(Object) - Method in class com.sleepycat.persist.model.PrimaryKeyMetadata
 
equals(Object) - Method in class com.sleepycat.persist.model.SecondaryKeyMetadata
 
equals(Object) - Method in class com.sleepycat.persist.raw.RawObject
 
equalsType(byte) - Method in class com.sleepycat.je.log.LogEntryType
Check for equality without making a new object.
equivalent(RepNodeImpl) - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
Like the equals method.
ERROR - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
errorMessage - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol.RejectMessage
 
estCount - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.AverageSize
 
estimateDataSize(byte[]) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns an estimate of the data size for LNs in this database, or -1 if an estimate is unknown.
estimatedAvgSize - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.TestAdjustment
 
estimatedFileSummary - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.TestAdjustment
 
estSize - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.AverageSize
 
events - Static variable in class com.sleepycat.je.utilint.EventTrace
 
EventTrace - Class in com.sleepycat.je.utilint
Internal class used for transient event tracing.
EventTrace(String) - Constructor for class com.sleepycat.je.utilint.EventTrace
 
EventTrace() - Constructor for class com.sleepycat.je.utilint.EventTrace
 
EventTrace.ExceptionEventTrace - Class in com.sleepycat.je.utilint
 
EventTrace.ExceptionEventTrace() - Constructor for class com.sleepycat.je.utilint.EventTrace.ExceptionEventTrace
 
evict() - Method in class com.sleepycat.je.dbi.CursorImpl
Evict the LN node at the cursor position.
evict(boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
Evict the LN node at the cursor position.
evictBatch(Evictor.EvictionSource, boolean, long) - Method in class com.sleepycat.je.evictor.Evictor
Each iteration will attempt to evict maxEvictBytes, but will give up after a complete pass over the INList, or if there is nothing more to evict, due to actions by concurrently executing threads.
evictLN(int) - Method in class com.sleepycat.je.tree.BIN
Evict a single LN if allowed and adjust the memory budget.
evictLNs() - Method in class com.sleepycat.je.tree.BIN
Reduce memory consumption by evicting all LN targets.
evictMemory() - Method in class com.sleepycat.je.cleaner.UtilizationTracker
Evicts tracked detail if the budget for the tracker is exceeded.
evictMemory() - Method in class com.sleepycat.je.Environment
Synchronously invokes the mechanism for keeping memory usage within the cache size boundaries.
Evictor - Class in com.sleepycat.je.evictor
The Evictor is responsible for maintaining the JE cache.
Evictor(EnvironmentImpl) - Constructor for class com.sleepycat.je.evictor.Evictor
 
Evictor.BackgroundEvictTask - Class in com.sleepycat.je.evictor
 
Evictor.BackgroundEvictTask(Evictor, boolean) - Constructor for class com.sleepycat.je.evictor.Evictor.BackgroundEvictTask
 
Evictor.DbCache - Interface in com.sleepycat.je.evictor
Caches DatabaseImpls to reduce DbTree.getDb overhead.
Evictor.EvictionSource - Enum in com.sleepycat.je.evictor
 
Evictor.RejectEvictHandler - Class in com.sleepycat.je.evictor
 
Evictor.RejectEvictHandler(AtomicLongStat) - Constructor for class com.sleepycat.je.evictor.Evictor.RejectEvictHandler
 
EVICTOR_ALLOW_BIN_DELTAS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_ALLOW_BIN_DELTAS - Static variable in class com.sleepycat.je.EnvironmentConfig
Allow Bottom Internal Nodes (BINs) to be written in a delta format during eviction.
EVICTOR_BINS_STRIPPED - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
EVICTOR_CORE_THREADS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_CORE_THREADS - Static variable in class com.sleepycat.je.EnvironmentConfig
The minimum number of threads in the eviction thread pool.
EVICTOR_CRITICAL_PERCENTAGE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_CRITICAL_PERCENTAGE - Static variable in class com.sleepycat.je.EnvironmentConfig
At this percentage over the allotted cache, critical eviction will start.
EVICTOR_DEADLOCK_RETRY - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
as of JE 4.1, since the single evictor thread has been replaced be a more robust thread pool. The number of times to retry the evictor if it runs into a deadlock.

When using the shared cache feature, the value of this property is applied the first time the cache is set up. New environments that join the cache do not alter the cache setting.

NameTypeMutable DefaultMinimumMaximum
"je.evictor.deadlockRetry" Integer No 3 0 -none-

EVICTOR_EVICT_BYTES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_EVICT_BYTES - Static variable in class com.sleepycat.je.EnvironmentConfig
When eviction occurs, the evictor will push memory usage to this number of bytes below EnvironmentConfig.MAX_MEMORY.
EVICTOR_EVICT_PASSES - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
EVICTOR_EVICTION_BATCH_PERCENTAGE - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
As of 1.7.2, 1 node is chosen per scan. The evictor percentage of scanned nodes to evict per wakeup.
EVICTOR_FORCED_YIELD - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_FORCED_YIELD - Static variable in class com.sleepycat.je.EnvironmentConfig
Call Thread.yield() at each check for cache overflow.
EVICTOR_KEEP_ALIVE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_KEEP_ALIVE - Static variable in class com.sleepycat.je.EnvironmentConfig
The duration that excess threads in the eviction thread pool will stay idle.
EVICTOR_LRU_ONLY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_LRU_ONLY - Static variable in class com.sleepycat.je.EnvironmentConfig
If true (the default), use an LRU-only policy to select nodes for eviction.
EVICTOR_MAX_THREADS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_MAX_THREADS - Static variable in class com.sleepycat.je.EnvironmentConfig
The maximum number of threads in the eviction thread pool.
EVICTOR_NODE_SCAN_PERCENTAGE - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
As of 1.7.2, this is replaced by je.evictor.nodesPerScan The evictor percentage of total nodes to scan per wakeup.
EVICTOR_NODES_EVICTED - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
EVICTOR_NODES_PER_SCAN - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
EVICTOR_NODES_PER_SCAN - Static variable in class com.sleepycat.je.EnvironmentConfig
The number of nodes in one evictor scan.
EVICTOR_NODES_SCANNED - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
EVICTOR_NODES_SELECTED - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
EVICTOR_REQUIRED_EVICT_BYTES - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
EVICTOR_RETRY - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
as of JE 4.1
EVICTOR_ROOT_NODES_EVICTED - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
EVICTOR_SHARED_CACHE_ENVS - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
EVICTOR_TERMINATE_TIMEOUT - Static variable in class com.sleepycat.je.config.EnvironmentParams
The amount of time to wait for the eviction pool to terminate, in order to create a clean shutdown.
EVICTOR_USEMEM_FLOOR - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
As of 2.0, this is replaced by je.evictor.evictBytes When eviction happens, the evictor will push memory usage to this percentage of je.maxMemory.
EVICTOR_WAKEUP_INTERVAL - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
as of JE 4.1
EvictorStatDefinition - Class in com.sleepycat.je.evictor
Per-stat Metadata for JE evictor statistics.
EvictorStatDefinition() - Constructor for class com.sleepycat.je.evictor.EvictorStatDefinition
 
evolve(EvolveConfig) - Method in class com.sleepycat.persist.EntityStore
Performs conversion of unevolved objects in order to reduce lazy conversion overhead.
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.EnumFormat
 
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.Format
Called for an existing format that may not equal the current format for the same class.
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.NonPersistentFormat
 
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
evolve(Format, Evolver) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
evolve(EvolveConfig) - Method in class com.sleepycat.persist.impl.Store
 
EVOLVE_FAILURE - Static variable in class com.sleepycat.persist.impl.Evolver
 
EVOLVE_NEEDED - Static variable in class com.sleepycat.persist.impl.Evolver
 
EVOLVE_NONE - Static variable in class com.sleepycat.persist.impl.Evolver
 
EvolveConfig - Class in com.sleepycat.persist.evolve
Configuration properties for eager conversion of unevolved objects.
EvolveConfig() - Constructor for class com.sleepycat.persist.evolve.EvolveConfig
Creates an evolve configuration with default properties.
EvolveConfigBeanInfo - Class in com.sleepycat.persist.evolve
 
EvolveConfigBeanInfo() - Constructor for class com.sleepycat.persist.evolve.EvolveConfigBeanInfo
 
EvolveEvent - Class in com.sleepycat.persist.evolve
The event passed to the EvolveListener interface during eager entity evolution.
EvolveEvent() - Constructor for class com.sleepycat.persist.evolve.EvolveEvent
 
evolveFormat(Format) - Method in class com.sleepycat.persist.impl.Evolver
Called by PersistCatalog for all entity formats, and by Format.evolve methods for all potentially referenced non-entity formats.
EvolveInternal - Class in com.sleepycat.persist.evolve
 
EvolveInternal() - Constructor for class com.sleepycat.persist.evolve.EvolveInternal
 
EvolveListener - Interface in com.sleepycat.persist.evolve
The listener interface called during eager entity evolution.
evolveMetadata(Format, Converter, Evolver) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
evolveMetadata(Format, Converter, Evolver) - Method in class com.sleepycat.persist.impl.Format
Called when a Converter handles evolution of a class, but we may still need to evolve the metadata.
evolveProgress(EvolveEvent) - Method in interface com.sleepycat.persist.evolve.EvolveListener
The listener method called during eager entity evolution.
Evolver - Class in com.sleepycat.persist.impl
Evolves each old format that is still relevant if necessary, using Mutations to configure deleters, renamers, and converters.
Evolver(PersistCatalog, String, Mutations, Map<String, Format>, boolean, boolean) - Constructor for class com.sleepycat.persist.impl.Evolver
 
evolveRequiredKeyField(Format, Format, FieldInfo, FieldInfo) - Method in class com.sleepycat.persist.impl.Evolver
Evolves a primary key field or composite key field.
EvolveStats - Class in com.sleepycat.persist.evolve
Statistics accumulated during eager entity evolution.
EvolveStats() - Constructor for class com.sleepycat.persist.evolve.EvolveStats
 
EXACT_KEY - Static variable in class com.sleepycat.je.dbi.CursorImpl
 
EXACT_MATCH - Static variable in class com.sleepycat.je.tree.IN
 
exactParentFound - Variable in class com.sleepycat.je.tree.SearchResult
 
examineINForCheckpointHook - Static variable in class com.sleepycat.je.recovery.Checkpointer
 
EXCEEDED_TIME - Static variable in class com.sleepycat.je.PreloadStatus
Database.preload took more than maxMillisecs.
EXCEPTION - Static variable in class com.sleepycat.asm.Edge
Denotes a control flow graph edge corresponding to an exception handler.
exception - Variable in class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
 
exceptionCount - Variable in class com.sleepycat.asm.MethodWriter
Number of exceptions that can be thrown by this method.
ExceptionEvent - Class in com.sleepycat.je
A class representing an exception event.
ExceptionEvent(Exception, String) - Constructor for class com.sleepycat.je.ExceptionEvent
 
ExceptionEvent(Exception) - Constructor for class com.sleepycat.je.ExceptionEvent
 
ExceptionListener - Interface in com.sleepycat.je
A callback to notify the application program when an exception occurs in a JE Daemon thread.
ExceptionListenerUser - Interface in com.sleepycat.je.utilint
Any daemon thread has these responsibilities: - it is required to publish any exceptions to the JE exception - it must be able to accept a reu listener should implement this interface, and should register itself with the EnvironmentImpl.
exceptions - Variable in class com.sleepycat.asm.MethodWriter
The exceptions that can be thrown by this method.
exceptionThrown(ExceptionEvent) - Method in interface com.sleepycat.je.ExceptionListener
This method is called if an exception is seen in a JE Daemon thread.
ExceptionUnwrapper - Class in com.sleepycat.util
Unwraps nested exceptions by calling the ExceptionWrapper.getCause() method for exceptions that implement the ExceptionWrapper interface.
ExceptionUnwrapper() - Constructor for class com.sleepycat.util.ExceptionUnwrapper
 
ExceptionWrapper - Interface in com.sleepycat.util
Interface implemented by exceptions that can contain nested exceptions.
execute(int, int, ClassWriter, Item) - Method in class com.sleepycat.asm.Frame
Simulates the action of the given instruction on the output stack frame.
execute(Logger, EnvironmentImpl, Formatter) - Method in class com.sleepycat.je.rep.elections.Utils.WithFutureExceptionHandler
 
execute() - Method in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackup
Execute the backup.
execute(InsufficientLogException, NetworkRestoreConfig) - Method in class com.sleepycat.je.rep.NetworkRestore
Restores the log files from one of the members of the replication group.
execute() - Method in class com.sleepycat.je.rep.stream.FeederReplicaHandshake
Executes the feeder side of the handshake.
execute(LocalCBVLSNUpdater) - Method in class com.sleepycat.je.rep.stream.FeederReplicaSyncup
The feeder's side of the protocol.
execute() - Method in class com.sleepycat.je.rep.stream.ReplicaFeederHandshake
Executes the replica side of the handshake.
execute(LocalCBVLSNTracker) - Method in class com.sleepycat.je.rep.stream.ReplicaFeederSyncup
The replica's side of the protocol.
execute() - Method in class com.sleepycat.persist.model.ClassEnhancerTask
 
executeFSync() - Method in class com.sleepycat.je.log.FSyncManager
Put the fsync execution into this method so it can be overridden for testing purposes.
EXISTING - Static variable in class com.sleepycat.je.txn.LockUpgrade
 
exists(long) - Method in class com.sleepycat.je.incomp.INCompressor
 
exitRequest - Variable in class com.sleepycat.je.rep.impl.node.Replica.ReplayThread
Set asynchronously when a shutdown is being requested.
EXPAND_FRAMES - Static variable in class com.sleepycat.asm.ClassReader
Flag to expand the stack map frames.
EXPECT_ENHANCED - Static variable in class com.sleepycat.persist.impl.EnhancedAccessor
 
expectFlush - Static variable in class com.sleepycat.persist.impl.Store
 
expectNoClassChanges - Static variable in class com.sleepycat.persist.impl.PersistCatalog
Used by unit tests.
expectResponse - Variable in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingRunnable
 
ExportConfig - Class in com.sleepycat.je.sync
Optional export parameters that may be passed to a sync operation.
ExportConfig() - Constructor for class com.sleepycat.je.sync.ExportConfig
 
expunge - Variable in class com.sleepycat.je.cleaner.Cleaner
 
externalToLocal(Object, Class, String, String) - Method in interface com.sleepycat.je.sync.FieldConverter
Converts a external field/column value to a local field/property value, or returns fromValue unchanged if no custom conversion is needed.

F

F2D - Static variable in interface com.sleepycat.asm.Opcodes
 
F2I - Static variable in interface com.sleepycat.asm.Opcodes
 
F2L - Static variable in interface com.sleepycat.asm.Opcodes
 
F_APPEND - Static variable in interface com.sleepycat.asm.Opcodes
Represents a compressed frame where locals are the same as the locals in the previous frame, except that additional 1-3 locals are defined, and with an empty stack.
F_CHOP - Static variable in interface com.sleepycat.asm.Opcodes
Represents a compressed frame where locals are the same as the locals in the previous frame, except that the last 1-3 locals are absent and with an empty stack.
F_FULL - Static variable in interface com.sleepycat.asm.Opcodes
Represents a compressed frame with complete frame data.
F_NEW - Static variable in interface com.sleepycat.asm.Opcodes
Represents an expanded frame.
F_SAME - Static variable in interface com.sleepycat.asm.Opcodes
Represents a compressed frame with exactly the same locals as the previous frame and with an empty stack.
F_SAME1 - Static variable in interface com.sleepycat.asm.Opcodes
Represents a compressed frame with exactly the same locals as the previous frame and with a single value on the stack.
FADD - Static variable in interface com.sleepycat.asm.Opcodes
 
fail(String) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
FAIL_RESP - Variable in class com.sleepycat.je.rep.impl.TextProtocol
 
FALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
FastInputStream - Class in com.sleepycat.util
A replacement for ByteArrayInputStream that does not synchronize every byte read.
FastInputStream(byte[]) - Constructor for class com.sleepycat.util.FastInputStream
Creates an input stream.
FastInputStream(byte[], int, int) - Constructor for class com.sleepycat.util.FastInputStream
Creates an input stream.
FASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
FastOutputStream - Class in com.sleepycat.util
A replacement for ByteArrayOutputStream that does not synchronize every byte read.
FastOutputStream() - Constructor for class com.sleepycat.util.FastOutputStream
Creates an output stream with default sizes.
FastOutputStream(int) - Constructor for class com.sleepycat.util.FastOutputStream
Creates an output stream with a default bump size and a given initial size.
FastOutputStream(int, int) - Constructor for class com.sleepycat.util.FastOutputStream
Creates an output stream with a given bump size and initial size.
FastOutputStream(byte[]) - Constructor for class com.sleepycat.util.FastOutputStream
Creates an output stream with a given initial buffer and a default bump size.
FastOutputStream(byte[], int) - Constructor for class com.sleepycat.util.FastOutputStream
Creates an output stream with a given initial buffer and a given bump size.
FCMPG - Static variable in interface com.sleepycat.asm.Opcodes
 
FCMPL - Static variable in interface com.sleepycat.asm.Opcodes
 
FCONST_0 - Static variable in interface com.sleepycat.asm.Opcodes
 
FCONST_1 - Static variable in interface com.sleepycat.asm.Opcodes
 
FCONST_2 - Static variable in interface com.sleepycat.asm.Opcodes
 
FDIV - Static variable in interface com.sleepycat.asm.Opcodes
 
Feeder - Class in com.sleepycat.je.rep.impl.node
There is an instance of a Feeder for each client that needs a replication stream.
Feeder(FeederManager, SocketChannel) - Constructor for class com.sleepycat.je.rep.impl.node.Feeder
 
Feeder() - Constructor for class com.sleepycat.je.rep.impl.node.Feeder
 
Feeder.ExitException - Exception in com.sleepycat.je.rep.impl.node
A marker exception that wraps the real exception.
Feeder.ExitException(String) - Constructor for exception com.sleepycat.je.rep.impl.node.Feeder.ExitException
 
Feeder.ExitException(Throwable) - Constructor for exception com.sleepycat.je.rep.impl.node.Feeder.ExitException
 
FEEDER_HEARTBEAT_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
FEEDER_INFO_REQ - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
FEEDER_INFO_RESP - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
FEEDER_JE_VERSIONS - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
FEEDER_PROTOCOL_VERSION - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
FEEDER_SERVICE - Static variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
FEEDER_SERVICE - Static variable in class com.sleepycat.je.rep.impl.node.FeederManager
 
FEEDER_TCP_NO_DELAY - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
FEEDER_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
FEEDER_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
A heartbeat is exchanged between the feeder and replica to ensure they are alive.
FeederManager - Class in com.sleepycat.je.rep.impl.networkRestore
Manages the multiple log file feeders that may be servicing requests from multiple clients requesting log files.
FeederManager(ServiceDispatcher, EnvironmentImpl, NameIdPair) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.FeederManager
Creates a FeederManager but does not start it.
FeederManager - Class in com.sleepycat.je.rep.impl.node
FeedManager is responsible for the creation and management of the Feeders used to respond to connections initiated by a Replica.
FeederManager(RepNode) - Constructor for class com.sleepycat.je.rep.impl.node.FeederManager
 
feederManager() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
FeederManager.Lease - Class in com.sleepycat.je.rep.impl.networkRestore
Provides the lease mechanism used to maintain a handle to the DbBackup object across Server client disconnects.
FeederManager.Lease(int, long, DbBackup) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.FeederManager.Lease
 
FeederManagerStatDefinition - Class in com.sleepycat.je.rep.impl.node
Per-stat Metadata for HA Replay statistics.
FeederManagerStatDefinition() - Constructor for class com.sleepycat.je.rep.impl.node.FeederManagerStatDefinition
 
FeederReader - Class in com.sleepycat.je.rep.stream
The FeederReader is a flavor of VLSNReader which supports replication stream feeding.
FeederReader(EnvironmentImpl, VLSNIndex, long, int, NameIdPair) - Constructor for class com.sleepycat.je.rep.stream.FeederReader
 
FeederReader(EnvironmentImpl, VLSNIndex, long, int) - Constructor for class com.sleepycat.je.rep.stream.FeederReader
For unit testing only!! Bypass the VLSNIndex cache, provide a node name.
FeederReader.SwitchWindow - Class in com.sleepycat.je.rep.stream
The SwitchWindow can fill itself from either the log file or the log buffers.
FeederReader.SwitchWindow(int, EnvironmentImpl) - Constructor for class com.sleepycat.je.rep.stream.FeederReader.SwitchWindow
 
FeederReplicaHandshake - Class in com.sleepycat.je.rep.stream
Implements the Feeder side of the handshake between the Feeder and the Replica.
FeederReplicaHandshake(RepNode, Feeder, NamedChannel) - Constructor for class com.sleepycat.je.rep.stream.FeederReplicaHandshake
An instance of this class is created with each new handshake preceding the setting up of a connection.
FeederReplicaSyncup - Class in com.sleepycat.je.rep.stream
Establish where the replication stream should start for a feeder and replica pair.
FeederReplicaSyncup(Feeder, NamedChannel, Protocol) - Constructor for class com.sleepycat.je.rep.stream.FeederReplicaSyncup
 
FeederReplicaSyncup.NetworkRestoreException - Exception in com.sleepycat.je.rep.stream
 
FeederReplicaSyncup.NetworkRestoreException(VLSN, VLSN, VLSN, NameIdPair) - Constructor for exception com.sleepycat.je.rep.stream.FeederReplicaSyncup.NetworkRestoreException
 
feeders - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
FeederSource - Interface in com.sleepycat.je.rep.stream
Provides the next log record, blocking if one is not available.
FeederSyncupReader - Class in com.sleepycat.je.rep.stream
The FeederSyncupReader scans the log backwards for requested log entries.
FeederSyncupReader(EnvironmentImpl, VLSNIndex, long, int, NameIdPair, VLSN, long) - Constructor for class com.sleepycat.je.rep.stream.FeederSyncupReader
 
FeederTxns - Class in com.sleepycat.je.rep.stream
FeederTxns manages transactions that need acknowledgments.
FeederTxns(RepImpl) - Constructor for class com.sleepycat.je.rep.stream.FeederTxns
 
FeederTxnStatDefinition - Class in com.sleepycat.je.rep.stream
Per-stat Metadata for HA Feeder Transaction statistics.
FeederTxnStatDefinition() - Constructor for class com.sleepycat.je.rep.stream.FeederTxnStatDefinition
 
FETCH_COUNT - Static variable in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackupStatDefinition
 
fetchAndInsertIntoTree() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
fetchLNSize(int, long) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Fetches the LN to get its size only if necessary and so configured.
fetchLSN(long, DatabaseEntry, LSNAccumulator) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
fetchObsoleteSize - Variable in class com.sleepycat.je.cleaner.Cleaner
 
fetchTarget(int) - Method in class com.sleepycat.je.tree.BIN
We require exclusive latches on a BIN, so this method does not need to declare that it throws RelatchRequiredException.
fetchTarget(DatabaseImpl, IN) - Method in class com.sleepycat.je.tree.ChildReference
Fetch the target object that this ChildReference refers to.
fetchTarget(int) - Method in class com.sleepycat.je.tree.IN
Returns the target of the idx'th entry or null if a pendingDeleted or knownDeleted entry has been cleaned.
fetchTargetWithExclusiveLatch(int) - Method in class com.sleepycat.je.tree.IN
Variant of fetchTarget that is called while holding an exclusive latch and therefore does not throw RelatchRequiredException.
FIELD - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_Fieldref constant pool items.
FieldConverter - Interface in com.sleepycat.je.sync
Provides custom conversion between local field/property values and external field/column values.
FieldInfo - Class in com.sleepycat.persist.impl
A field definition used by ComplexFormat and CompositeKeyFormat.
FieldMetadata - Class in com.sleepycat.persist.model
The metadata for a key field.
FieldMetadata(String, String, String) - Constructor for class com.sleepycat.persist.model.FieldMetadata
Used by an EntityModel to construct field metadata.
FIELDORMETH_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of field and method invocations instructions.
FieldVisitor - Class in com.sleepycat.asm
A visitor to visit a Java field.
FieldVisitor(int) - Constructor for class com.sleepycat.asm.FieldVisitor
Constructs a new FieldVisitor.
FieldVisitor(int, FieldVisitor) - Constructor for class com.sleepycat.asm.FieldVisitor
Constructs a new FieldVisitor.
FieldWriter - Class in com.sleepycat.asm
An FieldVisitor that generates Java fields in bytecode form.
FieldWriter(ClassWriter, int, String, String, String, Object) - Constructor for class com.sleepycat.asm.FieldWriter
Constructs a new FieldWriter.
FILE_END - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
FILE_INFO_REQ - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
FILE_INFO_RESP - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
FILE_LIST_REQ - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
FILE_LIST_RESP - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
FILE_LOGGING_LEVEL - Static variable in class com.sleepycat.je.EnvironmentConfig
Trace messages equal and above this level will be logged to the je.info file, which is in the Environment home directory.
FILE_REQ - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
FILE_START - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
fileChosenHook - Variable in class com.sleepycat.je.cleaner.Cleaner
 
FileHandle - Class in com.sleepycat.je.log
A FileHandle embodies a File and its accompanying latch.
FileHandle(long, String) - Constructor for class com.sleepycat.je.log.FileHandle
Creates a new handle but does not initialize it.
FileHandler - Class in com.sleepycat.je.util
JE instances of java.util.logging.Logger are configured to use this implementation of java.util.logging.FileHandler.
FileHandler(String, int, int, Formatter, EnvironmentImpl) - Constructor for class com.sleepycat.je.util.FileHandler
 
FILEHANDLER_LEVEL - Static variable in class com.sleepycat.je.jmx.JEDiagnostics
 
FileHandleSource - Class in com.sleepycat.je.log
FileHandleSource is a file source built on top of a cached file handle.
FileHandleSource(FileHandle, int, FileManager) - Constructor for class com.sleepycat.je.log.FileHandleSource
 
FileHeader - Class in com.sleepycat.je.log
A FileHeader embodies the header information at the beginning of each log file.
FileHeader(long, long) - Constructor for class com.sleepycat.je.log.FileHeader
 
FileHeader() - Constructor for class com.sleepycat.je.log.FileHeader
For logging only.
FileHeaderEntry - Class in com.sleepycat.je.log.entry
Contains a FileHeader entry.
FileHeaderEntry(Class<?>) - Constructor for class com.sleepycat.je.log.entry.FileHeaderEntry
Construct a log entry for reading.
FileHeaderEntry(LogEntryType, Loggable) - Constructor for class com.sleepycat.je.log.entry.FileHeaderEntry
Construct a log entry for writing.
fileLength - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
FileManager - Class in com.sleepycat.je.log
The FileManager presents the abstraction of one contiguous file.
FileManager(EnvironmentImpl, File, boolean) - Constructor for class com.sleepycat.je.log.FileManager
Set up the file cache and initialize the file manager to point to the beginning of the log.
fileManager - Variable in class com.sleepycat.je.log.FileReader
 
fileManager - Variable in class com.sleepycat.je.log.FileReader.ReadWindow
 
FileManager.FileMode - Enum in com.sleepycat.je.log
 
FileManager.LogEndFileDescriptor - Class in com.sleepycat.je.log
The LogEndFileDescriptor is used to write and fsync the end of the log.
FileManager.LogEndFileDescriptor() - Constructor for class com.sleepycat.je.log.FileManager.LogEndFileDescriptor
 
FILEMGR_BYTES_READ_FROM_WRITEQUEUE - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_BYTES_WRITTEN_FROM_WRITEQUEUE - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_FILE_OPENS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_GROUP_DESC - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_GROUP_NAME - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_LOG_FSYNCS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_OPEN_FILES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_RANDOM_READ_BYTES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_RANDOM_READS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_RANDOM_WRITE_BYTES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_RANDOM_WRITES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_READS_FROM_WRITEQUEUE - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_SEQUENTIAL_READ_BYTES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_SEQUENTIAL_READS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_SEQUENTIAL_WRITE_BYTES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_SEQUENTIAL_WRITES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_WRITEQUEUE_OVERFLOW - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_WRITEQUEUE_OVERFLOW_FAILURES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FILEMGR_WRITES_FROM_WRITEQUEUE - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
fileName - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileReq
 
fileName - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
fileNum - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.TestAdjustment
 
FileProcessor - Class in com.sleepycat.je.cleaner
Reads all entries in a log file and either determines them to be obsolete or marks them for migration.
FileProcessor(String, EnvironmentImpl, Cleaner, UtilizationProfile, UtilizationCalculator, FileSelector) - Constructor for class com.sleepycat.je.cleaner.FileProcessor
 
FileReader - Class in com.sleepycat.je.log
A FileReader is an abstract class that traverses the log files, reading in chunks of the file at a time.
FileReader(EnvironmentImpl, int, boolean, long, Long, long, long) - Constructor for class com.sleepycat.je.log.FileReader
A FileReader just needs to know what size chunks to read in.
FileReader.EOFException - Exception in com.sleepycat.je.log
Never seen by user, used to indicate that the file reader should stop.
FileReader.EOFException() - Constructor for exception com.sleepycat.je.log.FileReader.EOFException
 
FileReader.EOFException(String) - Constructor for exception com.sleepycat.je.log.FileReader.EOFException
 
FileReader.ReadWindow - Class in com.sleepycat.je.log
A ReadWindow provides a swathe of data read from the JE log.
FileReader.ReadWindow(int, EnvironmentImpl) - Constructor for class com.sleepycat.je.log.FileReader.ReadWindow
 
FileRedirectHandler - Class in com.sleepycat.je.utilint
Redirects logging messages to the the owning environment's file handler, so that messages can be prefixed with an environment name and sent to the correct logging file.
FileRedirectHandler() - Constructor for class com.sleepycat.je.utilint.FileRedirectHandler
 
FileSelector - Class in com.sleepycat.je.cleaner
Keeps track of the status of files for which cleaning is in progres.
FileSelector() - Constructor for class com.sleepycat.je.cleaner.FileSelector
 
FileSelector.CheckpointStartCleanerState - Class in com.sleepycat.je.cleaner
Holds copy of all checkpoint-dependent cleaner state.
filesExist() - Method in class com.sleepycat.je.log.FileManager
 
FileSource - Class in com.sleepycat.je.log
FileSource is used as a channel to a log file when faulting in objects from the log.
FileSource(RandomAccessFile, int, FileManager, long, int) - Constructor for class com.sleepycat.je.log.FileSource
 
FilesToMigrate - Class in com.sleepycat.je.cleaner
Iterator over files that should be migrated by cleaning them, even if they don't need to be cleaned for other reasons.
FilesToMigrate(EnvironmentImpl) - Constructor for class com.sleepycat.je.cleaner.FilesToMigrate
 
FileSummary - Class in com.sleepycat.je.cleaner
Per-file utilization counters.
FileSummary() - Constructor for class com.sleepycat.je.cleaner.FileSummary
Creates an empty summary.
FileSummaryLN - Class in com.sleepycat.je.tree
A FileSummaryLN represents a Leaf Node in the UtilizationProfile database.
FileSummaryLN(FileSummary) - Constructor for class com.sleepycat.je.tree.FileSummaryLN
Creates a new LN with a given base summary.
FileSummaryLN() - Constructor for class com.sleepycat.je.tree.FileSummaryLN
Creates an empty LN to be filled in from the log.
FILESUMMARYLN_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
fillDataEntry(DatabaseEntry) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
FILLED_CACHE - Static variable in class com.sleepycat.je.PreloadStatus
Database.preload filled maxBytes of the cache.
fillFromFile(FileHandle, long) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
fillInEnvironmentGeneratedProps(EnvironmentImpl) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Fills in the properties calculated by the environment to the given config object.
fillInEnvironmentGeneratedProps(RepImpl) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Fills in the properties calculated by the environment to the given config object.
fillInStackTrace() - Method in exception com.sleepycat.je.rep.vlsn.VLSNIndex.WaitTimeOutException
 
fillInStackTrace() - Method in exception com.sleepycat.je.utilint.RelatchRequiredException
 
fillNext(boolean, int) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
Fill up the read buffer with more data, moving along to the following file (next largest number) if needed.
fillNext(boolean, int) - Method in class com.sleepycat.je.rep.stream.FeederReader.SwitchWindow
Fill up the read buffer with more data, moving along to the following file (next largest number) if needed.
findBinForInsert(byte[], CursorImpl) - Method in class com.sleepycat.je.tree.Tree
Find the BIN that is relevant to the insert.
findBoth(Object, Object, boolean) - Method in class com.sleepycat.collections.DataCursor
Find the given key and value using getSearchBoth if possible or a sequential scan otherwise, no join cursor allowed.
findEntry(byte[], boolean, boolean) - Method in class com.sleepycat.je.tree.IN
 
findEntry(byte[], boolean, boolean, Comparator<byte[]>) - Method in class com.sleepycat.je.tree.IN
Find the entry in this IN for which key is LTE the key arg.
findMaster(Protocol, Set<InetSocketAddress>, Logger, RepImpl, Formatter) - Static method in class com.sleepycat.je.rep.elections.Learner
Returns the socket address for the current master, or null if one could not be determined from the available set of learners.
findParent(Tree.SearchType, long, boolean, byte[], SearchResult, boolean, CacheMode, int, boolean) - Method in class com.sleepycat.je.tree.IN
Determine if 'this' is the parent of a child IN (targetNodeId).
findPrevSyncEntry() - Method in class com.sleepycat.je.rep.stream.ReplicaSyncupReader
Backward scanning for finding an earlier candidate syncup matchpoint.
findPrimaryDatabase() - Method in class com.sleepycat.je.dbi.DatabaseImpl
For this secondary database return the primary that it is associated with, or null if not associated with any primary.
findTarget(long, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
findType(byte) - Static method in class com.sleepycat.je.log.LogEntryType
 
findValue(Object, boolean) - Method in class com.sleepycat.collections.DataCursor
Find the given value using getSearchBoth if possible or a sequential scan otherwise, no join cursor allowed.
fine(Logger, EnvironmentImpl, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
finer(Logger, EnvironmentImpl, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
finest(Logger, EnvironmentImpl, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
finish() - Method in class com.sleepycat.utilint.ActivityCounter
 
finishDeleteProcessing() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Release the INs for the deleted database, count all log entries for this database as obsolete, delete the MapLN, and set the state to DELETED.
finishedINListHarvest() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Should be called by the SortedLSNTreeWalker when it is finished with the INList.
finishEvolution() - Method in class com.sleepycat.persist.impl.Evolver
Called by PersistCatalog after calling evolveFormat or addNonEntityFormat for all old formats.
finishInit(EnvironmentConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Initialize the environment, including running recovery, if it is not already initialized.
first() - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns the first (lowest) element currently in this sorted set.
first() - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns the first (lowest) element currently in this sorted set.
first() - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns the first (lowest) element currently in this sorted set.
first() - Method in class com.sleepycat.persist.BasicCursor
 
first(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
first() - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the first value and returns it, or returns null if the cursor range is empty.
first(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the first value and returns it, or returns null if the cursor range is empty.
FIRST_LOCAL_NODE_ID - Static variable in class com.sleepycat.je.dbi.NodeSequence
 
FIRST_LOG_VERSION - Static variable in class com.sleepycat.je.log.LogEntryType
 
FIRST_REPLICATED_NODE_ID - Static variable in class com.sleepycat.je.dbi.NodeSequence
 
FIRST_VLSN - Static variable in class com.sleepycat.je.utilint.VLSN
 
firstActiveLsn - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
firstField - Variable in class com.sleepycat.asm.ClassWriter
The fields of this class.
firstKey() - Method in class com.sleepycat.collections.StoredSortedMap
Returns the first (lowest) key currently in this sorted map.
firstLogEntryOffset() - Static method in class com.sleepycat.je.log.FileManager
 
firstLoggedLsn - Variable in class com.sleepycat.je.txn.Txn
 
firstMethod - Variable in class com.sleepycat.asm.ClassWriter
The methods of this class.
firstVLSN - Variable in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
FIXED_PREFIX - Static variable in class com.sleepycat.je.utilint.LoggerUtils
 
FLAGS_OFFSET - Static variable in class com.sleepycat.je.log.LogEntryHeader
 
FLOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
FLOAT - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_Float constant pool items.
FLOAT - Static variable in class com.sleepycat.asm.Frame
The FLOAT type.
FLOAT - Static variable in interface com.sleepycat.asm.Opcodes
 
FLOAT - Static variable in class com.sleepycat.asm.Type
The sort of the float type.
FLOAT_TYPE - Static variable in class com.sleepycat.asm.Type
The float type.
FloatBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for an unsorted Float primitive wrapper or an unsorted float primitive.
FloatBinding() - Constructor for class com.sleepycat.bind.tuple.FloatBinding
 
FloatStat - Class in com.sleepycat.je.utilint
A Float JE stat.
FloatStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.FloatStat
 
FloatStat(StatGroup, StatDefinition, float) - Constructor for class com.sleepycat.je.utilint.FloatStat
 
floatToEntry(float, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.FloatBinding
Converts a simple float value into an entry buffer.
floatToEntry(float, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedFloatBinding
Converts a simple float value into an entry buffer.
flush() - Method in class com.sleepycat.je.log.LogManager
Flush all log entries, fsync the log file.
flush() - Method in class com.sleepycat.je.utilint.ConfiguredRedirectHandler
 
flush() - Method in class com.sleepycat.je.utilint.FileRedirectHandler
 
flush(Transaction) - Method in class com.sleepycat.persist.impl.PersistCatalog
Used to write the catalog when a format has been changed, for example, when Store.evolve has updated a Format's EvolveNeeded property.
flushFileSummary(TrackedFileSummary) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Updates and stores the FileSummary for a given tracked file, if flushing of the summary is allowed.
flushFileUtilization(Collection<TrackedFileSummary>) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Flush a FileSummaryLN node for each given TrackedFileSummary.
flushInternal(boolean) - Method in class com.sleepycat.je.log.LogManager
 
flushInternal(boolean) - Method in class com.sleepycat.je.log.SyncedLogManager
 
flushLocalTracker(LocalUtilizationTracker) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Count the given locally tracked info as obsolete and then log the file and database info.
flushLog(boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Flush the log buffers and write to the log, and optionally fsync.
flushLog(boolean) - Method in class com.sleepycat.je.Environment
Writes buffered data to the log, and optionally performs an fsync to guarantee that data is written to the physical device.
flushMapLNs(long) - Method in class com.sleepycat.je.recovery.DirtyINMap
Flushes all saved dirty/temp MapLNs and clears the saved set.
flushNoSync() - Method in class com.sleepycat.je.log.LogManager
May be used to avoid sync, for unit tests and for rep syncup.
flushRequired - Variable in class com.sleepycat.je.log.LogContext
Whether the log buffer(s) must be written to the file system.
flushRoot(long) - Method in class com.sleepycat.je.recovery.DirtyINMap
Flushes the DB mapping tree root at the end of the checkpoint, if either mapping DB is dirty and the root was not flushed previously during the checkpoint.
flushToDatabase(Durability) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Mappings are flushed to disk at close, and at checkpoints.
flushToDatabase(DatabaseImpl, Txn) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
Flush the tracker cache to disk.
flushWaiter(Locker, MemoryBudget, int) - Method in interface com.sleepycat.je.txn.Lock
Remove this locker from the waiter list.
flushWaiter(Locker, MemoryBudget, int) - Method in class com.sleepycat.je.txn.LockImpl
Remove this locker from the waiter list.
flushWaiter(Locker, MemoryBudget, int) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
flushWriteNoSync() - Method in class com.sleepycat.je.log.LogManager
Flush all log entries and write to the log but do not fsync.
FMUL - Static variable in interface com.sleepycat.asm.Opcodes
 
FNEG - Static variable in interface com.sleepycat.asm.Opcodes
 
follows(long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
follows(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
follows(VLSN) - Method in class com.sleepycat.je.utilint.VLSN
Return true if this VLSN's sequence directly follows the "other" VLSN.
force(Set<Long>) - Method in class com.sleepycat.je.log.FileManager
Fsync this set of log files.
forceLogFileFlip() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Flip the log to a new file, forcing an fsync.
forceMaster(boolean) - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
forceMaster(boolean) - Method in class com.sleepycat.je.rep.stream.MasterSuggestionGenerator
This entry point is for testing only.
forceNewLogFile() - Method in class com.sleepycat.je.log.FileManager
Set the flag that causes a new file to be written before the next write.
forceNewLogFile - Variable in class com.sleepycat.je.log.LogContext
Whether a new log file must be created for containing the logged item(s).
forceTreeWalkForTruncateAndRemove - Static variable in class com.sleepycat.je.dbi.DatabaseImpl
For unit testing, setting this field to true will force a walk of the tree to count utilization during truncate/remove, rather than using the per-database info.
forceTripLatches(DatabaseException) - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
Frees all the threads that are waiting on latches.
ForeignConstraintException - Exception in com.sleepycat.je
Thrown when an attempt to write a primary database record would insert a secondary record with a key that does not exist in a foreign key database, when the secondary key is configured as a foreign key.
ForeignConstraintException(Locker, String, String, DatabaseEntry, DatabaseEntry) - Constructor for exception com.sleepycat.je.ForeignConstraintException
For internal use only.
ForeignKeyDeleteAction - Enum in com.sleepycat.je
The action taken when a referenced record in the foreign key database is deleted.
ForeignKeyNullifier - Interface in com.sleepycat.je
The interface implemented for setting single-valued foreign keys to null.
ForeignKeyTrigger - Class in com.sleepycat.je
 
ForeignKeyTrigger(SecondaryDatabase) - Constructor for class com.sleepycat.je.ForeignKeyTrigger
 
ForeignMultiKeyNullifier - Interface in com.sleepycat.je
The interface implemented for setting multi-valued foreign keys to null.
forget(Xid) - Method in class com.sleepycat.je.XAEnvironment
 
format(String) - Method in class com.sleepycat.je.log.StatsFileReader.CheckpointInfoCSVFormatter
 
format(int) - Method in class com.sleepycat.je.log.StatsFileReader.CheckpointInfoCSVFormatter
 
format(long) - Method in class com.sleepycat.je.log.StatsFileReader.CheckpointInfoCSVFormatter
 
format(String) - Method in class com.sleepycat.je.log.StatsFileReader.CheckpointInfoTextFormatter
 
format(int) - Method in class com.sleepycat.je.log.StatsFileReader.CheckpointInfoTextFormatter
 
format(long) - Method in class com.sleepycat.je.log.StatsFileReader.CheckpointInfoTextFormatter
 
FORMAT - Static variable in class com.sleepycat.je.utilint.Stat
 
format(LogRecord) - Method in class com.sleepycat.je.utilint.TracerFormatter
Format the log record in this form:
Format - Class in com.sleepycat.persist.impl
The base class for all object formats.
Format(Catalog, Class) - Constructor for class com.sleepycat.persist.impl.Format
Creates a new format for a given class.
Format(Catalog, String) - Constructor for class com.sleepycat.persist.impl.Format
Creates a format for class evolution when no class may be present.
format - Variable in class com.sleepycat.persist.impl.KeyLocation
 
formatDuration(long, TimeUnit) - Static method in class com.sleepycat.je.utilint.PropUtil
Formats a String duration property (time + optional unit).
formatEntry(StringBuilder, byte[], boolean) - Static method in class com.sleepycat.je.utilint.CmdUtil
 
formatLong(long) - Static method in class com.sleepycat.je.utilint.HexFormatter
 
formatter - Variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
formatter - Variable in class com.sleepycat.je.rep.elections.ElectionAgentThread
 
formatter - Variable in class com.sleepycat.je.rep.elections.Proposer
 
formatter - Variable in class com.sleepycat.je.rep.impl.TextProtocol
 
formatter - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
formatterMap - Static variable in class com.sleepycat.je.utilint.LoggerUtils
 
FormatterRedirectHandler - Class in com.sleepycat.je.utilint
Redirect the ConsoleHandler to use a specific Formatter.
FormatterRedirectHandler() - Constructor for class com.sleepycat.je.utilint.FormatterRedirectHandler
 
formatUsingPrintable - Variable in class com.sleepycat.je.util.DbDump
 
forward - Variable in class com.sleepycat.je.log.FileReader
 
ForwardCursor - Interface in com.sleepycat.je
The interface for forward-moving Cursor operations.
ForwardCursor<V> - Interface in com.sleepycat.persist
Cursor operations limited to traversing forward.
FOUND - Static variable in class com.sleepycat.je.dbi.CursorImpl
 
FOUND_LAST - Static variable in class com.sleepycat.je.dbi.CursorImpl
 
Frame - Class in com.sleepycat.asm
Information about the input and output stack map frames of a basic block.
Frame() - Constructor for class com.sleepycat.asm.Frame
 
frame - Variable in class com.sleepycat.asm.Label
Information about the input and output stack map frames of this basic block.
FRAMES - Static variable in class com.sleepycat.asm.ClassReader
True to enable stack map frames support.
FreePortLocator - Class in com.sleepycat.je.rep.utilint
An iterator to iterate over the free ports on an interface.
FreePortLocator(String, int, int) - Constructor for class com.sleepycat.je.rep.utilint.FreePortLocator
Constructor identifying the interface and the port range within which to look for free ports.
freeze(Proposer.Proposal) - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
Initiates or extends a freeze on a VLSN in response to a new election that is in progress.
freezeLocalCBVLSN() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
freezeLocalCBVLSN() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
freezeLocalCBVLSN() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
FREM - Static variable in interface com.sleepycat.asm.Opcodes
 
FRETURN - Static variable in interface com.sleepycat.asm.Opcodes
 
fromASCII(byte[]) - Static method in class com.sleepycat.utilint.StringUtils
 
fromASCII(byte[], int, int) - Static method in class com.sleepycat.utilint.StringUtils
 
fromUTF8(byte[]) - Static method in class com.sleepycat.utilint.StringUtils
 
fromUTF8(byte[], int, int) - Static method in class com.sleepycat.utilint.StringUtils
 
FS_GROUP_DESC - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
FS_GROUP_NAME - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
FSTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
FSUB - Static variable in interface com.sleepycat.asm.Opcodes
 
fsync() - Method in class com.sleepycat.je.log.FSyncManager
Request that this file be fsynced to disk.
FSyncManager - Class in com.sleepycat.je.log
 
FSyncManager(EnvironmentImpl) - Constructor for class com.sleepycat.je.log.FSyncManager
 
FSyncManager.FSyncGroup - Class in com.sleepycat.je.log
 
FSyncManager.FSyncGroup(long, EnvironmentImpl) - Constructor for class com.sleepycat.je.log.FSyncManager.FSyncGroup
 
FSYNCMGR_FSYNC_REQUESTS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FSYNCMGR_FSYNC_TIME - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FSYNCMGR_FSYNC_TIMEOUTS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FSYNCMGR_FSYNCS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FSYNCMGR_GROUP_DESC - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
FSYNCMGR_GROUP_NAME - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
fsyncRequired - Variable in class com.sleepycat.je.log.LogContext
Whether an fsync must be performed after writing the item(s) to the log.
FULL_FRAME - Static variable in class com.sleepycat.asm.MethodWriter
Full frame
fun(E) - Method in class com.sleepycat.je.dbi.TriggerManager.MapOver
 
fv - Variable in class com.sleepycat.asm.FieldVisitor
The field visitor to which this visitor must delegate method calls.

G

gatherDataDirs() - Method in class com.sleepycat.je.log.FileManager
 
generateId(TxnManager, long) - Method in class com.sleepycat.je.rep.txn.MasterTxn
MasterTxns use txn ids from a reserved negative space.
generateId(TxnManager, long) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
Replay transactions always use the txn id that is included in its replicated operation.
generateId(TxnManager, long) - Method in class com.sleepycat.je.txn.BasicLocker
BasicLockers always have a fixed id, because they are never used for recovery.
generateId(TxnManager, long) - Method in class com.sleepycat.je.txn.Locker
A Locker has to generate its next id.
generateId(TxnManager, long) - Method in class com.sleepycat.je.txn.PreparedTxn
PrepareTxns use the mandated id.
generateId(TxnManager, long) - Method in class com.sleepycat.je.txn.Txn
UserTxns get a new unique id for each instance.
generateKey(String, String, SyncDB.DataType) - Static method in class com.sleepycat.je.sync.impl.SyncDB
 
generateTips() - Method in class com.sleepycat.je.jmx.plugin.JEStats
 
generateTips() - Method in class com.sleepycat.je.jmx.plugin.Stats
 
generateTips() - Method in class com.sleepycat.je.rep.jmx.plugin.RepJEStats
 
Generation - Class in com.sleepycat.je.tree
 
Generation() - Constructor for class com.sleepycat.je.tree.Generation
 
genSecondaryConfigMismatchMessage(DatabaseConfig, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class com.sleepycat.je.SecondaryConfig
 
get(int) - Method in class com.sleepycat.collections.StoredList
Returns the element at the specified position in this list.
get(Object) - Method in class com.sleepycat.collections.StoredMap
Returns the value to which this map maps the specified key.
get(Long, boolean, boolean, FileManager) - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
Returns the DbFileSummary for the given file, allocating it if necessary.
get(int) - Method in class com.sleepycat.je.cleaner.OffsetList.Segment
Returns the value at the given index from this segment only.
get(Transaction, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Database
Retrieves the key/data pair with the given key.
get(ConfigParam) - Method in class com.sleepycat.je.dbi.DbConfigManager
Get this parameter from the environment wide configuration settings.
get(String) - Method in class com.sleepycat.je.dbi.DbConfigManager
Get this parameter from the environment wide configuration settings.
get(DatabaseImpl) - Method in interface com.sleepycat.je.dbi.DbTree.GetRepContext
 
get(Proposer.Proposal) - Method in interface com.sleepycat.je.rep.elections.Acceptor.SuggestionGenerator
Used to generate a suggested value for use by a Proposer.
get(DatabaseId, Txn) - Method in class com.sleepycat.je.rep.impl.node.DbCache
Returns the DatabaseImpl associated with the dbId, caching the return value, if it's not already cached.
get(Proposer.Proposal) - Method in class com.sleepycat.je.rep.stream.MasterSuggestionGenerator
 
get(RepNode, int) - Static method in class com.sleepycat.je.rep.stream.Protocol
Returns a protocol object that supports the specific requested version.
get(long) - Method in class com.sleepycat.je.rep.util.ldiff.BlockBag
Returns all Blocks in the bag with a given checksum.
get() - Method in class com.sleepycat.je.rep.utilint.LongMaxZeroStat
 
get() - Method in class com.sleepycat.je.rep.utilint.LongMinZeroStat
 
get(int) - Static method in enum com.sleepycat.je.rep.utilint.ServiceDispatcher.Response
 
get(Object) - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
get(VLSN) - Method in class com.sleepycat.je.rep.vlsn.LogItemCache
 
get(Transaction, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryDatabase
 
get(Transaction, DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryDatabase
Retrieves the key/data pair with the given key.
get(Transaction, int) - Method in class com.sleepycat.je.Sequence
Returns the next available element in the sequence and changes the sequence value by delta.
get(int) - Method in class com.sleepycat.je.tree.INArrayRep
Returns the element at idx.
get(int) - Method in class com.sleepycat.je.tree.INKeyRep.Default
 
get(int) - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
get(int) - Method in class com.sleepycat.je.tree.INTargetRep.Default
 
get(int) - Method in class com.sleepycat.je.tree.INTargetRep.None
 
get(int) - Method in class com.sleepycat.je.tree.INTargetRep.Sparse
 
get(int) - Method in class com.sleepycat.je.tree.VLSNCache.DefaultCache
 
get(int) - Method in class com.sleepycat.je.tree.VLSNCache
 
get() - Method in class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
get() - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
get() - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
get(long) - Method in class com.sleepycat.je.utilint.BitMap
 
get() - Method in class com.sleepycat.je.utilint.BooleanStat
 
get() - Method in class com.sleepycat.je.utilint.FloatStat
 
get() - Method in class com.sleepycat.je.utilint.IntStat
 
get() - Method in class com.sleepycat.je.utilint.LongArrayStat
 
get() - Method in class com.sleepycat.je.utilint.LongStat
 
get() - Method in class com.sleepycat.je.utilint.Stat
 
get() - Method in class com.sleepycat.je.utilint.StringStat
 
get(K) - Method in interface com.sleepycat.persist.EntityIndex
Gets an entity via a key of this index.
get(Transaction, K, LockMode) - Method in interface com.sleepycat.persist.EntityIndex
Gets an entity via a key of this index.
get(SK) - Method in class com.sleepycat.persist.KeysIndex
 
get(Transaction, SK, LockMode) - Method in class com.sleepycat.persist.KeysIndex
 
get(PK) - Method in class com.sleepycat.persist.PrimaryIndex
 
get(Transaction, PK, LockMode) - Method in class com.sleepycat.persist.PrimaryIndex
 
get(SK) - Method in class com.sleepycat.persist.SecondaryIndex
 
get(Transaction, SK, LockMode) - Method in class com.sleepycat.persist.SecondaryIndex
 
get(PK) - Method in class com.sleepycat.persist.SubIndex
 
get(Transaction, PK, LockMode) - Method in class com.sleepycat.persist.SubIndex
 
get95thPercent() - Method in class com.sleepycat.utilint.Latency
 
get99thPercent() - Method in class com.sleepycat.utilint.Latency
 
getAbortDb() - Method in class com.sleepycat.je.txn.WriteLockInfo
 
getAbortKnownDeleted() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getAbortKnownDeleted() - Method in class com.sleepycat.je.log.LNFileReader
Get last abort known deleted seen by the reader.
getAbortKnownDeleted() - Method in class com.sleepycat.je.txn.WriteLockInfo
 
getAbortLogSize() - Method in class com.sleepycat.je.txn.WriteLockInfo
 
getAbortLsn() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getAbortLsn() - Method in class com.sleepycat.je.log.LNFileReader
Get last abort LSN seen by the reader (may be null).
getAbortLsn() - Method in class com.sleepycat.je.txn.WriteLockInfo
 
getAcceptedValue() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
getAcceptor() - Method in class com.sleepycat.je.rep.elections.Elections
Returns the Acceptor associated with this node.
getAcceptorSockets() - Method in class com.sleepycat.je.rep.elections.Elections
Returns a current set of acceptor sockets.
getAcceptorSockets() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the sockets used by nodes running Acceptor agents, that is, just nodes which participate in elections and can become Masters.
getAccess() - Method in class com.sleepycat.asm.ClassReader
Returns the class's access flags (see Opcodes).
getAccessor(boolean) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getAccessor(boolean) - Method in class com.sleepycat.persist.impl.ConverterReader
 
getAccessor(boolean) - Method in class com.sleepycat.persist.impl.Format
 
getAccessor(boolean) - Method in interface com.sleepycat.persist.impl.Reader
 
getAckTxn(long) - Method in class com.sleepycat.je.rep.stream.FeederTxns
Returns the transaction if it's waiting for acknowledgments.
getAckWaitMs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The total time in milliseconds that the master spent waiting for the Durability.ReplicaAckPolicy to be satisfied during successful transaction commits.
getActiveFeederCount() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
Returns the number of feeders that are currently active with this node.
getActiveFeeders() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getActiveFeeders() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoResp
 
getActiveFeeders() - Method in class com.sleepycat.je.rep.NodeState
Returns the number of current active Feeders running on this node.
getActiveServers() - Method in exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.LoadThresholdExceededException
 
getActiveTransfer() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getActiveTxnArray(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getActiveTxnIds() - Method in class com.sleepycat.je.txn.RollbackStart
 
getActiveTxns() - Method in class com.sleepycat.je.rep.impl.node.Replay
 
getActiveTxns() - Method in class com.sleepycat.je.TransactionStats
Return the array of active transactions.
getAdditionalTreeMemorySize() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns the tree memory size that should be added to MAPLN_OVERHEAD.
getAdler32ChunkSize() - Static method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getAdminBytes() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes of JE cache used for log cleaning metadata and other administrative structures.
getAdminMemoryUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget
Used for unit testing.
getAggressive() - Method in class com.sleepycat.je.VerifyConfig
Returns true if the Environment.verify and Database.verify are configured to perform fine granularity consistency checking that includes verifying in memory constructs.
getAllElectableMembers() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the subset of Electable nodes in the group.
getAllFileNumbers() - Method in class com.sleepycat.je.log.FileManager
Get all JE file numbers.
getAllMemberIds() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the nodes ids associated with all the nodes that are members of the group.
getAllMembers(RepGroupImpl.Predicate) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
 
getAllowConvert(ReplicationConfig) - Static method in class com.sleepycat.je.rep.RepInternal
 
getAllowConvert() - Method in class com.sleepycat.je.rep.ReplicationConfig
For internal use only.
getAllowCreate() - Method in class com.sleepycat.je.DatabaseConfig
Returns true if the Environment.openDatabase method is configured to create the database if it does not already exist.
getAllowCreate() - Method in class com.sleepycat.je.EnvironmentConfig
Returns a flag that specifies if we may create this environment.
getAllowCreate() - Method in class com.sleepycat.je.SequenceConfig
Returns true if the Database.openSequence method is configured to create the sequence if it does not already exist.
getAllowCreate() - Method in class com.sleepycat.persist.StoreConfig
Returns whether creation of a new store is allowed.
getAllowed() - Method in class com.sleepycat.je.txn.LockConflict
This method is called first to determine whether the locks is allowed.
getAllowFlush() - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Returns whether this summary is allowed or prohibited from being flushed or evicted during cleaning.
getAllowNestedTransactions() - Method in class com.sleepycat.collections.TransactionRunner
Returns whether nested transactions will be created if run() is called when a transaction is already active for the current thread.
getAllowNewDataSets() - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
getAllowPopulate() - Method in class com.sleepycat.je.SecondaryConfig
Returns whether automatic population of the secondary is allowed.
getAllowRepConvert() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
True if ReplicationConfig set allowConvert as true.
getAllowRepConvert() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getAllRawTypes() - Method in class com.sleepycat.persist.impl.PersistCatalog
Returns all formats as RawTypes.
getAllRawTypes() - Method in class com.sleepycat.persist.model.EntityModel
Returns all versions of all known types.
getAllRawTypeVersions(String) - Method in class com.sleepycat.persist.model.EntityModel
Returns all known versions of type information for a given class name, or null if no persistent version of the class is known.
getAllSimpleFormats(ClassLoader) - Static method in class com.sleepycat.persist.impl.SimpleCatalog
 
getAllTypes() - Static method in class com.sleepycat.je.log.LogEntryType
Get a copy of all types for unit testing.
getAlternateWireRecord() - Method in class com.sleepycat.je.rep.stream.Protocol.AlternateMatchpoint
 
getAndClearMaxActivity() - Method in class com.sleepycat.utilint.ActivityCounter
 
getAndResetNReads() - Method in class com.sleepycat.je.log.FileReader
Returns the number of reads since the last time this method was called.
getAndResetNReads() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
Returns the number of reads since the last time this method was called.
getAndSortPendingLSNs() - Method in class com.sleepycat.je.dbi.LSNAccumulator
 
getAppOpenCount() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the count of environment handles that were opened explicitly by the application.
getApproximateLsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.ForwardVLSNScanner
When doing an approximate search, the target vlsn may be a non-mapped vlsn within a bucket, or it may be between two different buckets.
getAppState() - Method in interface com.sleepycat.je.rep.AppStateMonitor
Return a byte array which holds information about the application's state.
getAppState() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getAppState() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Return the application state that defined in user specified AppStateMonitor.
getAppState() - Method in class com.sleepycat.je.rep.NodeState
Returns the application state which is obtained via AppStateMonitor.getAppState().
getArg(String[], int) - Static method in class com.sleepycat.je.utilint.CmdUtil
 
getArgumentsAndReturnSizes(String) - Static method in class com.sleepycat.asm.Type
Computes the size of the arguments and of the return value of a method.
getArgumentsAndReturnSizes() - Method in class com.sleepycat.asm.Type
Returns the size of the arguments and of the return value of methods of this type.
getArgumentTypes(String) - Static method in class com.sleepycat.asm.Type
Returns the Java types corresponding to the argument types of the given method descriptor.
getArgumentTypes(Method) - Static method in class com.sleepycat.asm.Type
Returns the Java types corresponding to the argument types of the given method.
getArgumentTypes() - Method in class com.sleepycat.asm.Type
Returns the argument types of methods of this type.
getAtomicLong(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getAttribute(String) - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
getAttribute(Environment, String) - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Get an attribute value for the given environment.
getAttribute(String) - Method in class com.sleepycat.je.jmx.JEMonitor
 
getAttributeList() - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
getAttributeList() - Method in class com.sleepycat.je.jmx.JEMBean
Get attribute metadata for this MBean.
getAttributeList(Environment) - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Get MBean attribute metadata for this environment.
getAttributeList() - Method in class com.sleepycat.je.jmx.JEMonitor
 
getAttributes(String[]) - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
getAttributes(String[]) - Method in class com.sleepycat.je.jmx.JEMonitor
 
getAutoCommitNoSync() - Method in class com.sleepycat.je.SequenceConfig
Returns true if the auto-commit operations on the sequence are configure to not flush the transaction log..
getAutoCommitTransactionConfig() - Method in class com.sleepycat.persist.PrimaryIndex
 
getAutoCommitTransactionConfig() - Method in class com.sleepycat.persist.SecondaryIndex
 
getAutoCommitTxnConfig() - Method in class com.sleepycat.persist.impl.Store
 
getAvailableReplicas() - Method in exception com.sleepycat.je.rep.InsufficientReplicasException
Returns the set of Replicas that were in contact with the master at the time of the commit operation.
getAvg() - Method in class com.sleepycat.utilint.Latency
 
getAvgBatchCacheMode() - Method in class com.sleepycat.je.EnvironmentStats
Average units of work done in one eviction pass by operations that use an explicitly set CacheMode.
getAvgBatchCritical() - Method in class com.sleepycat.je.EnvironmentStats
Average units of work done in one eviction pass by operations that will cause the cache to go over budget.
getAvgBatchDaemon() - Method in class com.sleepycat.je.EnvironmentStats
Average units of work done in one eviction pass by JE daemon threads.
getAvgBatchEvictorThread() - Method in class com.sleepycat.je.EnvironmentStats
Average units of work done in one eviction pass by an evictor pool thread.
getAvgBatchManual() - Method in class com.sleepycat.je.EnvironmentStats
Average units of work done in one eviction pass by the Environment.evictMemory() method, which is called during Environment startup, or by application code.
getAvgBatchStatDef() - Method in enum com.sleepycat.je.evictor.Evictor.EvictionSource
 
getAvgObsoleteLNSizeNotCounted() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns the average size for LNs with sizes not counted, or NaN if there are no such LNs.
getAwaitElectionCount() - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
 
getAwaitTimeoutCount() - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
 
getBacklog() - Method in class com.sleepycat.je.cleaner.FileSelector
Returns the number of files waiting TO_BE_CLEANED.
getBackup() - Method in class com.sleepycat.je.rep.NetworkRestore
 
getBackupCount() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns a count of the number of in-progress DbBackups.
getBarrierState() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getBarrierTime() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl.BarrierState
 
getBaseClass() - Method in class com.sleepycat.bind.serial.SerialBinding
Returns the base class for this binding.
getBaseLNEntrySize(boolean) - Method in class com.sleepycat.je.log.entry.LNLogEntry
Method shared by LNLogEntry subclasses.
getBaseSummary() - Method in class com.sleepycat.je.tree.FileSummaryLN
Returns the base summary for the file that is stored in the LN.
getBdescriptor(Class) - Static method in class com.sleepycat.util.ConfigBeanInfoBase
 
getBeanDescriptor() - Method in class com.sleepycat.je.CheckpointConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.CursorConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.DatabaseConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.DiskOrderedCursorConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.EnvironmentConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.EnvironmentMutableConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.JoinConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.PreloadConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.rep.monitor.MonitorConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.rep.NetworkRestoreConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.rep.ReplicationConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.rep.ReplicationMutableConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.SecondaryConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.SequenceConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.StatsConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.TransactionConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.je.VerifyConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.persist.evolve.EvolveConfigBeanInfo
 
getBeanDescriptor() - Method in class com.sleepycat.persist.StoreConfigBeanInfo
 
getBeanDescriptor(Class) - Method in class com.sleepycat.util.ConfigBeanInfoBase
Gets the bean's BeanDescriptors.
getBeanProperties() - Method in class com.sleepycat.je.sync.RecordMapping
Returns true if local bean property names are used or false if local field names are used.
getBeginData() - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
getBeginData() - Method in class com.sleepycat.je.rep.util.ldiff.Window
 
getBeginKey() - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
getBeginKey() - Method in class com.sleepycat.je.rep.util.ldiff.Window
 
getBestFile(SortedMap<Long, FileSummary>, boolean, Set<Long>, boolean, boolean) - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Returns the best file that qualifies for cleaning or probing, or null if no file qualifies.
getBigDecimalByteLength() - Method in class com.sleepycat.bind.tuple.TupleInput
Returns the byte length of an unsorted BigDecimal.
getBigDecimalMaxByteLength(BigDecimal) - Static method in class com.sleepycat.bind.tuple.TupleOutput
Returns the maximum byte length that would be output for a given BigDecimal value if TupleOutput.writeBigDecimal(java.math.BigDecimal) were called.
getBigIntegerByteLength() - Method in class com.sleepycat.bind.tuple.TupleInput
Returns the byte length of a BigInteger.
getBigIntegerByteLength(BigInteger) - Static method in class com.sleepycat.bind.tuple.TupleOutput
Returns the exact byte length that would would be output for a given BigInteger value if TupleOutput.writeBigInteger(java.math.BigInteger) were called.
getBIN() - Method in class com.sleepycat.je.dbi.CursorImpl
 
getBINDelta() - Method in class com.sleepycat.je.log.CleanerFileReader
 
getBinDeltaPercent() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getBINEntriesHistogram() - Method in class com.sleepycat.je.BtreeStats
Returns an array representing a histogram of the number of Bottom Internal Nodes with various percentages of non-deleted entry counts.
getBINEntriesHistogram() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
getBinMaxDeltas() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getBINNodeIdsSeen() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
getBinRefQueueSize() - Method in class com.sleepycat.je.incomp.INCompressor
 
getBINsByLevel() - Method in class com.sleepycat.je.BtreeStats
Returns the count of Bottom Internal Nodes per level, indexed by level.
getBINsByLevel() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
getBINStatDef() - Method in enum com.sleepycat.je.evictor.Evictor.EvictionSource
 
getBINToBeRemoved() - Method in class com.sleepycat.je.dbi.CursorImpl
 
getBlock() - Method in class com.sleepycat.je.rep.util.ldiff.BlockBag
 
getBlock() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.BlockInfo
 
getBlockId() - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
getBlockIndex() - Method in class com.sleepycat.je.rep.util.ldiff.BlockBag
 
getBlockSize() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Return the number of records to include in each block analyzed by the LDiff operation.
getBlockSize() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.DbBlocks
 
getBoolean(BooleanConfigParam) - Method in class com.sleepycat.je.dbi.DbConfigManager
Get this parameter from the environment wide configuration settings.
getBoolean(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
 
getBoolean(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getBooleanLogSize() - Static method in class com.sleepycat.je.log.LogUtils
 
getBooleanVal(Properties, BooleanConfigParam) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for getting boolean values.
getBottomInternalNodeCount() - Method in class com.sleepycat.je.BtreeStats
Returns the number of Bottom Internal Nodes in the database tree.
getBranchQualifier() - Method in class com.sleepycat.je.log.LogUtils.XidImpl
 
getBroadcastCBVLSN() - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNTracker
 
getBtreeComparator() - Method in class com.sleepycat.je.DatabaseConfig
Returns the Comparator used for key comparison on this database.
getBtreeComparator() - Method in class com.sleepycat.je.dbi.DatabaseImpl
This comparator should not be used directly for comparisons.
getBtreeComparatorByClass() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getBtreeComparatorByClassName() - Method in class com.sleepycat.je.DatabaseConfig
Returns true if the btree comparator is set by class name, not by serializable Comparator object
getBtreeLevels() - Method in class com.sleepycat.je.util.DbCacheSize
 
getBtreeRecordNumbers(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getBuddy() - Method in class com.sleepycat.je.txn.BuddyLocker
Returns the buddy locker.
getBudgetedMemorySize() - Method in class com.sleepycat.je.tree.IN
Returns the amount of memory currently budgeted for this IN.
getBudgetedMemorySize() - Method in class com.sleepycat.je.txn.Txn
Returns the amount of memory currently budgeted for this transaction.
getBuffer() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
getBuffer() - Method in class com.sleepycat.je.log.LogItem
 
getBufferBytes() - Method in class com.sleepycat.je.EnvironmentStats
The total memory currently consumed by log buffers, in bytes.
getBufferBytes() - Method in class com.sleepycat.util.FastInputStream
Returns the underlying data being read.
getBufferBytes() - Method in class com.sleepycat.util.FastOutputStream
Returns the buffer owned by this object.
getBufferLength() - Method in class com.sleepycat.util.FastInputStream
Returns the end of the buffer being read.
getBufferLength() - Method in class com.sleepycat.util.FastOutputStream
Returns the length used in the internal buffer, i.e., the offset at which data will be written next.
getBufferOffset() - Method in class com.sleepycat.util.FastInputStream
Returns the offset at which data is being read from the buffer.
getBufferOffset() - Method in class com.sleepycat.util.FastOutputStream
Returns the offset of the internal buffer.
getBufferPoolLatchStats() - Method in class com.sleepycat.je.log.LogBufferPool
For unit testing.
getBufferPoolLatchStats() - Method in class com.sleepycat.je.log.LogManager
For unit testing.
getByteArray(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
 
getByteArray(DatabaseEntry) - Static method in class com.sleepycat.util.keyrange.KeyRange
Returns an entry's byte array, copying it if the entry offset is non-zero.
getByteArray(DatabaseEntry, int) - Static method in class com.sleepycat.util.keyrange.KeyRange
 
getByteArrayLogSize(byte[]) - Static method in class com.sleepycat.je.log.LogUtils
 
getByteBufferFromLog(long) - Method in class com.sleepycat.je.log.LogManager
Return a ByteBuffer holding the log entry at this LSN.
getByteLength(char[]) - Static method in class com.sleepycat.util.UtfOps
Returns the byte length of the UTF string that would be created by converting the given characters to UTF.
getByteLength(char[], int, int) - Static method in class com.sleepycat.util.UtfOps
Returns the byte length of the UTF string that would be created by converting the given characters to UTF.
getBytes() - Method in class com.sleepycat.je.dbi.DatabaseId
 
getBytes(long) - Method in class com.sleepycat.je.log.FileSource
 
getBytes(long, int) - Method in class com.sleepycat.je.log.FileSource
 
getBytes(long) - Method in class com.sleepycat.je.log.LogBuffer
 
getBytes(long, int) - Method in class com.sleepycat.je.log.LogBuffer
 
getBytes(long) - Method in interface com.sleepycat.je.log.LogSource
Fill the destination byte array with bytes.
getBytes(long, int) - Method in interface com.sleepycat.je.log.LogSource
Fill the destination byte array with the requested number of bytes.
getCacheDataBytes() - Method in class com.sleepycat.je.EnvironmentStats
Deprecated.
Please use EnvironmentStats.getDataBytes() to get the amount of cache used for data and use EnvironmentStats.getAdminBytes(), EnvironmentStats.getLockBytes() and EnvironmentStats.getBufferBytes() to get other components of the total cache usage (EnvironmentStats.getCacheTotalBytes()).
getCachedVLSNMinLength() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the number of initial bytes per VLSN in the VLSNCache.
getCachedVLSNMinLength() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns the number of initial bytes per VLSN in the VLSNCache.
getCacheKeys() - Method in class com.sleepycat.je.log.FileManager
 
getCacheMemoryUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
getCacheMode() - Method in interface com.sleepycat.je.CacheModeStrategy
Returns the cache mode to be used for an operation where CacheMode.DYNAMIC is the configured cache mode.
getCacheMode() - Method in class com.sleepycat.je.Cursor
Returns the CacheMode used for subsequent operations performed using this cursor.
getCacheMode() - Method in class com.sleepycat.je.DatabaseConfig
Returns the default CacheMode used for operations performed on this database, or null if the environment default is used.
getCacheMode() - Method in class com.sleepycat.je.dbi.CursorImpl
 
getCacheMode() - Method in class com.sleepycat.je.EnvironmentMutableConfig
Returns the default CacheMode used for operations performed in this environment, or null if CacheMode.DEFAULT is used.
getCacheMode() - Method in class com.sleepycat.persist.BasicCursor
 
getCacheMode() - Method in interface com.sleepycat.persist.EntityCursor
Returns the CacheMode used for operations performed using this cursor.
getCacheModeStrategy() - Method in class com.sleepycat.je.DatabaseConfig
 
getCacheModeStrategy() - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
getCachePercent() - Method in class com.sleepycat.je.EnvironmentMutableConfig
Returns the percentage value used in the JE cache size calculation.
getCacheSize() - Method in class com.sleepycat.je.EnvironmentMutableConfig
Returns the memory available to the database system, in bytes.
getCacheSize() - Method in class com.sleepycat.je.SequenceConfig
Returns the number of elements cached by a sequence handle..
getCacheSize() - Method in class com.sleepycat.je.SequenceStats
Returns the number of values that will be cached in this handle.
getCacheTotalBytes() - Method in class com.sleepycat.je.EnvironmentStats
The total amount of JE cache in use, in bytes.
getCacheUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget.Totals
 
getCacheVLSN() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns true if the VLSN is both preserved and cached.
getCacheVLSN() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns true if the VLSN is both preserved and cached.
getCandidates() - Method in class com.sleepycat.je.evictor.TargetSelector.EvictProfile
 
getCapacity() - Method in class com.sleepycat.je.log.LogBuffer
 
getCatalog() - Method in class com.sleepycat.collections.TupleSerialFactory
Returns the class catalog associated with this factory.
getCatalog() - Method in class com.sleepycat.persist.impl.AbstractInput
 
getCatalog() - Method in interface com.sleepycat.persist.impl.EntityInput
Returns the Catalog associated with this input.
getCatalog() - Method in class com.sleepycat.persist.impl.Format
 
getCatalog() - Method in class com.sleepycat.persist.impl.RecordInput
 
getCause() - Method in interface com.sleepycat.util.ExceptionWrapper
Returns the nested exception or null if none is present.
getCause() - Method in exception com.sleepycat.util.IOExceptionWrapper
 
getCausesRestart() - Method in class com.sleepycat.je.txn.LockType
Returns whether when this type is requested it can result in LockGrantType.RESTART.
getCBVLSN() - Method in class com.sleepycat.je.rep.impl.node.GlobalCBVLSN
 
getCBVLSN() - Method in class com.sleepycat.je.rep.stream.Protocol.RestoreResponse
 
getCBVLSNTracker() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getChain(long, long, EnvironmentImpl) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
getChangeListener() - Method in class com.sleepycat.je.rep.impl.node.NodeState
 
getChangeListener() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getChangeSet() - Method in class com.sleepycat.je.sync.impl.LogChangeReader
 
getChangeTxns() - Method in interface com.sleepycat.je.sync.ChangeReader
Returns an iterator over all transactions containing changes for one of the data sets of interest (specified by SyncProcessor.getChangeSet and indirectly by SyncProcessor.sync or syncAll).
getChangeTxns() - Method in class com.sleepycat.je.sync.impl.LogChangeReader
 
getChangeType() - Method in class com.sleepycat.je.rep.monitor.GroupChangeEvent
Returns the type of the change (the addition of a new member or the removal of an existing member) made to the group.
getChangeVersion() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the version of the instance as represented by changes to the members constituting the group.
getChangeVersion() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getChannel() - Method in class com.sleepycat.je.rep.utilint.NamedChannel
 
getChannelTimeoutTask() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getCharLength(byte[]) - Static method in class com.sleepycat.util.UtfOps
Returns the number of characters represented by the given UTF string.
getCharLength(byte[], int, int) - Static method in class com.sleepycat.util.UtfOps
Returns the number of characters represented by the given UTF string.
getCheapestFileToClean(SortedMap<Long, FileSummary>, SortedSet<Long>) - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Returns the cheapest file to clean from the given list of files.
getCheckpointer() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getCheckpointStart() - Method in class com.sleepycat.je.recovery.RollbackTracker
 
getCheckpointStartLsn() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getCheckpointUP(EnvironmentConfig) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentConfig.getCheckpointUP()
getCheckpointUP() - Method in class com.sleepycat.je.EnvironmentConfig
For unit testing, to prevent writing utilization data during checkpoint.
getChecksum() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getChecksum() - Method in class com.sleepycat.je.rep.util.ldiff.Window
The checksum for the window.
getChecksumOnRead() - Method in class com.sleepycat.je.log.LogManager
 
getChildEvictionType() - Method in class com.sleepycat.je.tree.BIN
Note that the IN may or may not be latched when this method is called.
getChildEvictionType() - Method in class com.sleepycat.je.tree.IN
Returns the eviction type based on the status of child nodes, irrespective of isEvictionProhibited.
getClassesToEvolve() - Method in class com.sleepycat.persist.evolve.EvolveConfig
Returns an unmodifiable set of the entity classes to be evolved.
getClassFormat(byte[]) - Method in interface com.sleepycat.bind.serial.ClassCatalog
Return the ObjectStreamClass for the given class ID.
getClassFormat(byte[]) - Method in class com.sleepycat.bind.serial.StoredClassCatalog
 
getClassID(ObjectStreamClass) - Method in interface com.sleepycat.bind.serial.ClassCatalog
Return the class ID for the current version of the given class description.
getClassID(ObjectStreamClass) - Method in class com.sleepycat.bind.serial.StoredClassCatalog
 
getClassLoader() - Method in interface com.sleepycat.bind.serial.ClassCatalog
Returns the ClassLoader to be used by bindings that use this catalog.
getClassLoader() - Method in class com.sleepycat.bind.serial.SerialBinding
Returns the class loader to be used during deserialization, or null if a default class loader should be used.
getClassLoader() - Method in class com.sleepycat.bind.serial.StoredClassCatalog
For BDB JE, returns the ClassLoader property of the catalog database environment.
getClassLoader(Environment) - Static method in class com.sleepycat.compat.DbCompat
 
getClassLoader() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getClassLoader() - Method in class com.sleepycat.je.EnvironmentConfig
Returns the ClassLoader for loading user-supplied classes by name, or null if no specified ClassLoader is configured.
getClassLoader() - Method in class com.sleepycat.persist.model.EntityModel
 
getClassLoader(EntityModel) - Static method in class com.sleepycat.persist.model.ModelInternal
Internal access method that should not be used by applications.
getClassMetadata() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getClassMetadata() - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
getClassMetadata() - Method in class com.sleepycat.persist.impl.Format
 
getClassMetadata(String) - Method in class com.sleepycat.persist.impl.StoredModel
 
getClassMetadata(String) - Method in class com.sleepycat.persist.model.AnnotationModel
 
getClassMetadata(String) - Method in class com.sleepycat.persist.model.EntityModel
Returns the metadata for a given persistent class name, including proxy classes and entity classes.
getClassMetadata() - Method in interface com.sleepycat.persist.raw.RawType
Returns the original model class metadata used to create this class, or null if this is not a model class.
getClassName() - Method in class com.sleepycat.asm.ClassReader
Returns the internal name of the class (see getInternalName).
getClassName() - Method in class com.sleepycat.asm.Type
Returns the binary name of the class corresponding to this type.
getClassName() - Method in class com.sleepycat.persist.evolve.Mutation
Returns the class to which this mutation applies.
getClassName() - Method in class com.sleepycat.persist.impl.FieldInfo
 
getClassName() - Method in class com.sleepycat.persist.impl.Format
 
getClassName() - Method in class com.sleepycat.persist.model.ClassMetadata
Returns the name of the persistent class.
getClassName() - Method in class com.sleepycat.persist.model.EntityMetadata
Returns the name of the entity class.
getClassName() - Method in class com.sleepycat.persist.model.FieldMetadata
Returns the class name of the field type.
getClassName() - Method in interface com.sleepycat.persist.raw.RawType
Returns the class name for this type in the format specified by Class.getName().
getClassVersion() - Method in class com.sleepycat.persist.evolve.Mutation
Returns the class version to which this mutation applies.
getCleanedDatabases(Collection<Long>) - Method in class com.sleepycat.je.cleaner.FileSelector
Returns a copy of the databases for a collection of cleaned files, or null if there are none.
getCleanedFiles() - Method in class com.sleepycat.je.cleaner.FileSelector.CheckpointStartCleanerState
 
getCleanedFilesToDelete() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getCleaner() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getCleanerBacklog() - Method in class com.sleepycat.je.EnvironmentStats
The number of files to be cleaned to reach the target utilization.
getCleanerBarrierFile() - Method in class com.sleepycat.je.rep.impl.node.GlobalCBVLSN
Returns the file number that forms a barrier for the cleaner's file deletion activities.
getCleanerBarrierFile() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the file number that forms a barrier for the cleaner's file deletion activities.
getCleanerBarrierStartFile() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the first protected file number.
getCleanerBarrierStartFile() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getCleanerLogSummary() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getClear() - Method in class com.sleepycat.je.StatsConfig
Returns true if the statistics operation is configured to reset statistics after they are returned.
getClientVLSN() - Method in class com.sleepycat.je.log.ReplicationContext
 
getClock() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getClockSkewMs() - Static method in class com.sleepycat.je.rep.impl.RepImpl
 
getCollection() - Method in class com.sleepycat.collections.StoredIterator
Returns the collection associated with this iterator.
getColumnClass(int) - Method in class com.sleepycat.je.jmx.plugin.Stats.StatsTableModel
 
getColumnCount() - Method in class com.sleepycat.je.jmx.plugin.Stats.StatsTableModel
 
getColumnName(int) - Method in class com.sleepycat.je.jmx.plugin.Stats.StatsTableModel
 
getCommitDurability() - Method in class com.sleepycat.je.txn.Txn
Returns the durability used for the commit operation.
getCommitPolicy() - Method in exception com.sleepycat.je.rep.InsufficientReplicasException
Returns the Replica ack policy that was in effect for the transaction.
getCommitToken() - Method in class com.sleepycat.je.rep.CommitPointConsistencyPolicy
Return the CommitToken used to create this consistency policy.
getCommitToken() - Method in class com.sleepycat.je.rep.txn.MasterTxn
Returns the transaction commit token used to identify the transaction.
getCommitToken() - Method in class com.sleepycat.je.Transaction
This method is intended for use with a replicated environment.
getCommitToken() - Method in class com.sleepycat.je.txn.Txn
Returns the CommitToken associated with a successful replicated commit.
getCommitTxnId() - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
 
getCommitVLSN() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getCommitVLSN() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
getCommonSuperClass(String, String) - Method in class com.sleepycat.asm.ClassWriter
Returns the common super type of the two given types.
getCompactMaxKeyLength() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns EnvironmentConfig.TREE_COMPACT_MAX_KEY_LENGTH.
getCompactMaxKeyLength() - Method in class com.sleepycat.je.tree.IN
 
getComparator() - Method in class com.sleepycat.je.dbi.DatabaseImpl.ComparatorReader
 
getComparatorClass() - Method in class com.sleepycat.je.dbi.DatabaseImpl.ComparatorReader
 
getComplexSuper() - Method in class com.sleepycat.persist.impl.ComplexFormat
Returns getSuperFormat cast to ComplexFormat.
getComponentType() - Method in class com.sleepycat.persist.impl.Format
 
getComponentType() - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
getComponentType() - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
getComponentType() - Method in interface com.sleepycat.persist.raw.RawType
Returns the array component type, or null if this is not an array type.
getCompositeKeyFields() - Method in class com.sleepycat.persist.model.ClassMetadata
Returns an unmodifiable list of metadata for the fields making up a composite key, or null if this is a not a composite key class.
getConfig() - Method in class com.sleepycat.je.Cursor
Returns this cursor's configuration.
getConfig() - Method in class com.sleepycat.je.Database
Returns this Database object's configuration.
getConfig() - Method in class com.sleepycat.je.DiskOrderedCursor
Returns this cursor's configuration.
getConfig() - Method in class com.sleepycat.je.Environment
Returns this object's configuration.
getConfig() - Method in class com.sleepycat.je.JoinCursor
Returns this object's configuration.
getConfig() - Method in class com.sleepycat.je.SecondaryDatabase
Returns a copy of the secondary configuration of this database.
getConfig() - Method in class com.sleepycat.persist.EntityStore
Returns a copy of the entity store configuration.
getConfig() - Method in class com.sleepycat.persist.impl.Store
 
getConfig() - Method in class com.sleepycat.persist.raw.RawStore
Returns a copy of the entity store configuration.
getConfigManager() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the config manager for the current base configuration.
getConfigManager() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getConfigParam(Properties, String) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for environment and replication configuration classes.
getConfigParam(String) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Returns the value for this configuration parameter.
getConfigParam(String) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Return the value for this parameter.
getConfiguredHandler() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getConflict(LockType) - Method in class com.sleepycat.je.txn.LockType
Returns the LockConfict that results when this lock type is held and the given lock type is requested by another locker.
getConnection(String, EnvironmentConfig) - Method in interface com.sleepycat.je.jca.ra.JEConnectionFactory
 
getConnection(String, EnvironmentConfig, TransactionConfig) - Method in interface com.sleepycat.je.jca.ra.JEConnectionFactory
 
getConnection(String, EnvironmentConfig) - Method in class com.sleepycat.je.jca.ra.JEConnectionFactoryImpl
 
getConnection(String, EnvironmentConfig, TransactionConfig) - Method in class com.sleepycat.je.jca.ra.JEConnectionFactoryImpl
 
getConnection(Subject, ConnectionRequestInfo) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
getConnection() - Static method in class com.sleepycat.je.jmx.plugin.Stats
 
getConnectionConfig() - Method in class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
Returns the connection configuration.
getConnectionConfig() - Method in class com.sleepycat.je.sync.mobile.MobileSyncProcessor
Returns the connection configuration.
getConsistencyPolicy() - Method in interface com.sleepycat.je.dbi.RepConfigProxy
 
getConsistencyPolicy() - Method in exception com.sleepycat.je.rep.ReplicaConsistencyException
Returns the Replica consistency policy that could not be satisfied.
getConsistencyPolicy() - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the default consistency policy associated with the configuration.
getConsistencyPolicy() - Method in class com.sleepycat.je.TransactionConfig
Returns the consistency policy associated with the configuration.
getConsistencyTracker() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
getConsoleHandler() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getConstructor() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.MessageOp
 
getConstructorDescriptor(Constructor<?>) - Static method in class com.sleepycat.asm.Type
Returns the descriptor corresponding to the given constructor.
getConstructors() - Method in class com.sleepycat.je.jmx.JEMBean
Get constructor metadata for this MBean.
getContentSize() - Method in class com.sleepycat.je.dbi.Operation
 
getConversion() - Method in class com.sleepycat.persist.evolve.Converter
Returns the converter instance specified to the constructor.
getConverter() - Method in class com.sleepycat.je.sync.SyncDatabase
Returns the record converter.
getConverter(String, int, String) - Method in class com.sleepycat.persist.evolve.Mutations
Returns the converter mutation for the given class, version and field, or null if none exists.
getConverters() - Method in class com.sleepycat.persist.evolve.Mutations
Returns an unmodifiable collection of all converter mutations.
getCorrectedAvgLNSize() - Method in class com.sleepycat.je.EnvironmentStats
Deprecated.
in JE 5.0.56, use EnvironmentStats.getCorrectedAvgLNSize() instead.
getCount() - Method in class com.sleepycat.asm.Attribute
Returns the length of the attribute list that begins with this attribute.
getCount() - Method in class com.sleepycat.je.sync.impl.SyncDB
 
getCounter(StartupTracker.Phase) - Method in class com.sleepycat.je.dbi.StartupTracker
Return the counter for this phase so we can update one of the detail values stored there.
getCreateConfig() - Method in class com.sleepycat.je.log.DbOpReplicationContext
 
getCreatedThisTxn() - Method in class com.sleepycat.je.txn.WriteLockInfo
 
getCreateUP(EnvironmentConfig) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentConfig.getCreateUP()
getCreateUP() - Method in class com.sleepycat.je.EnvironmentConfig
For unit testing, to prevent creating the utilization profile DB.
getCriticalThreshold() - Method in class com.sleepycat.je.dbi.MemoryBudget.Totals
 
getCSVData() - Method in class com.sleepycat.je.utilint.StatGroup
Return a string suitable for using as the header for a .csv file.
getCSVHeader() - Method in class com.sleepycat.je.utilint.StatGroup
Return a string suitable for using as the header for a .csv file.
getCumulativeLatency() - Method in class com.sleepycat.utilint.StatsTracker
 
getCurrent(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getCurrent(), no join cursor allowed.
getCurrent(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Returns the key/data pair to which the cursor refers.
getCurrent(DatabaseEntry, DatabaseEntry, LockType) - Method in class com.sleepycat.je.dbi.CursorImpl
Retrieve the current record.
getCurrent(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.dbi.DiskOrderedCursorImpl
 
getCurrent(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.DiskOrderedCursor
Returns the key/data pair to which the cursor refers.
getCurrent(DatabaseEntry, DatabaseEntry, LockMode) - Method in interface com.sleepycat.je.ForwardCursor
Returns the key/data pair to which the cursor refers.
getCurrent(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getCurrent(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Returns the key/data pair to which the cursor refers.
getCurrent() - Method in class com.sleepycat.je.SequenceStats
Returns the current value of the sequence in the database.
getCurrent(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getCurrentAlreadyLatched(DatabaseEntry, DatabaseEntry, LockType) - Method in class com.sleepycat.je.dbi.CursorImpl
Retrieve the current record.
getCurrentFileNum() - Method in class com.sleepycat.je.log.FileManager
Returns the highest (current) file number.
getCurrentInternal(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Returns the current key and data.
getCurrentKey() - Method in class com.sleepycat.collections.DataCursor
Returns the key object for the last record read.
getCurrentKey() - Method in class com.sleepycat.je.dbi.CursorImpl
Returns the key at the current position, regardless of whether the record is deleted.
getCurrentLN(LockType) - Method in class com.sleepycat.je.dbi.CursorImpl
Retrieve the current LN, return with the target bin unlatched.
getCurrentLNAlreadyLatched(LockType) - Method in class com.sleepycat.je.dbi.CursorImpl
Retrieve the current LN, assuming the BIN is already latched.
getCurrentRecordNumber() - Method in class com.sleepycat.collections.DataCursor
Returns the record number for the last record read.
getCurrentRecordNumber(Cursor, DatabaseEntry, LockMode) - Static method in class com.sleepycat.compat.DbCompat
 
getCurrentRequiredAckCount() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
getCurrentTokenPosition() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Message
Returns the current token position in the payload.
getCurrentTxn() - Method in class com.sleepycat.collections.DataView
Returns the current transaction for the view or null if the environment is non-transactional.
getCurrentTxnEndVLSN() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the latest VLSN associated with a replicated commit.
getCurrentTxnEndVLSN() - Method in class com.sleepycat.je.rep.NodeState
Returns the latest transaction end VLSN on this replication node.
getCurrentTxnEndVLSN() - Method in class com.sleepycat.je.rep.stream.Protocol.Heartbeat
 
getCurrentValue() - Method in class com.sleepycat.collections.DataCursor
Returns the value object for the last record read.
getCurrentVersion(boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
Returns the VLSN and LSN for the record at the current position.
getCursor() - Method in class com.sleepycat.collections.DataCursor
Returns the internal range cursor.
getCursor() - Method in class com.sleepycat.util.keyrange.RangeCursor
Returns the underlying cursor.
getCursorConfig() - Method in class com.sleepycat.collections.StoredContainer
Returns the cursor configuration that is used for all operations performed via this container.
getCursorImpl() - Method in class com.sleepycat.je.Cursor
Internal entrypoint.
getCursorImpl(Cursor) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.getCursorImpl()
getCursorsBins() - Method in class com.sleepycat.je.EnvironmentStats
The number of BINs encountered by the INCompressor that had cursors referring to them when the compressor ran.
getCursorSet() - Method in class com.sleepycat.je.tree.BIN
 
getData() - Method in class com.sleepycat.je.DatabaseEntry
Returns the byte array.
getData() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
getData() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
getData() - Method in class com.sleepycat.je.rep.util.ldiff.Record
 
getData() - Method in interface com.sleepycat.je.sync.ChangeReader.Change
Returns the record data for this change, or null if this is a DELETE operation.
getData() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChange
 
getData() - Method in class com.sleepycat.je.tree.LN
 
getDatabase() - Method in class com.sleepycat.je.Cursor
Returns the Database handle associated with this Cursor.
getDatabase() - Method in class com.sleepycat.je.dbi.TruncateResult
 
getDatabase() - Method in class com.sleepycat.je.DiskOrderedCursor
Returns the Database handle associated with this Cursor.
getDatabase() - Method in interface com.sleepycat.je.ForwardCursor
Returns the Database handle associated with this ForwardCursor.
getDatabase() - Method in class com.sleepycat.je.JoinCursor
Returns the primary database handle associated with this cursor.
getDatabase() - Method in exception com.sleepycat.je.rep.DatabasePreemptedException
Returns the database handle that was forcibly closed.
getDatabase() - Method in class com.sleepycat.je.Sequence
Returns the Database handle associated with this sequence.
getDatabase() - Method in class com.sleepycat.je.tree.IN
Get the database for this IN.
getDatabase() - Method in class com.sleepycat.je.tree.MapLN
 
getDatabase() - Method in class com.sleepycat.je.tree.Tree
 
getDatabase() - Method in class com.sleepycat.persist.PrimaryIndex
Returns the underlying database for this index.
getDatabase() - Method in class com.sleepycat.persist.SecondaryIndex
Returns the underlying secondary database for this index.
getDatabaseClassName(String) - Method in class com.sleepycat.persist.impl.PersistCatalog
Returns the name of an entity class to be used to form the database name.
getDatabaseCount(Database) - Static method in class com.sleepycat.compat.DbCompat
 
getDatabaseFile(Database) - Static method in class com.sleepycat.compat.DbCompat
 
getDatabaseId() - Method in class com.sleepycat.je.log.CleanerFileReader
Get the last databaseId seen by the reader.
getDatabaseId() - Method in class com.sleepycat.je.log.INFileReader
Get the last databaseId seen by the reader.
getDatabaseId() - Method in class com.sleepycat.je.log.LNFileReader
Get the last databaseId seen by the reader.
getDatabaseId() - Method in class com.sleepycat.je.tree.BINReference
 
getDatabaseId() - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
getDatabaseId() - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
getDatabaseId() - Method in class com.sleepycat.je.tree.IN
 
getDatabaseImpl() - Method in class com.sleepycat.je.Cursor
Always returns non-null, while getDatabase() returns null if no handle is associated with this cursor.
getDatabaseImpl() - Method in class com.sleepycat.je.Database
Returns the databaseImpl object instance.
getDatabaseImpl(Database) - Static method in class com.sleepycat.je.DbInternal
Proxy to Database.getDatabaseImpl()
getDatabaseImpl() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
For unit testing.
getDatabaseImpl() - Method in class com.sleepycat.je.sync.impl.SyncDB
 
getDatabaseKeyName(String, String) - Method in class com.sleepycat.persist.impl.PersistCatalog
Similar to getDatabaseClassName but instead handles an earlier version of a renamed key.
getDatabaseMap() - Method in class com.sleepycat.je.cleaner.BaseLocalUtilizationTracker
Returns the map of databases; for use by subclasses.
getDatabaseName() - Method in class com.sleepycat.je.Database
Returns the database name.
getDatabaseName() - Method in exception com.sleepycat.je.rep.DatabasePreemptedException
Returns the name of the database that was forcibly closed.
getDatabaseName() - Method in interface com.sleepycat.je.sync.ChangeReader.Change
Returns the name of the local database to which this change was applied.
getDatabaseName() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChange
 
getDatabaseName() - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
getDatabaseName() - Method in interface com.sleepycat.je.trigger.Trigger
Returns the result of the Trigger.setDatabaseName(String) operation.
getDatabaseNamer() - Method in class com.sleepycat.persist.StoreConfig
 
getDatabaseNames() - Method in class com.sleepycat.je.Environment
Returns a List of database names for the database environment.
getDatabaseNames() - Method in interface com.sleepycat.je.sync.ChangeReader.ChangeTxn
Returns the names of all local databases that are effected by this transaction and that are part of a single data set (specified by getDataSetName).
getDatabaseNames() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChangeTxn
 
getDatabases() - Method in class com.sleepycat.je.sync.SyncDataSet
Returns the databases that are synchronized.
getDataBuffer() - Method in class com.sleepycat.je.log.LogBuffer
 
getDataBytes() - Method in class com.sleepycat.je.EnvironmentStats
The amount of JE cache used for holding data, keys and internal Btree nodes, in bytes.
getDataSetName() - Method in interface com.sleepycat.je.sync.ChangeReader.ChangeTxn
Returns the name of the data set to which this transaction should be applied.
getDataSetName() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChangeTxn
 
getDataSets() - Method in class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
 
getDataSets() - Method in class com.sleepycat.je.sync.mobile.MobileSyncProcessor
 
getDataSets() - Method in class com.sleepycat.je.sync.ProcessorMetadata
 
getDataSets() - Method in class com.sleepycat.je.sync.SyncProcessor
Returns all SyncDataSets that are managed by this processor.
getDataType(String) - Static method in enum com.sleepycat.je.sync.impl.SyncDB.DataType
 
getDate(long) - Method in class com.sleepycat.je.utilint.TracerFormatter
 
getDb(Locker, String, HandleLocker) - Method in class com.sleepycat.je.dbi.DbTree
Get a database object given a database name.
getDb(DatabaseId) - Method in class com.sleepycat.je.dbi.DbTree
Get a database object based on an id only.
getDb(DatabaseId, long) - Method in class com.sleepycat.je.dbi.DbTree
Get a database object based on an id only.
getDb(DatabaseId, long, Map<DatabaseId, DatabaseImpl>) - Method in class com.sleepycat.je.dbi.DbTree
Get a database object based on an id only, caching the id-db mapping in the given map.
getDb(DatabaseId, long, String) - Method in class com.sleepycat.je.dbi.DbTree
Get a database object based on an id only.
getDb(EnvironmentImpl, DatabaseId) - Method in interface com.sleepycat.je.evictor.Evictor.DbCache
Calls DbTree.getDb for the given environment and database ID, and caches the result to optimize multiple calls for the same DB.
getDb() - Method in class com.sleepycat.je.SecondaryTrigger
 
getDbCache() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
getDbClosedBins() - Method in class com.sleepycat.je.EnvironmentStats
The number of BINs encountered by the INCompressor that had their database closed between the time they were put on the compressor queue and when the compressor ran.
getDbEnvironment() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getDbEviction() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns whether DB/MapLN eviction is enabled.
getDbFileSummaries() - Method in class com.sleepycat.je.dbi.DatabaseImpl
For unit testing.
getDbFileSummary(Object, long) - Method in class com.sleepycat.je.cleaner.BaseLocalUtilizationTracker
Allocates DbFileSummary information locally in this object rather than in the DatabaseImpl.
getDbFileSummary(Object, long) - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Returns a DbFileSummary for the given database key and file number, adding an empty one if the file is not already being tracked.
getDbFileSummary(Object, long) - Method in class com.sleepycat.je.cleaner.UtilizationTracker
Allocates DbFileSummary information in the DatabaseImpl, which is the database key.
getDbFileSummary(Long, boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns the DbFileSummary for the given file, allocates it if necessary and budgeted memory for any changes.
getDbId() - Method in class com.sleepycat.je.cleaner.LNInfo
 
getDbId() - Method in class com.sleepycat.je.log.entry.BINDeltaLogEntry
 
getDbId() - Method in interface com.sleepycat.je.log.entry.INContainingEntry
 
getDbId() - Method in class com.sleepycat.je.log.entry.INLogEntry
 
getDbId() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getDbId() - Method in interface com.sleepycat.je.log.entry.LogEntry
 
getDbId() - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
getDbId() - Method in class com.sleepycat.je.tree.BINDelta
 
getDBINsByLevel() - Method in class com.sleepycat.je.BtreeStats
Deprecated.
as of 5.0, returns an empty array.
getDbName(DatabaseId) - Method in class com.sleepycat.je.dbi.DbTree
Return the database name for a given db.
getDbName() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.DbBlocks
 
getDbNameMessage(String[]) - Method in class com.sleepycat.persist.impl.Store
Creates a message identifying the database from the pair of strings returned by parseDbName.
getDbNames() - Method in class com.sleepycat.je.dbi.DbTree
 
getDbNamesAndIds() - Method in class com.sleepycat.je.dbi.DbTree
 
getDbOperationType() - Method in class com.sleepycat.je.log.DbOpReplicationContext
 
getDbOperationType() - Method in class com.sleepycat.je.log.ReplicationContext
 
getDbsWithDifferentLevels() - Method in class com.sleepycat.je.recovery.LevelRecorder
 
getDbTree() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getDbTreeCacheClearingOpCount() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getDbType() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getDeadlockStackTrace() - Static method in class com.sleepycat.je.txn.LockInfo
For unit testing only.
getDebugName() - Method in class com.sleepycat.je.Database
 
getDebugName() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns the DB name for debugging and error messages.
getDeclaringClassName() - Method in class com.sleepycat.persist.model.FieldMetadata
Returns the name of the class where the field is declared.
getDecrement() - Method in class com.sleepycat.je.SequenceConfig
Returns true if the sequence is configured to decrement.
getDefault() - Method in class com.sleepycat.je.config.ConfigParam
 
getDefaultCacheMode() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns the default cache mode for this database.
getDefaultCacheMode() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the default cache mode for this environment.
getDefaultCacheModeStrategy() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the environment cache mode strategy.
getDefaultConsistencyPolicy() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getDefaultConsistencyPolicy() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getDefaultDurability() - Method in class com.sleepycat.je.txn.Txn
Returns the durability associated the transaction at the time it's first created.
getDefaultEventIndex() - Method in class com.sleepycat.util.ConfigBeanInfoBase
A bean may have a "default" event that is the event that will mostly commonly be used by human's when using the bean.
getDefaultNoWait() - Method in class com.sleepycat.je.txn.Locker
 
getDefaultPropertyIndex() - Method in class com.sleepycat.util.ConfigBeanInfoBase
A bean may have a "default" property that is the property that will mostly commonly be initially chosen for update by human's who are customizing the bean.
getDefaultTxnConfig(Environment) - Static method in class com.sleepycat.je.DbInternal
Proxy to Environment.getDefaultTxnConfig()
getDefaultTxnConfig() - Method in class com.sleepycat.je.Environment
Returns the default txn config for this environment handle.
getDefaultVersion() - Static method in class com.sleepycat.je.rep.stream.Protocol
 
getDeferredWrite(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getDeferredWrite() - Method in class com.sleepycat.je.DatabaseConfig
Returns the deferred-write option.
getDeferredWrite() - Method in class com.sleepycat.persist.StoreConfig
Returns the deferred-write configuration property.
getDefinition() - Method in class com.sleepycat.je.utilint.Stat
 
getDelay() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
getDeleteAction() - Method in class com.sleepycat.persist.model.SecondaryKeyMetadata
Returns the action to take when a related entity is deleted having a primary key value that exists as a secondary key value for this entity.
getDeletedDupKey() - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
getDeletedIdKey() - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
getDeletedKeys() - Method in class com.sleepycat.persist.evolve.EntityConverter
Returns the set of key names that are to be deleted.
getDeletedLeafNodeCount() - Method in class com.sleepycat.je.BtreeStats
Returns the number of deleted data records in the database tree that are pending removal by the compressor.
getDeletedLNCount() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
getDeletedMainKey() - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
getDeletedNodeId() - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
getDeletedNodeId() - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
getDeleter(String, int, String) - Method in class com.sleepycat.persist.evolve.Mutations
Returns the deleter mutation for the given class, version and field, or null if none exists.
getDeleters() - Method in class com.sleepycat.persist.evolve.Mutations
Returns an unmodifiable collection of all deleter mutations.
getDelta() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker.DeltaINEntry
 
getDelta() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker.INEntry
 
getDelta() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
getDeltaLsn() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker.DeltaINEntry
 
getDeltaLsn() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker.INEntry
 
getDesc() - Method in class com.sleepycat.asm.Handle
Returns the descriptor of the field or method designated by this handle.
getDescription() - Method in class com.sleepycat.je.utilint.StatDefinition
 
getDescription() - Method in class com.sleepycat.je.utilint.StatGroup
 
getDescriptor() - Method in class com.sleepycat.asm.Type
Returns the descriptor corresponding to this Java type.
getDescriptor(Class<?>) - Static method in class com.sleepycat.asm.Type
Returns the descriptor corresponding to the given Java type.
getDesignatedPrimary() - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Determines whether this node is the currently designated Primary.
getDestinationTimestamp() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
getDetail() - Method in interface com.sleepycat.util.ExceptionWrapper
Deprecated.
getDetail() - Method in exception com.sleepycat.util.IOExceptionWrapper
Deprecated.
getDetail() - Method in exception com.sleepycat.util.RuntimeExceptionWrapper
Deprecated.
replaced by Throwable.getCause().
getDiagnosticsClassName() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getDiagnosticsClassName() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getDiffAnalysis() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Return whether an LDiff object will provide detailed analysis about diff failures.
getDiffArea(Cursor, Protocol.RemoteDiffRequest) - Static method in class com.sleepycat.je.rep.util.ldiff.DiffRecordAnalyzer
 
getDiffRegions() - Method in class com.sleepycat.je.rep.util.ldiff.DiffTracker
 
getDiffRegions() - Method in class com.sleepycat.je.rep.util.ldiff.LDiff
 
getDiffSize() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
getDiffSize() - Method in class com.sleepycat.je.rep.util.ldiff.Window
 
getDigestSHA1() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoResp
Returns the SHA1 value if it was requested, or a zero length byte array if it was not requested.
getDimensions() - Method in class com.sleepycat.asm.Type
Returns the number of dimensions of this array type.
getDimensions() - Method in class com.sleepycat.persist.impl.Format
 
getDimensions() - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
getDimensions() - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
getDimensions() - Method in interface com.sleepycat.persist.raw.RawType
Returns the number of array dimensions, or zero if this is not an array type.
getDINsByLevel() - Method in class com.sleepycat.je.BtreeStats
Deprecated.
as of 5.0, returns an empty array.
getDirty() - Method in class com.sleepycat.je.tree.IN
 
getDouble(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
 
getDupConvertPreloadConfig() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getDupConvertPreloadConfig() - Method in class com.sleepycat.je.EnvironmentConfig
 
getDupCount() - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
getDupCountLeafNodeCount() - Method in class com.sleepycat.je.BtreeStats
Deprecated.
as of 5.0, returns zero.
getDupCountLN() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
getDupCountLNRef() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
getDuplicateBottomInternalNodeCount() - Method in class com.sleepycat.je.BtreeStats
Deprecated.
as of 5.0, returns zero.
getDuplicateComparator() - Method in class com.sleepycat.je.DatabaseConfig
Returns the Comparator used for duplicate record comparison on this database.
getDuplicateComparator() - Method in class com.sleepycat.je.dbi.DatabaseImpl
This comparator should not be used directly for comparisons.
getDuplicateComparatorByClass() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getDuplicateComparatorByClassName() - Method in class com.sleepycat.je.DatabaseConfig
Returns true if the duplicate comparator is set by class name, not by serializable Comparator object.
getDuplicateInternalNodeCount() - Method in class com.sleepycat.je.BtreeStats
Deprecated.
as of 5.0, returns zero.
getDuplicateTreeMaxDepth() - Method in class com.sleepycat.je.BtreeStats
Deprecated.
as of 5.0, returns zero.
getDupsConverted() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getDupsConverted() - Method in class com.sleepycat.je.dbi.DbTree
 
getDurability() - Method in class com.sleepycat.je.EnvironmentMutableConfig
Returns the durability associated with the configuration.
getDurability() - Method in class com.sleepycat.je.sync.ExportConfig
 
getDurability() - Method in class com.sleepycat.je.sync.ImportConfig
 
getDurability() - Method in class com.sleepycat.je.TransactionConfig
Returns the durability associated with the configuration.
getDurabilityFromSync(EnvironmentImpl) - Method in class com.sleepycat.je.TransactionConfig
 
getDuration(DurationConfigParam) - Method in class com.sleepycat.je.dbi.DbConfigManager
Get this parameter from the environment wide configuration settings.
getDurationVal(Properties, DurationConfigParam, TimeUnit) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for getting duration values.
getEarliestPassedTxn() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
 
getEarliestTransactionCommitTime() - Method in exception com.sleepycat.je.rep.RollbackException
Return the time in milliseconds of the earliest transaction commit that has been rolled back.
getEarliestTransactionCommitTime() - Method in exception com.sleepycat.je.rep.RollbackProhibitedException
Return the time in milliseconds of the earliest transaction commit that will be rolled back if the log is truncated to the location specified by RollbackProhibitedException.getTruncationFileNumber() and RollbackProhibitedException.getTruncationFileOffset()
getEarliestTransactionId() - Method in exception com.sleepycat.je.rep.RollbackException
Return the id of the earliest transaction commit that has been rolled back.
getEarliestTransactionId() - Method in exception com.sleepycat.je.rep.RollbackProhibitedException
Return the id of the earliest transaction commit that will be rolled back if the log is truncated to the location specified by RollbackProhibitedException.getTruncationFileNumber() and RollbackProhibitedException.getTruncationFileOffset()
getEffectiveCacheMode(CacheMode) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns the effective cache mode to use for a cursor operation, based on the given non-null cache mode parameter.
getEISProductName() - Method in class com.sleepycat.je.jca.ra.JEConnectionMetaData
 
getEISProductVersion() - Method in class com.sleepycat.je.jca.ra.JEConnectionMetaData
 
getElectableGroupSize() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Note that even unACKed nodes are considered part of the group for group size/durability considerations.
getElectableGroupSizeOverride() - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Returns the value associated with the override.
getElectableNodes() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
 
getElectableNodes() - Method in class com.sleepycat.je.rep.ReplicationGroup
Returns the subset of ELECTABLE nodes with replicated environments that can be elected and become masters.
getElectionCount() - Method in class com.sleepycat.je.rep.elections.Elections
The number of elections that have been held.
getElectionLatch() - Method in class com.sleepycat.je.rep.elections.Elections.ElectionListener
Used during shutdown only
getElectionPolicy() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getElectionPriority() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getElectionQuorumSize(QuorumPolicy) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the number of nodes needed to form a quorum for elections
getElections() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getElementClassName() - Method in class com.sleepycat.persist.model.SecondaryKeyMetadata
Returns the class name of the array or collection element for a ONE_TO_MANY or MANY_TO_MANY relationship, or null for a Relationship#ONE_TO_ONE ONE_TO_ONE} or MANY_TO_ONE relationship.
getElements(RawObject) - Static method in class com.sleepycat.persist.impl.CollectionProxy
 
getElements() - Method in class com.sleepycat.persist.raw.RawObject
Returns the array of elements for an array type, or null for a complex type or an enum type.
getElementType() - Method in class com.sleepycat.asm.Type
Returns the type of the elements of this array type.
getEmptyStats() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getEncryptionType() - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
getEndFileNumAtLastAdjustment() - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
getEndOffset() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
getEndOfLog() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getEndOfLog() - Method in class com.sleepycat.je.EnvironmentStats
The location of the next entry to be written to the log.
getEndOfLog() - Method in class com.sleepycat.je.log.LastFileReader
 
getEndOfLog() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getEntityBinding(Class<V>) - Method in class com.sleepycat.collections.TupleSerialFactory
 
getEntityBinding() - Method in class com.sleepycat.je.sync.RecordMapping
Returns the entity binding, or null if key and value bindings are used.
getEntityBinding() - Method in class com.sleepycat.persist.PrimaryIndex
Returns the entity binding for this index.
getEntityClass() - Method in class com.sleepycat.persist.PrimaryIndex
Returns the entity class for this index.
getEntityClassName() - Method in class com.sleepycat.persist.evolve.EvolveEvent
The class name of the current entity class being converted.
getEntityFormat() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getEntityFormat() - Method in class com.sleepycat.persist.impl.Format
For an entity class or subclass, returns the base entity class; returns null in other cases.
getEntityFormats(Collection<Format>) - Method in class com.sleepycat.persist.impl.PersistCatalog
 
getEntityMetadata() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getEntityMetadata() - Method in class com.sleepycat.persist.impl.Format
 
getEntityMetadata(String) - Method in class com.sleepycat.persist.impl.StoredModel
 
getEntityMetadata(String) - Method in class com.sleepycat.persist.model.AnnotationModel
 
getEntityMetadata(String) - Method in class com.sleepycat.persist.model.EntityModel
Returns the metadata for a given entity class name.
getEntityMetadata() - Method in interface com.sleepycat.persist.raw.RawType
Returns the original model entity metadata used to create this class, or null if this is not an entity class.
getEntriesCounted() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns the total number of entries counted.
getEntry(long) - Method in class com.sleepycat.je.log.LogManager
Fault in the first object in the log entry log entry at this LSN.
getEntry() - Method in class com.sleepycat.je.log.WholeEntry
 
getEntryHandleFileNotFound(long) - Method in class com.sleepycat.je.log.LogManager
 
getEntryLsnByteArray() - Method in class com.sleepycat.je.tree.IN
 
getEntryLsnLongArray() - Method in class com.sleepycat.je.tree.IN
 
getEntryType() - Method in class com.sleepycat.je.log.LastFileReader
 
getEntryType() - Method in class com.sleepycat.je.rep.stream.InputWireRecord
 
getEntryType() - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
 
getEnum(Class<T>, ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
 
getEnum() - Method in class com.sleepycat.persist.raw.RawObject
Returns the enum constant String for an enum type, or null for a complex type or an array type.
getEnumConstants() - Method in class com.sleepycat.persist.impl.EnumFormat
 
getEnumConstants() - Method in class com.sleepycat.persist.impl.Format
 
getEnumConstants() - Method in interface com.sleepycat.persist.raw.RawType
Returns an unmodifiable list of the names of the enum instances, or null if this is not an enum type.
getEnumerator(String) - Method in class com.sleepycat.je.rep.impl.EnumConfigParam
Returns the enumerator associated with the name
getEnv() - Method in class com.sleepycat.collections.DataView
Returns the environment for the database.
getEnv() - Method in class com.sleepycat.je.jca.ra.JELocalTransaction
 
getEnvConfig() - Method in class com.sleepycat.je.jca.ra.JERequestInfo
 
getEnvImpl() - Method in class com.sleepycat.je.recovery.RollbackTracker
 
getEnvImpl() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
getEnvImpls() - Method in class com.sleepycat.je.dbi.DbEnvPool
 
getEnvironment() - Method in class com.sleepycat.collections.CurrentTransaction
Returns the underlying Berkeley DB environment.
getEnvironment() - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
 
getEnvironment() - Method in class com.sleepycat.je.cleaner.UtilizationTracker
 
getEnvironment() - Method in class com.sleepycat.je.Database
Returns the Environment handle for the database environment underlying the Database.
getEnvironment(File, EnvironmentConfig, boolean, boolean, RepConfigProxy) - Method in class com.sleepycat.je.dbi.DbEnvPool
Find a single environment, used by Environment handles and by command line utilities.
getEnvironment(Transaction) - Static method in class com.sleepycat.je.DbInternal
Proxy to Transaction.getEnvironment()
getEnvironment() - Method in class com.sleepycat.je.jca.ra.JEConnection
 
getEnvironment() - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
getEnvironment() - Method in class com.sleepycat.je.sync.SyncProcessor
Returns the JE Environment associated with this processor.
getEnvironment() - Method in class com.sleepycat.je.Transaction
 
getEnvironment() - Method in class com.sleepycat.je.txn.Locker
 
getEnvironment() - Method in class com.sleepycat.persist.EntityStore
Returns the environment associated with this store.
getEnvironment() - Method in class com.sleepycat.persist.impl.Store
 
getEnvironment() - Method in class com.sleepycat.persist.raw.RawStore
Returns the environment associated with this store.
getEnvironmentConfig() - Method in class com.sleepycat.je.dbi.DbConfigManager
 
getEnvironmentHome() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Get the environment home directory.
getEnvironmentHome() - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Return the target environment directory.
getEnvironmentIfOpen() - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Return an Environment only if the environment has already been opened in this process.
getEnvironmentImpl() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getEnvironmentImpl(Environment) - Static method in class com.sleepycat.je.DbInternal
Proxy to Environment.getEnvironmentImpl
getEnvironmentImpl() - Method in class com.sleepycat.je.Environment
Internal entrypoint.
getEnvironmentImpl() - Method in class com.sleepycat.je.txn.Txn
 
getEnvironmentMapKey(File) - Method in class com.sleepycat.je.dbi.DbEnvPool
 
getEnvironmentOpenConfig() - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
If the helper was instantiated with canConfigure==true, it shows environment configuration attributes.
getEnvironmentShell(File) - Static method in class com.sleepycat.je.DbInternal
Get an Environment only if the environment is already open.
getEnvOverhead() - Method in class com.sleepycat.je.util.DbCacheSize
 
getEofLsn() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getErrorMessage() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.RejectMessage
 
getErrors() - Method in class com.sleepycat.persist.impl.Evolver
Returns an error string if any mutations are invalid or missing, or returns null otherwise.
getErrorType() - Method in exception com.sleepycat.je.rep.impl.TextProtocol.InvalidMessageException
 
getErrorType() - Method in class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
getEstimatedAvgLNSize() - Method in class com.sleepycat.je.EnvironmentStats
Deprecated.
in JE 5.0.56, use EnvironmentStats.getCorrectedAvgLNSize() instead.
getEvent() - Method in exception com.sleepycat.je.rep.StateChangeException
Returns the event that resulted in this exception.
getEventSetDescriptors() - Method in class com.sleepycat.util.ConfigBeanInfoBase
Gets the bean's EventSetDescriptors.
getEventTime() - Method in class com.sleepycat.je.rep.StateChangeEvent
Returns the time (in nano second units) the event occurred, as reported by System.nanoTime()
getEvictionPledge() - Method in class com.sleepycat.je.evictor.Arbiter
Return non zero number of bytes if eviction should happen.
getEvictionType() - Method in class com.sleepycat.je.tree.IN
Returns the eviction type for this IN, for use by the evictor.
getEvictor() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getEvolveListener() - Method in class com.sleepycat.persist.evolve.EvolveConfig
Returns the progress listener that is notified each time an entity is read.
getEvolveNeeded() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getEvolveNeeded() - Method in class com.sleepycat.persist.impl.Format
Overridden by ComplexFormat.
getException() - Method in class com.sleepycat.je.ExceptionEvent
Returns the exception in the event.
getException() - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
 
getExceptionListener() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getExceptionListener() - Method in class com.sleepycat.je.EnvironmentMutableConfig
Returns the exception listener, if set.
getExceptionListener() - Method in class com.sleepycat.je.utilint.DaemonThread
For testing.
getExclusiveCreate() - Method in class com.sleepycat.je.DatabaseConfig
Returns true if the Environment.openDatabase method is configured to fail if the database already exists.
getExclusiveCreate() - Method in class com.sleepycat.je.SequenceConfig
Returns true if the Database.openSequence method is configured to fail if the database already exists.
getExclusiveCreate() - Method in class com.sleepycat.persist.StoreConfig
Returns whether opening an existing store is prohibited.
getExistingType() - Method in class com.sleepycat.persist.impl.Format
Called to get the type when it is known to exist for an uninitialized format.
getExplicitDurabilityConfigured() - Method in class com.sleepycat.je.txn.Txn
 
getExplicitSyncConfigured() - Method in class com.sleepycat.je.txn.Txn
 
getExternalFieldNames() - Method in interface com.sleepycat.je.sync.RecordConverter
Returns an array of the names of fields in the external RDBMS.
getExternalFieldNames() - Method in class com.sleepycat.je.sync.RecordMapping
 
getExternalFieldTypes() - Method in interface com.sleepycat.je.sync.RecordConverter
Returns an array of the types of fields in the external RDBMS.
getExternalFieldTypes() - Method in class com.sleepycat.je.sync.RecordMapping
 
getExternalName() - Method in class com.sleepycat.je.sync.SyncDatabase
Returns the name of the external table/view.
getExtraMemorySize() - Method in class com.sleepycat.je.cleaner.PackedOffsets
Return the extra memory used by this object when the pack() method has been called to allocate the data array.
getFast() - Method in class com.sleepycat.je.StatsConfig
Returns true if the statistics operation is configured to return only the values which do not require expensive actions.
getFeeder(String) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Returns the Feeder associated with the node, if such a feeder is currently active.
getFeederManagerStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Returns the statistics associated with the FeederManager.
getFeederTxns() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getFeederTxns() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getFetchObsoleteSize() - Method in class com.sleepycat.je.cleaner.Cleaner
 
GETFIELD - Static variable in interface com.sleepycat.asm.Opcodes
 
getField(Object, int, int, boolean) - Method in interface com.sleepycat.persist.impl.Accessor
Returns the value of a given field, representing primitives as primitive wrapper objects.
getField(Object, int, int, boolean) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
getField(List<FieldInfo>, String) - Static method in class com.sleepycat.persist.impl.FieldInfo
 
getField(Object, int, int, boolean) - Method in class com.sleepycat.persist.impl.RawAccessor
 
getField(Object, int, int, boolean) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
getFieldClass(Catalog) - Method in class com.sleepycat.persist.impl.FieldInfo
 
getFieldIndex(List<FieldInfo>, String) - Static method in class com.sleepycat.persist.impl.FieldInfo
 
getFieldInfo() - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
getFieldMapping() - Method in class com.sleepycat.je.sync.RecordMapping
Returns a Map from local field/property name to external field/column name, or null if no custom mapping is used.
getFieldName() - Method in class com.sleepycat.persist.evolve.Mutation
Returns the field name to which this mutation applies, or null if this mutation applies to the class itself.
getFieldNameArray(List<FieldMetadata>) - Static method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
getFields() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getFields() - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
getFields() - Method in class com.sleepycat.persist.impl.Format
 
getFields() - Method in interface com.sleepycat.persist.raw.RawType
Returns a map of field name to raw field for each non-static non-transient field declared in this class, or null if this is not a complex type (in other words, this is a simple type or an array type).
getFile() - Method in class com.sleepycat.je.log.FileHandle
 
getFile(File) - Method in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackup
Requests and obtains the specific log file from the server.
getFileDeletionBacklog() - Method in class com.sleepycat.je.EnvironmentStats
The number of log files that are ready to be deleted.
getFileHandle(long) - Method in class com.sleepycat.je.log.FileManager
Return a read only file handle that corresponds to this file number.
getFileHandler() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getFileHeader() - Method in class com.sleepycat.je.log.CleanerFileReader
 
getFileHeaderPrevOffset(long) - Method in class com.sleepycat.je.log.FileManager
 
getFileLength() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
getFileLogVersion(long) - Method in class com.sleepycat.je.log.FileManager
Returns the log version for the given file.
getFileManager() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getFileName(long, String) - Static method in class com.sleepycat.je.log.FileManager
 
getFileName() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileReq
 
getFileName(String, String, String) - Method in interface com.sleepycat.persist.DatabaseNamer
Returns the name of the file to be used to store the dataabase for the given store, entity class and key.
getFileNames() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileListResp
 
getFileNum() - Method in class com.sleepycat.je.log.FileHandle
 
getFileNumber() - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Returns the file number being tracked.
getFileNumber(byte[]) - Static method in class com.sleepycat.je.tree.FileSummaryLN
Convert a FileSummaryLN key from a byte array to a long.
getFileNumber(long) - Static method in class com.sleepycat.je.utilint.DbLsn
Return the file number for this DbLsn.
getFileOffset(long) - Static method in class com.sleepycat.je.utilint.DbLsn
Return the file offset for this DbLsn.
getFileOffsetAsInt(long) - Static method in class com.sleepycat.je.utilint.DbLsn
 
getFilesAtCheckpointStart() - Method in class com.sleepycat.je.cleaner.Cleaner
Returns a copy of the cleaned and processed files at the time a checkpoint starts.
getFilesAtCheckpointStart() - Method in class com.sleepycat.je.cleaner.FileSelector
Returns a copy of the CLEANED and FULLY_PROCESSED files at the time a checkpoint starts.
getFileSelector() - Method in class com.sleepycat.je.cleaner.Cleaner
 
getFileSummary(long) - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Returns a tracked file for the given file number, adding an empty one if the file is not already being tracked.
getFileSummaryDb() - Method in class com.sleepycat.je.cleaner.UtilizationProfile
For unit testing.
getFileSummaryMap(boolean) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Returns a copy of the current file summary map, optionally including tracked summary information, for use by the DbSpace utility and by unit tests.
getFirst() - Method in class com.sleepycat.asm.Label
Returns the first label of the series to which this label belongs.
getFirst(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getFirst(), join cursor is allowed.
getFirst(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the first key/data pair of the database, and returns that pair.
getFirst() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
getFirst() - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
getFirst(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getFirst(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the first key/data pair of the database, and return that pair.
getFirst(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getFirstActiveLsn() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getFirstActiveLsn() - Method in class com.sleepycat.je.txn.Txn
[#16861] The firstLoggedLsn field is volatile to avoid making getFirstActiveLsn synchronized, which causes a deadlock in HA.
getFirstActiveLsn() - Method in class com.sleepycat.je.txn.TxnManager
Get the earliest LSN of all the active transactions, for checkpoint.
getFirstFileNum() - Method in class com.sleepycat.je.log.FileManager
public for cleaner.
getFirstLsn() - Method in class com.sleepycat.je.log.LogBuffer
Return first LSN held in this buffer.
getFirstNode(CacheMode) - Method in class com.sleepycat.je.tree.Tree
Find the leftmost node (IN or BIN) in the tree.
getFirstNodeId() - Static method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the node ID that is associated with the very first node in the replication group.
getFirstOrLast(boolean) - Method in class com.sleepycat.collections.StoredCollection
 
getFirstTracked() - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
getFixedMemoryOverhead() - Method in class com.sleepycat.je.tree.BIN
 
getFixedMemoryOverhead() - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
getFixedMemoryOverhead() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
getFixedMemoryOverhead() - Method in class com.sleepycat.je.tree.IN
 
getFloat(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getFlushInterval() - Method in class com.sleepycat.je.rep.impl.node.LogFlusher
 
getFlushTask() - Method in class com.sleepycat.je.rep.impl.node.LogFlusher
 
getFollowingFileNum(long, boolean) - Method in class com.sleepycat.je.log.FileManager
Get the next file number before/after currentFileNum.
getForce() - Method in class com.sleepycat.je.CheckpointConfig
Returns the configuration of the checkpoint force option.
getForceFlag() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferMaster
 
getForeignKeyDatabase() - Method in class com.sleepycat.je.SecondaryConfig
Returns the database used to check the foreign key integrity constraint, or null if no foreign key constraint will be checked.
getForeignKeyDeleteAction() - Method in class com.sleepycat.je.SecondaryConfig
Returns the action taken when a referenced record in the foreign key database is deleted.
getForeignKeyNullifier() - Method in class com.sleepycat.je.SecondaryConfig
Returns the user-supplied object used for setting single-valued foreign keys to null.
getForeignMultiKeyNullifier() - Method in class com.sleepycat.je.SecondaryConfig
Returns the user-supplied object used for setting multi-valued foreign keys to null.
getFormat(int, boolean) - Method in interface com.sleepycat.persist.impl.Catalog
Returns a format for a given ID, or throws an exception.
getFormat(Class, boolean) - Method in interface com.sleepycat.persist.impl.Catalog
Returns a format for a given class, or throws an exception.
getFormat(String) - Method in interface com.sleepycat.persist.impl.Catalog
Returns a format by class name.
getFormat(String) - Method in class com.sleepycat.persist.impl.ComparatorCatalog
 
getFormat(int, boolean) - Method in class com.sleepycat.persist.impl.PersistCatalog
 
getFormat(Class, boolean) - Method in class com.sleepycat.persist.impl.PersistCatalog
Get a format for a given class, creating it if it does not exist.
getFormat(String) - Method in class com.sleepycat.persist.impl.PersistCatalog
 
getFormat(int, boolean) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
getFormat(Class, boolean) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
getFormat(String) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
getFormat(int, boolean) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
getFormat(Class, boolean) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
getFormat(String) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
getFormatData() - Method in class com.sleepycat.persist.impl.EnumFormat
Returns data needed for serialization of a CompositeKeyFormat.
getFormatId() - Method in class com.sleepycat.je.log.LogUtils.XidImpl
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.BooleanStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.FloatStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.IntStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.LongArrayStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.LongMaxStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.LongMinStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.LongStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.LSNStat
 
getFormattedValue() - Method in class com.sleepycat.je.utilint.Stat
Return a string with the stat value formatted as appropriate for its type.
getFormattedValue() - Method in class com.sleepycat.je.utilint.StringStat
 
getFreezeCount() - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
 
getFullFileName(long, String) - Method in class com.sleepycat.je.log.FileManager
 
getFullFileName(String) - Method in class com.sleepycat.je.log.FileManager
 
getFullFileNames(long) - Method in class com.sleepycat.je.log.FileManager
 
getFullyProcessedFiles() - Method in class com.sleepycat.je.cleaner.FileSelector.CheckpointStartCleanerState
 
getGeneration() - Method in class com.sleepycat.je.tree.IN
 
getGenericLogType() - Method in class com.sleepycat.je.tree.IN
 
getGenericLogType() - Method in class com.sleepycat.je.tree.LN
 
getGenericLogType() - Method in class com.sleepycat.je.tree.Node
Returns the generic LogEntryType for this node.
getGlobalTransactionId() - Method in class com.sleepycat.je.log.LogUtils.XidImpl
 
getGroup() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getGroup(RepImpl, String, ReplicaConsistencyPolicy) - Static method in class com.sleepycat.je.rep.impl.RepGroupDB
Returns all the members that are currently part of the replication group.
getGroup(ReplicaConsistencyPolicy) - Method in class com.sleepycat.je.rep.impl.RepGroupDB
 
getGroup(File) - Static method in class com.sleepycat.je.rep.impl.RepGroupDB
An internal API used to obtain group information by opening a stand alone environment handle and reading the RepGroupDB.
getGroup() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupResponse
 
getGroup() - Method in class com.sleepycat.je.rep.monitor.Monitor
Returns the current composition of the group.
getGroup() - Method in class com.sleepycat.je.rep.monitor.Protocol.GroupChange
 
getGroup() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Returns a description of the replication group as known by this node.
getGroup() - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Returns the current composition of the group from the Master.
getGroupCBVLSN() - Method in class com.sleepycat.je.rep.impl.node.RepNode
May return NULL_VLSN
getGroupDb() - Method in class com.sleepycat.je.rep.impl.RepImpl
Open the group db, which should exist already.
getGroupDb(ReplicaConsistencyPolicy) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getGroupDurableVLSN() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getGroupDurableVLSN() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getGroupMasterNameId() - Method in class com.sleepycat.je.rep.stream.MasterStatus
 
getGroupName() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateRequest
 
getGroupName() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getGroupName() - Method in class com.sleepycat.je.rep.monitor.Monitor
Returns the name of the group associated with the Monitor.
getGroupName() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Gets the name associated with the replication group.
getGroupName() - Method in class com.sleepycat.je.rep.NodeState
Returns the name of the group which the node joins.
getGroupName() - Method in class com.sleepycat.je.rep.ReplicationConfig
Gets the name associated with the replication group.
getGroupName() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
getGroupName() - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Returns the name of the replication group.
getGTEBucket(VLSN, VLSNBucket) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Get the vlsnBucket that owns this VLSN.
getGTEBucket(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
Return a bucket for reading a mapping for this VLSN.
getGTELsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
Return a lsn as a starting point for a backward scan.
getGTELsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Returns the mapping whose VLSN is >= the VLSN parameter.
getHandlerLevel(DbConfigManager, ConfigParam, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
getHeader() - Method in class com.sleepycat.je.log.LogItem
 
getHeader() - Method in class com.sleepycat.je.log.WholeEntry
 
getHeartbeatInterval() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getHelperHosts() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns the string identifying one or more helper host and port pairs in this format:
getHelperHosts() - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the string identifying one or more helper host and port pairs in this format:
getHelperSockets() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns the set of sockets associated with helper nodes.
getHelperSockets() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
getHelperSockets() - Method in class com.sleepycat.je.rep.ReplicationConfig
 
getHelperSockets() - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Returns the helper sockets being used to contact a replication group member, in order to query for the information.
getHigherProposal() - Method in class com.sleepycat.je.rep.elections.Protocol.Reject
 
getHighestFlushLevel(DatabaseImpl) - Method in class com.sleepycat.je.recovery.DirtyINMap
 
getHighestLevel() - Method in class com.sleepycat.je.dbi.DbTree
 
getHighestLevel(DatabaseImpl) - Method in class com.sleepycat.je.dbi.DbTree
 
getHighestProposal() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
getHome() - Method in class com.sleepycat.je.Environment
Returns the database environment's home directory.
getHookValue() - Method in interface com.sleepycat.je.utilint.TestHook
 
getHookValue() - Method in class com.sleepycat.je.utilint.TestHookAdapter
 
getHostName() - Method in class com.sleepycat.je.rep.elections.MasterValue
 
getHostName() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns the hostname associated with this node.
getHostName() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getHostName() - Method in interface com.sleepycat.je.rep.ReplicationNode
Returns the host name associated with the node.
getHostName() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
getHostname(String) - Static method in class com.sleepycat.je.rep.utilint.HostPortPair
Parses and returns the hostname string of a hostport pair
getHostPortPair() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getIcon(int) - Method in class com.sleepycat.util.ConfigBeanInfoBase
This method returns an image object that can be used to represent the bean in toolboxes, toolbars, etc.
getId() - Method in class com.sleepycat.je.dbi.DatabaseId
 
getId() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getId() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getId() - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
Returns the internally generated compact id.
getId() - Method in class com.sleepycat.je.Transaction
Return the transaction's unique ID.
getId() - Method in class com.sleepycat.je.TransactionStats.Active
The transaction ID of the transaction.
getId() - Method in class com.sleepycat.je.tree.NameLN
 
getId() - Method in class com.sleepycat.je.txn.Locker
 
getId() - Method in class com.sleepycat.je.txn.TxnEnd
 
getId() - Method in class com.sleepycat.persist.impl.Format
Returns the format ID.
getId() - Method in interface com.sleepycat.persist.raw.RawType
Returns the internal unique ID for this type.
getIdDatabaseImpl() - Method in class com.sleepycat.je.dbi.DbTree
 
getIdentifierKey() - Method in class com.sleepycat.je.tree.IN
 
getIllegal() - Method in class com.sleepycat.je.txn.LockUpgrade
This method is called to determine whether the upgrade is illegal.
getImmutableSecondaryKey() - Method in class com.sleepycat.je.SecondaryConfig
Returns whether the secondary key is immutable.
getImportunate() - Method in class com.sleepycat.je.txn.Locker
Get the state of a transaction's IMPORTUNATE bit.
getImportunate() - Method in class com.sleepycat.je.txn.Txn
Get the state of a transaction's IMPORTUNATE bit.
getIN(DatabaseImpl) - Method in class com.sleepycat.je.log.CleanerFileReader
Get the last entry seen by the reader as an IN.
getIN(DatabaseImpl) - Method in class com.sleepycat.je.log.entry.BINDeltaLogEntry
 
getIN(DatabaseImpl) - Method in interface com.sleepycat.je.log.entry.INContainingEntry
 
getIN(DatabaseImpl) - Method in class com.sleepycat.je.log.entry.INLogEntry
 
getIN(DatabaseImpl) - Method in class com.sleepycat.je.log.INFileReader
Get the last IN seen by the reader.
getInCompQueueSize() - Method in class com.sleepycat.je.EnvironmentStats
The number of entries in the INCompressor queue when the getStats() call was made.
getINCompressor() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Return the incompressor.
getINCompressorQueueSize() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getIncorrectlyOrderedSecKeys() - Method in class com.sleepycat.persist.impl.ComplexFormat
For unit testing.
getIndex() - Method in class com.sleepycat.je.dbi.CursorImpl
 
getIndexOffset() - Method in class com.sleepycat.collections.StoredCollection
 
getIndexOffset() - Method in class com.sleepycat.collections.StoredList
 
getInitialAdjustments() - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
getInitializeCache(EnvironmentConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getInitializeCDB(EnvironmentConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getInitializeLocking(EnvironmentConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getInitialLockTimeout() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
Don't let the ReplayTxn have a timeout of 0.
getInitialLockTimeout() - Method in class com.sleepycat.je.txn.Locker
 
getInitialValue() - Method in class com.sleepycat.je.SequenceConfig
Returns the initial value for a sequence..
getInitVersion(Format, boolean) - Method in interface com.sleepycat.persist.impl.Catalog
See above.
getInitVersion(Format, boolean) - Method in class com.sleepycat.persist.impl.PersistCatalog
When a format is intialized, this method is called to get the version of the serialized object to be initialized.
getInitVersion(Format, boolean) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
getInitVersion(Format, boolean) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
getInListResident() - Method in class com.sleepycat.je.tree.IN
Returns whether this IN is on the INList.
getINListStats(StatsConfig) - Method in class com.sleepycat.je.evictor.PrivateSelector
Return stats for the single INList covered by this evictor.
getINListStats(StatsConfig) - Method in class com.sleepycat.je.evictor.SharedSelector
Return stats for the multiple INLists covered by this evictor.
getINListStats(StatsConfig) - Method in class com.sleepycat.je.evictor.TargetSelector
 
getInMemoryINs() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getInMemorySize() - Method in class com.sleepycat.je.tree.IN
For unit tests.
getINNodeIdsSeen() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
getINsByLevel() - Method in class com.sleepycat.je.BtreeStats
Returns the count of Internal Nodes per level, indexed by level.
getINsByLevel() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
getInstance(Environment) - Static method in class com.sleepycat.collections.CurrentTransaction
Gets the CurrentTransaction accessor for a specified Berkeley DB environment.
getInstance() - Static method in class com.sleepycat.je.dbi.DbEnvPool
Access the singleton instance.
getInstanceFields(Class, ClassMetadata) - Static method in class com.sleepycat.persist.impl.FieldInfo
Returns a list of all non-transient non-static fields that are declared in the given class.
getInstanceInternal(Environment) - Static method in class com.sleepycat.collections.CurrentTransaction
Gets the CurrentTransaction accessor for a specified Berkeley DB environment.
getInt(IntConfigParam) - Method in class com.sleepycat.je.dbi.DbConfigManager
Get this parameter from the environment wide configuration settings.
getInt(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getInterfaces() - Method in class com.sleepycat.asm.ClassReader
Returns the internal names of the class's interfaces (see getInternalName).
getInternalEnvHandle() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getInternalMemoryLimit() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Returns the maximum amount of non JE Cache Memory that the DiskOrderedScan can use at one time.
getInternalMemoryLimit() - Method in class com.sleepycat.je.PreloadConfig
Returns the maximum amount of non JE Cache Memory that preload can use at one time.
getInternalName() - Method in class com.sleepycat.asm.Type
Returns the internal name of the class corresponding to this object or array type.
getInternalName(Class<?>) - Static method in class com.sleepycat.asm.Type
Returns the internal name of the given class.
getInternalName() - Method in enum com.sleepycat.je.dbi.DbType
Returns the DB name for an internal DB type.
getInternalNodeCount() - Method in class com.sleepycat.je.BtreeStats
Returns the number of Internal Nodes in the database tree.
getInternalNoLookupDbNames() - Method in class com.sleepycat.je.dbi.DbTree
Return a list of the names of internally used databases that don't get looked up through the naming tree.
getInternalNoRepDbNames() - Method in class com.sleepycat.je.dbi.DbTree
Return a list of the names of internally used databases for all environment types.
getInternalReadOperationLocker(EnvironmentImpl) - Static method in class com.sleepycat.je.txn.LockerFactory
Get a non-transactional locker for internal database operations.
getInternalRepDbNames() - Method in class com.sleepycat.je.dbi.DbTree
Return a list of the names of internally used databases for replication only.
getIntervalLatency() - Method in class com.sleepycat.utilint.StatsTracker
 
getIntLogSize() - Static method in class com.sleepycat.je.log.LogUtils
 
getIntVal(Properties, IntConfigParam) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for getting integer values.
getInvalidatingException() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getInvariantSizeMinusChecksum() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getInvoker() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getItem(int) - Method in class com.sleepycat.asm.ClassReader
Returns the start index of the constant pool item in b, plus one.
getItemCount() - Method in class com.sleepycat.asm.ClassReader
Returns the number of constant pool items in b.
getItemSize() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getIteratorBlockSize() - Method in class com.sleepycat.collections.StoredCollection
Returns the number of records read at one time by iterators returned by the StoredCollection.iterator() method.
getJavaCommand(Class<?>) - Static method in class com.sleepycat.je.utilint.CmdUtil
Returns a description of the java command for running a utility, without arguments.
getJERootDir() - Method in class com.sleepycat.je.jca.ra.JERequestInfo
 
getJEVersion() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
getJEVersion() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getJEVersion() - Method in class com.sleepycat.je.rep.NodeState
Returns the current JEVersion that this node runs on.
getJoinTime() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getJoinTime() - Method in class com.sleepycat.je.rep.impl.node.MonitorEventManager
 
getJoinTime() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
getJoinTime() - Method in class com.sleepycat.je.rep.monitor.JoinGroupEvent
Returns the time at which the node joined the group.
getJoinTime() - Method in class com.sleepycat.je.rep.monitor.LeaveGroupEvent
 
getJoinTime() - Method in class com.sleepycat.je.rep.NodeState
Returns the time when this node joins the replication group.
getKBytes() - Method in class com.sleepycat.je.CheckpointConfig
Returns the checkpoint log data threshold, in kilobytes.
getKey() - Method in class com.sleepycat.collections.MapEntryParameter
Returns the key of this entry.
getKey() - Method in class com.sleepycat.je.cleaner.LNInfo
 
getKey() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getKey() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
getKey() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
getKey() - Method in class com.sleepycat.je.rep.util.ldiff.Record
 
getKey() - Method in class com.sleepycat.je.Sequence
Returns the DatabaseEntry used to open this sequence.
getKey() - Method in interface com.sleepycat.je.sync.ChangeReader.Change
Returns the record key for this change.
getKey() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChange
 
getKey() - Method in class com.sleepycat.je.tree.BINReference
 
getKey() - Method in class com.sleepycat.je.tree.ChildReference
Return the key for this ChildReference.
getKey() - Method in class com.sleepycat.je.tree.DeltaInfo
 
getKey(int) - Method in class com.sleepycat.je.tree.IN
Return the idx'th key.
getKey() - Method in class com.sleepycat.je.tree.Key
Get the byte array for the key.
getKeyAssigner() - Method in class com.sleepycat.persist.impl.PersistEntityBinding
 
getKeyBinding() - Method in class com.sleepycat.je.sync.RecordMapping
Returns the key binding, or null if an entity binding is used.
getKeyBinding() - Method in class com.sleepycat.persist.PrimaryIndex
Returns the primary key binding for this index.
getKeyBinding() - Method in class com.sleepycat.persist.SecondaryIndex
Returns the secondary key binding for the index.
getKeyClass() - Method in class com.sleepycat.persist.PrimaryIndex
Returns the primary key class for this index.
getKeyClass() - Method in class com.sleepycat.persist.SecondaryIndex
Returns the secondary key class for this index.
getKeyComparator() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Should always be used when comparing keys for this database.
getKeyComparator() - Method in class com.sleepycat.je.tree.IN
Convenience method to return the database key comparator.
getKeyCreator(Class<V>, String) - Method in class com.sleepycat.collections.TupleSerialFactory
Creates a SecondaryKeyCreator object for use in configuring a SecondaryDatabase.
getKeyCreator() - Method in class com.sleepycat.je.SecondaryConfig
Returns the user-supplied object used for creating single-valued secondary keys.
getKeyLocation(Format) - Method in class com.sleepycat.persist.impl.RecordInput
Called when copying secondary keys, for an input that is positioned on the secondary key field.
getKeyName() - Method in class com.sleepycat.persist.model.SecondaryKeyMetadata
Returns the key name, which may be different from the field name.
getKeyPrefix() - Method in class com.sleepycat.je.tree.IN
 
getKeyPrefixing() - Method in class com.sleepycat.je.DatabaseConfig
Returns the key prefixing configuration.
getKeyPrefixing() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getKeyPrefixing(byte) - Static method in class com.sleepycat.je.dbi.DatabaseImpl
Returns true if the flagVal enables the KeyPrefixing, used to create ReplicatedDatabaseConfig after reading a NameLNLogEntry.
getKeyPrefixLength(byte[], int, byte[]) - Static method in class com.sleepycat.je.tree.Key
 
getKeyRatios(List<TrackingInfo>, boolean) - Static method in class com.sleepycat.je.tree.CountEstimator
 
getKeysDatabase() - Method in class com.sleepycat.persist.SecondaryIndex
Returns the underlying secondary database that is not associated with the primary database and is used for the SecondaryIndex.keysIndex.
getKeysOnly() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Returns true if the DiskOrderedCursor is configured to return only keys.
getKeyThang() - Method in class com.sleepycat.collections.DataCursor
Returns the internal key entry.
getKeyVals() - Method in class com.sleepycat.je.tree.IN
 
getKnownClasses() - Method in class com.sleepycat.persist.impl.StoredModel
 
getKnownClasses() - Method in class com.sleepycat.persist.model.AnnotationModel
 
getKnownClasses() - Method in class com.sleepycat.persist.model.EntityModel
Returns the names of all known persistent classes.
getKnownMasterCommitVLSN() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getKnownMasterTxnEndVLSN() - Method in class com.sleepycat.je.rep.NodeState
Returns the transaction end VLSN on the master known by this node.
getKnownSpecialClasses() - Method in class com.sleepycat.persist.model.AnnotationModel
 
getKnownSpecialClasses() - Method in class com.sleepycat.persist.model.EntityModel
Returns the names of all known persistent enum and array classes that may be used to store persistent data.
getLabels() - Method in class com.sleepycat.asm.Attribute
Returns the labels corresponding to this attribute.
getLast(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getLast(), no join cursor allowed.
getLast(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the last key/data pair of the database, and returns that pair.
getLast() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
getLast() - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
getLast(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getLast(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the last key/data pair of the database, and return that pair.
getLast(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getLastCBVLSN() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl.BarrierState
 
getLastCheckpointEnd() - Method in class com.sleepycat.je.EnvironmentStats
The location in the log of the last checkpoint end.
getLastCheckpointId() - Method in class com.sleepycat.je.EnvironmentStats
The Id of the last checkpoint.
getLastCheckpointStart() - Method in class com.sleepycat.je.EnvironmentStats
The location in the log of the last checkpoint start.
getLastDeltaVersion() - Method in class com.sleepycat.je.tree.BIN
Overrides the IN method to account for deltas.
getLastDeltaVersion() - Method in class com.sleepycat.je.tree.IN
Returns the last delta version LSN, or NULL_LSN if a delta was not last logged.
getLastEntryInPrevFileOffset() - Method in class com.sleepycat.je.log.FileHeader
 
getLastEntrySize() - Method in class com.sleepycat.je.log.FileReader
Returns the total size (including header) of the last entry read.
getLastFileInBackupSet() - Method in class com.sleepycat.je.util.DbBackup
Can only be called in backup mode, after startBackup() has been called.
getLastFileNum() - Method in class com.sleepycat.je.log.FileManager
 
getLastFullLsn() - Method in class com.sleepycat.je.tree.BINDelta
 
getLastFullVersion() - Method in class com.sleepycat.je.tree.IN
Returns the last full version LSN, or NULL_LSN if never logged.
getLastLocalDbId() - Method in class com.sleepycat.je.dbi.DbTree
The last allocated local and replicated db ids are used for ckpts.
getLastLocalDbId() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getLastLocalNodeId() - Method in class com.sleepycat.je.dbi.NodeSequence
The last allocated local and replicated node IDs are used for ckpts.
getLastLocalNodeId() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getLastLocalTxnId() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getLastLocalTxnId() - Method in class com.sleepycat.je.txn.TxnManager
Get the last used id, for checkpoint info.
getLastLoggedSize() - Method in class com.sleepycat.je.log.entry.BaseEntry
By default, return zero because the last logged size is unknown.
getLastLoggedSize() - Method in class com.sleepycat.je.log.entry.LNLogEntry
Returns the last logged size, saved by readEntry and writeEntry.
getLastLoggedSize() - Method in interface com.sleepycat.je.log.entry.LogEntry
 
getLastLoggedSize() - Method in class com.sleepycat.je.tree.LN
Returns the total last logged log size, including the LNLogEntry overhead of this LN when it was last logged and the log entry header.
getLastLoggedVersion() - Method in class com.sleepycat.je.tree.BIN
Overrides the IN method to account for deltas.
getLastLoggedVersion() - Method in class com.sleepycat.je.tree.IN
Returns the last logged LSN, or NULL_LSN if never logged.
getLastLsn() - Method in class com.sleepycat.je.log.FileReader
Get LSN of the last entry read.
getLastLsn() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
getLastLsn() - Method in class com.sleepycat.je.txn.Txn
Access to last LSN.
getLastLsn() - Method in class com.sleepycat.je.txn.TxnEnd
 
getLastLsnAtRecovery() - Method in class com.sleepycat.je.log.LogManager
 
getLastMatchpointLsn() - Method in class com.sleepycat.je.rep.vlsn.VLSNRecoveryTracker
 
getLastMatchpointVLSN() - Method in class com.sleepycat.je.rep.vlsn.VLSNRecoveryTracker
 
getLastModifiedTime() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
getLastNode(CacheMode) - Method in class com.sleepycat.je.tree.Tree
Find the rightmost node (IN or BIN) in the tree.
getLastObject() - Method in class com.sleepycat.je.log.SearchFileReader
 
getLastOnDisk() - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
getLastReplayedTxn() - Method in class com.sleepycat.je.rep.impl.node.Replay
 
getLastReplayedVLSN() - Method in class com.sleepycat.je.rep.impl.node.Replay
 
getLastReplicatedDbId() - Method in class com.sleepycat.je.dbi.DbTree
 
getLastReplicatedDbId() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getLastReplicatedNodeId() - Method in class com.sleepycat.je.dbi.NodeSequence
 
getLastReplicatedNodeId() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getLastReplicatedTxnId() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getLastReplicatedTxnId() - Method in class com.sleepycat.je.txn.TxnManager
 
getLastSeen(LogEntryType) - Method in class com.sleepycat.je.log.LastFileReader
 
getLastSync() - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
getLastSyncEnd() - Method in class com.sleepycat.je.sync.impl.LogChangeSet
 
getLastTxnEnd() - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
getLastUsedLsn() - Method in class com.sleepycat.je.log.FileManager
Return the last allocated LSN in the log.
getLastValidLsn() - Method in class com.sleepycat.je.log.LastFileReader
 
getLastValidVLSN() - Method in class com.sleepycat.je.txn.TxnChain
 
getLastValue() - Method in class com.sleepycat.je.SequenceStats
Returns the last cached value of the sequence.
getLastVLSN(Long) - Method in class com.sleepycat.je.cleaner.FileSelector
Returns the last VLSN for a cleaned file.
getLastVLSN() - Method in class com.sleepycat.je.log.CleanerFileReader
Returns the last VLSN encountered, or NULL_VLSN if no entries were replicated.
getLatchQueueLength() - Method in class com.sleepycat.je.tree.IN
 
getLatchStats() - Method in class com.sleepycat.je.latch.Latch
 
getLatchString() - Method in class com.sleepycat.je.tree.IN
 
getLatestAllocatedVal() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
For testing and internal use.
getLatestVersion() - Method in class com.sleepycat.persist.impl.Format
If this is the latest/evolved format, returns this; otherwise, returns the current version of this format.
getLatestVersion(String) - Method in class com.sleepycat.persist.impl.PersistCatalog
 
getLeader() - Method in class com.sleepycat.je.log.FSyncManager.FSyncGroup
 
getLeafNodeCount() - Method in class com.sleepycat.je.BtreeStats
Returns the number of leaf nodes in the database tree, which can equal the number of records.
getLearner() - Method in class com.sleepycat.je.rep.elections.Elections
Returns the Learner associated with this node
getLearnerSockets() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Return all learner sockets.
getLeaseCount() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
Returns the number of leases that are currently outstanding.
getLeaseDuration() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
getLeaseRenewalCount() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
Returns the number of times the lease was actually renewed.
getLeaveReason() - Method in class com.sleepycat.je.rep.monitor.LeaveGroupEvent
Returns the reason why the node left the group.
getLeaveReason() - Method in class com.sleepycat.je.rep.monitor.Protocol.LeaveGroup
 
getLeaveTime() - Method in class com.sleepycat.je.rep.monitor.LeaveGroupEvent
Returns the time at which the node left the group.
getLeaveTime() - Method in class com.sleepycat.je.rep.monitor.Protocol.LeaveGroup
 
getLevel() - Method in class com.sleepycat.je.tree.IN
 
getLevel() - Method in class com.sleepycat.je.tree.Node
Cover for LN's and just return 0 since they'll always be at the bottom of the tree.
getLN() - Method in class com.sleepycat.je.cleaner.LNInfo
 
getLN() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getLNCount() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
getLNLogEntry() - Method in class com.sleepycat.je.log.CleanerFileReader
Get the last LN log entry seen by the reader.
getLNLogEntry() - Method in class com.sleepycat.je.log.LNFileReader
Get the last LN log entry seen by the reader.
getLNSizeCorrectionFactor() - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Returns the factor to be multiplied by the average LN size (for LNs with uncounted sizes) to correct for differences between obsolete and active LN sizes.
getLNSizeCorrectionFactor() - Method in class com.sleepycat.je.EnvironmentStats
The factor used to correct average LN size, for LNs whose obsolete size is unknown.
getLoadLNs() - Method in class com.sleepycat.je.PreloadConfig
Return the configuration of the preload load LNs option.
getLoadPropertyFile() - Method in class com.sleepycat.je.EnvironmentMutableConfig
For unit testing, to prevent loading of je.properties.
getLocalBeginData() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
getLocalBeginKey() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
getLocalDiffSize() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
getLocalName() - Method in class com.sleepycat.je.sync.SyncDatabase
Returns the name of the local JE Database, or null if a default local name is to be used but has not yet been assigned.
getLocalSync() - Method in class com.sleepycat.je.Durability
Returns the transaction synchronization policy to be used locally when committing a transaction.
getLocalTransaction() - Method in class com.sleepycat.je.jca.ra.JEConnection
 
getLocalTransaction() - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
getLockBytes() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes of JE cache used for holding locks and transactions.
getLocker() - Method in class com.sleepycat.je.dbi.CursorImpl
 
getLocker(Transaction) - Static method in class com.sleepycat.je.DbInternal
Proxy to Transaction.getLocker()
getLocker() - Method in class com.sleepycat.je.Transaction
This method should only be called by the LockerFactory.getReadableLocker and getWritableLocker methods.
getLocker() - Method in class com.sleepycat.je.txn.LockInfo
 
getLockGrant() - Method in class com.sleepycat.je.txn.LockResult
 
getLocking() - Method in class com.sleepycat.je.EnvironmentConfig
Returns true if the database environment is configured for locking.
getLockManager() - Method in class com.sleepycat.je.txn.TxnManager
Give transactions and environment access to lock manager.
getLockMemoryUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget
Public for unit testing.
getLockMode(boolean) - Method in class com.sleepycat.collections.DataCursor
Returns the lock mode to use for a getXxx() operation.
getLockResult() - Method in class com.sleepycat.je.dbi.CursorImpl.LockStanding
 
getLockStats() - Method in class com.sleepycat.je.dbi.CursorImpl
 
getLockStats(StatsConfig) - Method in class com.sleepycat.je.Environment
Deprecated.
as of 4.0.10, replaced by Environment.getStats(StatsConfig).

getLockTableIndex(Long) - Method in class com.sleepycat.je.txn.LockManager
 
getLockTableIndex(long) - Method in class com.sleepycat.je.txn.LockManager
 
getLockTimeout() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getLockTimeout(TimeUnit) - Method in class com.sleepycat.je.EnvironmentConfig
Returns the lock timeout setting.
getLockTimeout() - Method in class com.sleepycat.je.EnvironmentConfig
Deprecated.
getLockTimeout(TimeUnit) - Method in class com.sleepycat.je.Transaction
Returns the lock request timeout value for the transaction.
getLockTimeout() - Method in class com.sleepycat.je.txn.BuddyLocker
Returns the lock timeout of the buddy locker, since this locker has no independent timeout.
getLockTimeout() - Method in class com.sleepycat.je.txn.Locker
Get the lock timeout period for this locker, in milliseconds WARNING: Be sure to always access the timeout with this accessor, since it is overridden in BuddyLocker.
getLockType() - Method in class com.sleepycat.je.txn.LockInfo
 
getLogBufferBudget() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
getLogBufferSize() - Method in class com.sleepycat.je.log.LogBufferPool
 
getLogEntry(long) - Method in class com.sleepycat.je.log.LogManager
Instantiate all the objects in the log entry at this LSN.
getLogEntry() - Method in class com.sleepycat.je.rep.stream.InputWireRecord
 
getLogEntryAllowChecksumException(long) - Method in class com.sleepycat.je.log.LogManager
Throws ChecksumException rather than translating it to EnvironmentFailureException and invalidating the environment.
getLogEntryAllowChecksumException(long, RandomAccessFile, int) - Method in class com.sleepycat.je.log.LogManager
 
getLogEntryAllowInvisible(long) - Method in class com.sleepycat.je.log.LogManager
Instantiate all the objects in the log entry at this LSN.
getLogEntryAllowInvisibleAtRecovery(long) - Method in class com.sleepycat.je.log.LogManager
Instantiate all the objects in the log entry at this LSN.
getLogEntryFromLogSource(long, LogSource, boolean) - Method in class com.sleepycat.je.log.LogManager
Instantiate all the objects in the log entry at this LSN.
getLogEntryHandleFileNotFound(long) - Method in class com.sleepycat.je.log.LogManager
 
getLogEntryType() - Method in class com.sleepycat.je.log.LNFileReader
Return the type of this log entry.
getLogFilesInBackupSet() - Method in class com.sleepycat.je.util.DbBackup
Get the list of all files that are needed for the environment at the point of time when backup mode started.
getLogFilesInBackupSet(long) - Method in class com.sleepycat.je.util.DbBackup
Deprecated.
replaced by DbBackup.getLogFilesInBackupSet(); pass lastFileInPrevBackup to the DbBackup.DbBackup(Environment,long) constructor.
getLogFlusher() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getLogger() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getLogger() - Method in class com.sleepycat.je.rep.elections.ElectionAgentThread
 
getLogger() - Method in class com.sleepycat.je.rep.elections.Elections
 
getLogger() - Method in class com.sleepycat.je.rep.elections.Learner
 
getLogger() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
getLogger() - Method in class com.sleepycat.je.rep.impl.networkRestore.LogFileFeeder
 
getLogger() - Method in class com.sleepycat.je.rep.impl.node.Replica.ReplayThread
 
getLogger() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getLogger() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
 
getLogger(Class<?>) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Get a logger which is configured to use the shared console, memory, and file handlers of an EnvironmentImpl and prefixes all messages with an environment identifier.
getLogger() - Method in class com.sleepycat.je.utilint.StoppableThread
 
getLoggerFixedPrefix(Class<?>, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
getLoggerFixedPrefix(Class<?>, String, EnvironmentImpl) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Get a logger that uses the generic console handler, with no attempt to use thread local state to customize the message prefix.
getLoggerFormatterNeeded(Class<?>) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Get a logger which only publishes to a console handler.
getLoggerProperty(String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
getLoggingHandler() - Method in class com.sleepycat.je.EnvironmentConfig
Returns the custom java.util.logging.Handler specified by the application.
getLogItem() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.VLSNAwaitLatch
Returns the log item that caused the latch to be released.
getLogManager() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getLogManager() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getLogProvider() - Method in class com.sleepycat.je.rep.NetworkRestore
 
getLogProviders() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns a list of nodes suitable for feeding log files for a network restore.
getLogProviders() - Method in exception com.sleepycat.je.rep.InsufficientLogException
Returns the members of the replication group that can serve as candidate log providers to supply the logs needed by this node.
getLogProviders() - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
Returns the candidate list of members that may be used to obtain log files.
getLogProviders() - Method in class com.sleepycat.je.rep.stream.Protocol.RestoreResponse
 
getLogSize() - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
getLogSize() - Method in class com.sleepycat.je.cleaner.DbFileSummary
 
getLogSize() - Method in class com.sleepycat.je.cleaner.FileSummary
 
getLogSize() - Method in class com.sleepycat.je.cleaner.PackedOffsets
 
getLogSize() - Method in class com.sleepycat.je.dbi.DatabaseId
 
getLogSize() - Method in class com.sleepycat.je.dbi.DatabaseImpl
This log entry type is configured to perform marshaling (getLogSize and writeToLog) under the write log mutex.
getLogSize() - Method in class com.sleepycat.je.dbi.DbTree
 
getLogSize() - Method in class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
 
getLogSize() - Method in enum com.sleepycat.je.log.entry.DbOperationType
 
getLogSize() - Method in class com.sleepycat.je.log.FileHeader
 
getLogSize() - Method in interface com.sleepycat.je.log.Loggable
 
getLogSize() - Method in class com.sleepycat.je.log.Trace
 
getLogSize() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getLogSize() - Method in class com.sleepycat.je.recovery.CheckpointStart
 
getLogSize() - Method in class com.sleepycat.je.tree.BINDelta
 
getLogSize() - Method in class com.sleepycat.je.tree.ChildReference
 
getLogSize() - Method in class com.sleepycat.je.tree.DeltaInfo
 
getLogSize() - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
getLogSize() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
getLogSize() - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
getLogSize() - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
getLogSize() - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
getLogSize() - Method in class com.sleepycat.je.tree.FileSummaryLN
This log entry type is configured to perform marshaling (getLogSize and writeToLog) under the write log mutex.
getLogSize() - Method in class com.sleepycat.je.tree.IN
 
getLogSize() - Method in class com.sleepycat.je.tree.LN
 
getLogSize() - Method in class com.sleepycat.je.tree.MapLN
 
getLogSize() - Method in class com.sleepycat.je.tree.NameLN
 
getLogSize() - Method in class com.sleepycat.je.tree.Node
 
getLogSize() - Method in class com.sleepycat.je.tree.Tree
 
getLogSize() - Method in class com.sleepycat.je.txn.RollbackEnd
 
getLogSize() - Method in class com.sleepycat.je.txn.RollbackStart
 
getLogSize() - Method in class com.sleepycat.je.txn.Txn
 
getLogSize() - Method in class com.sleepycat.je.txn.TxnEnd
 
getLogSize() - Method in class com.sleepycat.je.txn.TxnPrepare
 
getLogSize() - Method in class com.sleepycat.je.utilint.Matchpoint
 
getLogSize() - Method in class com.sleepycat.je.utilint.VLSN
 
getLogSource(long) - Method in class com.sleepycat.je.log.LogManager
Find the LSN, whether in a file or still in the log buffers.
getLogSummary() - Method in class com.sleepycat.je.cleaner.Cleaner
 
getLogSummary() - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Returns log summary info that should be saved persistently.
getLogType() - Method in class com.sleepycat.je.log.entry.BaseEntry
 
getLogType() - Method in interface com.sleepycat.je.log.entry.LogEntry
 
getLogType() - Method in class com.sleepycat.je.tree.BIN
 
getLogType() - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
getLogType() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
getLogType(boolean, boolean) - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
Return the correct log entry type for a DupCountLN depends on whether it's transactional.
getLogType(boolean, boolean) - Method in class com.sleepycat.je.tree.FileSummaryLN
Return the correct log type for a FileSummaryLN.
getLogType() - Method in class com.sleepycat.je.tree.IN
Get the log type of this node.
getLogType(boolean, boolean) - Method in class com.sleepycat.je.tree.LN
 
getLogType(boolean, boolean) - Method in class com.sleepycat.je.tree.MapLN
Return the correct log entry type for a MapLN depends on whether it's transactional.
getLogType(boolean, boolean) - Method in class com.sleepycat.je.tree.NameLN
Return the correct log entry type for a NameLN depends on whether it's transactional.
getLogVersion() - Method in class com.sleepycat.je.log.FileHandle
 
getLogVersion() - Method in class com.sleepycat.je.log.FileHandleSource
 
getLogVersion() - Method in class com.sleepycat.je.log.FileHeader
 
getLogVersion() - Method in class com.sleepycat.je.log.FileSource
 
getLogVersion() - Method in class com.sleepycat.je.log.LogBuffer
Entries in write buffers are always the current version.
getLogVersion() - Method in interface com.sleepycat.je.log.LogSource
Returns the log version of the log entries from this source.
getLogVersion() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
getLogVersion() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getLogVersion() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getLogVersion() - Method in class com.sleepycat.je.rep.NodeState
Returns the log version of this node.
getLogVersion() - Method in class com.sleepycat.je.rep.stream.Protocol.JEVersions
 
getLogWriter() - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
getLogWriter() - Method in class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
getLong(LongConfigParam) - Method in class com.sleepycat.je.dbi.DbConfigManager
Get this parameter from the environment wide configuration settings.
getLong(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getLongArray(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getLongLogSize() - Static method in class com.sleepycat.je.log.LogUtils
 
getLongStat(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getLowestLevelSet() - Method in class com.sleepycat.je.recovery.DirtyINMap
Get the lowest level currently stored in the map.
getLowUtilizationFiles() - Method in class com.sleepycat.je.cleaner.FileSelector
Returns a read-only set of low utilization files that can be accessed without synchronization.
getLSN() - Method in class com.sleepycat.je.dbi.RecordVersion
 
getLsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
There is no mapping for this VLSN, so always return NULL_LSN.
getLsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
getLsn() - Method in class com.sleepycat.je.tree.ChildReference
Return the LSN for this ChildReference.
getLsn() - Method in class com.sleepycat.je.tree.DeltaInfo
 
getLsn(int) - Method in class com.sleepycat.je.tree.IN
Return the idx'th LSN for this entry.
getLSNBatchSize() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Returns the maximum number of LSNs to be sorted that this DiskOrderedCursor is configured for.
getLSNBatchSize() - Method in class com.sleepycat.je.PreloadConfig
Preload is implemented to optimize I/O cost by fetching the records of a Database by disk order, so that disk access is are sequential rather than random.
getLsnForVLSN(VLSN, int) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getLsnForVLSN(VLSN, int) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getLTEBucket(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
Get the bucket which holds a mapping for this VLSN.
getLTEBucketFromDatabase(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
getLTEFileNumber() - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
Return a file number that is less or equal to the first mapped vlsn, for use in determining the CBVLSN.
getLTEFileNumber() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Return a file number that is less or equal to the first lsn mapped by this bucket.
getLTEFileNumber(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Return the nearest file number <= the log file that houses this VLSN.
getLTELsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
Return a lsn as a starting point for a forward scan.
getLTELsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Returns the lsn whose VLSN is <= the VLSN parameter.
getMainItem() - Method in class com.sleepycat.je.log.entry.INLogEntry
 
getMainItem() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getMainItem() - Method in interface com.sleepycat.je.log.entry.LogEntry
 
getMainItem() - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
getMainItem() - Method in class com.sleepycat.je.log.LNFileReader
 
getMainTreeMaxDepth() - Method in class com.sleepycat.je.BtreeStats
Returns the maximum depth of the main database tree.
getMainTreeMaxDepth() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
getMajor() - Method in class com.sleepycat.je.JEVersion
Major number of the release version.
getMajorVersionNumber(String) - Method in class com.sleepycat.je.rep.impl.TextProtocol
Returns the Integer number which represents a Protocol version.
getMap() - Method in class com.sleepycat.je.rep.impl.node.DbCache
 
getMaster() - Method in exception com.sleepycat.je.rep.impl.node.Replica.HardRecoveryElectionException
The master that needs to be verified with an election.
getMasterName() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getMasterName() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getMasterName() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
getMasterName() - Method in class com.sleepycat.je.rep.monitor.MemberChangeEvent
Returns the name of the master at the time of this event.
getMasterName() - Method in class com.sleepycat.je.rep.NodeState
Returns the name of the current master known by this node.
getMasterNodeId() - Method in class com.sleepycat.je.txn.TxnEnd
 
getMasterNodeId() - Method in class com.sleepycat.je.utilint.Matchpoint
 
getMasterNodeName() - Method in class com.sleepycat.je.rep.monitor.Monitor
Identifies the master of the replication group, resulting from the last successful election.
getMasterNodeName() - Method in class com.sleepycat.je.rep.StateChangeEvent
Returns the node name identifying the master at the time of the event.
getMasterNodeName() - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Returns the node name associated with the master
getMasterNow() - Method in class com.sleepycat.je.rep.stream.Protocol.Heartbeat
 
getMasterStatus() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getMasterTxnEndTime() - Method in class com.sleepycat.je.rep.impl.node.Replay.TxnInfo
 
getMasterTxnEndVLSN() - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
 
getMasterTxnEndVLSN() - Method in class com.sleepycat.je.rep.impl.node.Replica
Returns the last commit VLSN at the master, as known at the replica.
getMatchedVLSN() - Method in class com.sleepycat.je.rep.stream.ReplicaFeederSyncup
 
getMatchedVLSNTime() - Method in class com.sleepycat.je.rep.stream.ReplicaFeederSyncup
 
getMatchpoint() - Method in class com.sleepycat.je.txn.RollbackEnd
 
getMatchpoint() - Method in class com.sleepycat.je.txn.RollbackStart
 
getMatchpointLSN() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
 
getMatchpointVLSN() - Method in class com.sleepycat.je.txn.RollbackStart
 
getMax() - Method in class com.sleepycat.je.SequenceStats
Returns the maximum permitted value of the sequence.
getMax() - Method in class com.sleepycat.utilint.Latency
 
getMaxBtreeSize() - Method in class com.sleepycat.je.util.DbCacheSize
 
getMaxBtreeSizeWithData() - Method in class com.sleepycat.je.util.DbCacheSize
 
getMaxBytes() - Method in class com.sleepycat.je.PreloadConfig
Return the number of bytes in the cache to stop the preload at.
getMaxClockDelta(TimeUnit) - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the maximum acceptable clock skew between this Replica and its Feeder, which is the node that is the source of its replication stream.
getMaxConnectionAttempts() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Return the maximum number of times the operation will attempt to connect to the remote service before aborting.
getMaxConnections() - Method in class com.sleepycat.je.jca.ra.JEConnectionMetaData
 
getMaxDbId() - Method in class com.sleepycat.je.log.INFileReader
Get the maximum DB ID seen by the reader.
getMaxEntries() - Method in class com.sleepycat.je.rep.impl.node.DbCache
Returns the max entries that can be held by the cache.
getMaxEntries() - Method in class com.sleepycat.je.tree.IN
 
getMaxErrors() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Return the maximum number of errors to analyze before ending the LDiff operation.
getMaxLNs() - Method in class com.sleepycat.je.tree.Tree
Cheaply calculates and returns the maximum possible number of LNs in the btree.
getMaxMemory() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
getMaxMemory() - Method in class com.sleepycat.je.dbi.MemoryBudget.Totals
 
getMaxMillisecs() - Method in class com.sleepycat.je.PreloadConfig
Return the number of millisecs to stop the preload after.
getMaxNodeId() - Method in class com.sleepycat.je.log.INFileReader
Get the maximum node ID seen by the reader.
getMaxObsoleteLNSize() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns the maximum possible obsolete LN size, using the maximum LN size for LN sizes that were not counted.
getMaxObsoleteSize() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns an estimate of the total bytes that are obsolete, using getMaxObsoleteLNSize instead of getObsoleteLNSize.
getMaxOperations() - Method in class com.sleepycat.je.sync.ExportConfig
 
getMaxOperations() - Method in class com.sleepycat.je.sync.ImportConfig
 
getMaxRetries() - Method in class com.sleepycat.collections.TransactionRunner
Returns the maximum number of retries that will be performed when deadlocks are detected.
getMaxSeedMillisecs() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Returns the maximum time (in milliseconds) to spend seeding the Disk Ordered Scan.
getMaxSeedNodes() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Returns the maximum number of internal nodes to use to seed the Disk Ordered Scan.
getMaxSeedTestHook() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
 
getMaxStringLength() - Method in class com.sleepycat.asm.ClassReader
Returns the maximum length of the strings contained in the constant pool of the class.
getMaxTime(TimeUnit) - Method in class com.sleepycat.je.sync.ExportConfig
 
getMaxTime(TimeUnit) - Method in class com.sleepycat.je.sync.ImportConfig
 
getMaxTrackedLatencyMillis() - Method in class com.sleepycat.utilint.Latency
 
getMaxTxnId() - Method in class com.sleepycat.je.log.INFileReader
Get the maximum txn ID seen by the reader.
getMBeanInfo() - Method in class com.sleepycat.je.jmx.JEMBean
 
getMd5Hash() - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
getMd5Hash() - Method in class com.sleepycat.je.rep.util.ldiff.Window
Compute the MD5 hash for the window.
getMeasuredBtreeSize() - Method in class com.sleepycat.je.util.DbCacheSize
 
getMeasuredBtreeSizeWithData() - Method in class com.sleepycat.je.util.DbCacheSize
 
getMember(int) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
 
getMember(String) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Lookup for existing members.
getMember(String) - Method in class com.sleepycat.je.rep.ReplicationGroup
Get administrative information about a node by its node name.
getMemoryBudget() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getMemorySize() - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
 
getMemorySize() - Method in class com.sleepycat.je.cleaner.LNInfo
Note that the dbId is not counted because it is shared with the DatabaseImpl, where it is accounted for in the memory budget.
getMemorySize() - Method in class com.sleepycat.je.cleaner.PackedObsoleteInfo
 
getMemorySize() - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Return the total memory size for this object.
getMemorySize() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker.DeltaINEntry
 
getMemorySize() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker.INEntry
 
getMemorySize() - Method in class com.sleepycat.je.tree.BINDelta
Returns the number of bytes occupied by this object.
getMemorySize() - Method in class com.sleepycat.je.tree.DeltaInfo
Returns the number of bytes occupied by this object.
getMemorySize() - Method in class com.sleepycat.je.tree.VLSNCache.DefaultCache
 
getMemorySize() - Method in class com.sleepycat.je.tree.VLSNCache
 
getMemorySizeIncludedByParent() - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
Compute the approximate size of this node in memory for evictor invocation purposes.
getMemorySizeIncludedByParent() - Method in class com.sleepycat.je.tree.FileSummaryLN
Overrides this method to add space occupied by this object's fields.
getMemorySizeIncludedByParent() - Method in class com.sleepycat.je.tree.LN
Compute the approximate size of this node in memory for evictor invocation purposes.
getMemorySizeIncludedByParent() - Method in class com.sleepycat.je.tree.MapLN
Compute the approximate size of this node in memory for evictor invocation purposes.
getMemorySizeIncludedByParent() - Method in class com.sleepycat.je.tree.Node
Return the approximate size of this node in memory, if this size should be included in its parents memory accounting.
getMemorySizeIncludedByParent() - Method in class com.sleepycat.je.tree.VersionedLN
Add additional size taken by this LN subclass.
getMemoryUsage() - Method in class com.sleepycat.je.Environment
For unit testing.
getMergedType(int, int) - Method in class com.sleepycat.asm.ClassWriter
Returns the index of the common super type of the two given types.
getMessage() - Method in exception com.sleepycat.je.DatabaseException
 
getMessage() - Method in exception com.sleepycat.je.EnvironmentFailureException
 
getMessage() - Method in class com.sleepycat.je.log.Trace
 
getMessage() - Method in exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.InsufficientVLSNRangeException
 
getMessage() - Method in exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.LoadThresholdExceededException
 
getMessage() - Method in exception com.sleepycat.je.rep.impl.node.Replica.HardRecoveryElectionException
 
getMessage() - Method in exception com.sleepycat.je.rep.impl.node.Replica.RetryException
 
getMessage() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Fail
 
getMessage() - Method in class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
getMessage() - Method in exception com.sleepycat.je.rep.RollbackException
 
getMessage() - Method in exception com.sleepycat.je.rep.RollbackProhibitedException
 
getMessage() - Method in exception com.sleepycat.je.rep.stream.FeederReplicaSyncup.NetworkRestoreException
 
getMessage() - Method in exception com.sleepycat.je.rep.stream.MasterStatus.MasterSyncException
 
getMessage() - Method in exception com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolException
 
getMessage() - Method in exception com.sleepycat.je.rep.utilint.ServiceDispatcher.ServiceConnectFailedException
 
getMessage() - Method in exception com.sleepycat.persist.impl.RefreshException
 
getMessageClass() - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageOp
 
getMessageClass() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.MessageOp
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.elections.Protocol.MasterQuery
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.elections.Protocol.MasterQueryResponse
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateRequest
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureNode
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupRequest
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupResponse
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Fail
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Message
 
getMessagePrefix() - Method in class com.sleepycat.je.rep.impl.TextProtocol.OK
 
getMessageQueueOverflows() - Method in class com.sleepycat.je.rep.impl.node.Replay
 
getMetaData() - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
getMethodDescriptor(Type, Type...) - Static method in class com.sleepycat.asm.Type
Returns the descriptor corresponding to the given argument and return types.
getMethodDescriptor(Method) - Static method in class com.sleepycat.asm.Type
Returns the descriptor corresponding to the given method.
getMethodType(String) - Static method in class com.sleepycat.asm.Type
Returns the Java type corresponding to the given method descriptor.
getMethodType(Type, Type...) - Static method in class com.sleepycat.asm.Type
Returns the Java method type corresponding to the given argument and return types.
getMigrate() - Method in class com.sleepycat.je.tree.ChildReference
Get the entry migrate status.
getMigrate(int) - Method in class com.sleepycat.je.tree.IN
Get the idx'th migrate status.
getMigrationRepContext(LN) - Static method in class com.sleepycat.je.cleaner.Cleaner
Returns the ReplicationContext to use for migrating the given LN.
getMin() - Method in class com.sleepycat.je.config.ShortConfigParam
 
getMin() - Method in class com.sleepycat.je.SequenceStats
Returns the minimum permitted value of the sequence.
getMin() - Method in class com.sleepycat.utilint.Latency
 
getMinBtreeSize() - Method in class com.sleepycat.je.util.DbCacheSize
 
getMinBtreeSizeWithData() - Method in class com.sleepycat.je.util.DbCacheSize
 
getMinimizeRecoveryTime() - Method in class com.sleepycat.je.CheckpointConfig
Returns the configuration of the minimize recovery time option.
getMinor() - Method in class com.sleepycat.je.JEVersion
Minor number of the release version.
getMinReplicatedDbId() - Method in class com.sleepycat.je.log.INFileReader
 
getMinReplicatedNodeId() - Method in class com.sleepycat.je.log.INFileReader
 
getMinReplicatedTxnId() - Method in class com.sleepycat.je.log.INFileReader
 
getMinSyncStart() - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier
 
getMinTreeMemoryUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget
For unit tests.
getMinutes() - Method in class com.sleepycat.je.CheckpointConfig
Returns the checkpoint time threshold, in minutes.
getMinVLSN() - Method in exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.InsufficientVLSNRangeException
 
GetMode - Enum in com.sleepycat.je.dbi
Internal class used to distinguish which variety of getXXX() that Cursor.retrieveNext should use.
getModel() - Method in class com.sleepycat.persist.EntityStore
Returns the current entity model for this store.
getModel() - Method in class com.sleepycat.persist.impl.Store
 
getModel() - Method in class com.sleepycat.persist.raw.RawStore
Returns the last configured and stored entity model for this store.
getModel() - Method in class com.sleepycat.persist.StoreConfig
Returns the entity model that defines entity classes and index keys.
getModelClasses() - Method in class com.sleepycat.persist.impl.PersistCatalog
Returns a set of all persistent (non-simple type) class names.
getModeValue() - Method in enum com.sleepycat.je.log.FileManager.FileMode
 
getMonitorClassName() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getMonitorClassName() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getMonitorEventManager() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getMonitorNameIdPair() - Method in class com.sleepycat.je.rep.monitor.Monitor
 
getMonitorNodes() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the monitor nodes that are members of the group.
getMonitorNodes() - Method in class com.sleepycat.je.rep.ReplicationGroup
Returns the subset of monitor nodes.
getMonitorSocketAddress() - Method in class com.sleepycat.je.rep.monitor.Monitor
Returns the socket used by this monitor to listen for group changes
getMonitorSockets() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the sockets used by just the Monitor nodes in the group
getMultiKeyCreator() - Method in class com.sleepycat.je.SecondaryConfig
Returns the user-supplied object used for creating multi-valued secondary keys.
getMutableConfig() - Method in class com.sleepycat.je.Environment
Returns database environment attributes.
getMutations() - Method in class com.sleepycat.persist.EntityStore
Returns the set of mutations that were configured when the store was opened, or if none were configured, the set of mutations that were configured and stored previously.
getMutations() - Method in class com.sleepycat.persist.impl.Evolver
 
getMutations() - Method in class com.sleepycat.persist.impl.PersistCatalog
Returns the current merged mutations.
getMutations() - Method in class com.sleepycat.persist.impl.Store
 
getMutations() - Method in class com.sleepycat.persist.raw.RawStore
Returns the set of mutations that were configured and stored previously.
getMutations() - Method in class com.sleepycat.persist.StoreConfig
Returns the configured mutations for performing lazy evolution of stored instances.
getNAborts() - Method in class com.sleepycat.je.TransactionStats
The number of transactions that have aborted.
getNAcquiresNoWaiters() - Method in class com.sleepycat.je.EnvironmentStats
Number of acquires of lock table latch with no contention.
getNAcquiresNoWaiters() - Method in class com.sleepycat.je.LockStats
Deprecated.
Number of acquires of lock table latch with no contention.
getNAcquiresNoWaitSuccessful() - Method in class com.sleepycat.je.EnvironmentStats
Number of times acquireNoWait() was successfully called for the lock table latch.
getNAcquiresNoWaitSuccessful() - Method in class com.sleepycat.je.LockStats
Deprecated.
Number of times acquireNoWait() was successfully called for the lock table latch.
getNAcquiresNoWaitUnSuccessful() - Method in class com.sleepycat.je.EnvironmentStats
Number of times acquireNoWait() was unsuccessfully called for the lock table latch.
getNAcquiresNoWaitUnSuccessful() - Method in class com.sleepycat.je.LockStats
Deprecated.
Number of times acquireNoWait() was unsuccessfully called for the lock table latch.
getNAcquiresSelfOwned() - Method in class com.sleepycat.je.EnvironmentStats
Number of acquires of lock table latch when it was already owned by the caller.
getNAcquiresSelfOwned() - Method in class com.sleepycat.je.LockStats
Deprecated.
Number of acquires of lock table latch when it was already owned by the caller.
getNAcquiresWithContention() - Method in class com.sleepycat.je.EnvironmentStats
Number of acquires of lock table latch when it was already owned by another thread.
getNAcquiresWithContention() - Method in class com.sleepycat.je.LockStats
Deprecated.
Number of acquires of lock table latch when it was already owned by another thread.
getNActive() - Method in class com.sleepycat.je.TransactionStats
The number of transactions that are currently active.
getName() - Method in class com.sleepycat.asm.Handle
Returns the name of the field or method designated by this handle.
getName() - Method in class com.sleepycat.je.config.ConfigParam
 
getName() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getName() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Get an environment name, for tagging onto logging and debug message.
getName() - Method in class com.sleepycat.je.latch.Latch
Used by com.sleepycat.je.utilint.TimingLatch.
getName() - Method in class com.sleepycat.je.rep.CommitPointConsistencyPolicy
Returns the name:"CommitPointConsistencyPolicy", associated with this policy.
getName() - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
Returns the application assigned name
getName() - Method in class com.sleepycat.je.rep.impl.PointConsistencyPolicy
Returns the name:"PointConsistencyPolicy", associated with this policy.
getName() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
 
getName() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getName() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getName() - Method in class com.sleepycat.je.rep.NoConsistencyRequiredPolicy
Returns the name:"NoConsistencyRequiredPolicy", associated with this policy.
getName() - Method in class com.sleepycat.je.rep.ReplicationGroup
Returns the name associated with the group.
getName() - Method in interface com.sleepycat.je.rep.ReplicationNode
Returns the unique name associated with the node.
getName() - Method in class com.sleepycat.je.rep.TimeConsistencyPolicy
Returns the name:"TimeConsistencyPolicy", associated with this policy.
getName() - Method in interface com.sleepycat.je.ReplicaConsistencyPolicy
Returns the name used to identify the policy.
getName() - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
getName() - Method in class com.sleepycat.je.sync.SyncDataSet
Returns the name of the data set, which is unique among all data sets for each SyncProcessor instance.
getName() - Method in class com.sleepycat.je.sync.SyncProcessor
Returns the name of the processor, which is unique among all processors for a JE Environment.
getName() - Method in class com.sleepycat.je.Transaction
Get the user visible name for the transaction.
getName() - Method in class com.sleepycat.je.TransactionStats.Active
The transaction name, including the thread name if available.
getName() - Method in interface com.sleepycat.je.trigger.Trigger
Returns the name associated with the trigger.
getName() - Method in class com.sleepycat.je.utilint.StatDefinition
 
getName() - Method in class com.sleepycat.je.utilint.StatGroup
 
getName() - Method in class com.sleepycat.persist.impl.FieldInfo
 
getName() - Method in class com.sleepycat.persist.model.FieldMetadata
Returns the field name.
getName() - Method in interface com.sleepycat.persist.raw.RawField
Returns the name of the field.
getNameId() - Method in class com.sleepycat.je.rep.elections.MasterValue
 
getNameIdPair() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getNameIdPair() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureOK
 
getNameIdPair() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getNameIdPair() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getNameIdPair() - Method in class com.sleepycat.je.rep.impl.TextProtocol
 
getNameIdPair() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
getNameIdPair() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoOK
 
getNameIdPair() - Method in class com.sleepycat.je.rep.stream.Protocol.ProtocolVersion
The nodeName of the sender
getNameIdPair(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
 
getNameIdPair() - Method in class com.sleepycat.je.rep.utilint.NamedChannel
 
getNameLNLogEntry() - Method in class com.sleepycat.je.log.LNFileReader
Returns a NameLNLogEntry if the LN is a NameLN, or null otherwise.
getNBatchesCacheMode() - Method in class com.sleepycat.je.EnvironmentStats
Number of attempts to evict in the course of executing operations that use an explicitly set CacheMode.
getNBatchesCritical() - Method in class com.sleepycat.je.EnvironmentStats
Number of attempts to evict in the course of executing operations that will cause the cache to go over budget.
getNBatchesDaemon() - Method in class com.sleepycat.je.EnvironmentStats
Number of attempts to evict from the cache by JE daemon threads.
getNBatchesEvictorThread() - Method in class com.sleepycat.je.EnvironmentStats
Number of attempts to evict by an evictor pool thread.
getNBatchesManual() - Method in class com.sleepycat.je.EnvironmentStats
Number of attempts to evict by the Environment.evictMemory() method, which is called during Environment startup, or by application code.
getNBegins() - Method in class com.sleepycat.je.TransactionStats
The number of transactions that have begun.
getNBINDeltasCleaned() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of BINDeltas cleaned.
getNBINDeltasDead() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of BINDeltas that were not found in the tree anymore (deleted).
getNBINDeltasMigrated() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of BINDeltas migrated.
getNBINDeltasObsolete() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of BINDeltas obsolete.
getNBINsEvictedCacheMode() - Method in class com.sleepycat.je.EnvironmentStats
Number of BINs evicted from the cache due to an explicitly set CacheMode.
getNBINsEvictedCritical() - Method in class com.sleepycat.je.EnvironmentStats
Number of BINs evicted from the cache in the course of executing operations that will cause the cache to go over budget.
getNBINsEvictedDaemon() - Method in class com.sleepycat.je.EnvironmentStats
Number of BINs evicted from the cache by JE daemon threads.
getNBINsEvictedEvictorThread() - Method in class com.sleepycat.je.EnvironmentStats
Number of BINs evicted from the cache by an evictor pool thread.
getNBINsEvictedManual() - Method in class com.sleepycat.je.EnvironmentStats
Number of BINs evicted from the cache by the Environment.evictMemory() method, which is called during Environment startup, or by application code.
getNBINsFetch() - Method in class com.sleepycat.je.EnvironmentStats
Number of BINs (bottom internal nodes) requested by btree operations.
getNBINsFetchMiss() - Method in class com.sleepycat.je.EnvironmentStats
Number of BINs (bottom internal nodes) requested by btree operations that were not in cache.
getNBINsLoaded() - Method in class com.sleepycat.je.PreloadStats
Returns the number of BINs that were loaded into the cache during the preload() operation.
getNBINsStripped() - Method in class com.sleepycat.je.EnvironmentStats
The number of BINs for which the child LNs have been removed (stripped) and are no longer in the cache.
getNBytesReadFromWriteQueue() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes read to fulfill file read operations by reading out of the pending write queue.
getNBytesWrittenFromWriteQueue() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes written from the pending write queue.
getNCachedBINs() - Method in class com.sleepycat.je.EnvironmentStats
Number of BINs (bottom internal nodes) in cache.
getNCachedGets() - Method in class com.sleepycat.je.SequenceStats
Returns the number of times that Sequence.get was called and a cached value was returned.
getNCachedUpperINs() - Method in class com.sleepycat.je.EnvironmentStats
Number of INs (internal nodes) in cache.
getNCacheMiss() - Method in class com.sleepycat.je.EnvironmentStats
The total number of requests for database objects which were not in memory.
getNCacheMiss() - Method in class com.sleepycat.je.log.LogBufferPool
Return the current nCacheMiss statistic in a lightweight fashion, without perturbing other statistics or requiring synchronization.
getNCacheMiss() - Method in class com.sleepycat.je.log.LogManager
Return the current number of cache misses in a lightweight fashion, without incurring the cost of loading all the stats, and without clearing any stats.
getNCheckpoints() - Method in class com.sleepycat.je.EnvironmentStats
The total number of checkpoints run so far.
getNCleanerDeletions() - Method in class com.sleepycat.je.EnvironmentStats
The number of cleaner file deletions this session.
getNCleanerEntriesRead() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of log entries read by the cleaner.
getNCleanerProbeRuns() - Method in class com.sleepycat.je.EnvironmentStats
Number of cleaner runs for probing utilization.
getNCleanerRuns() - Method in class com.sleepycat.je.EnvironmentStats
Number of cleaner runs, including probe runs.
getNClusterLNsProcessed() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs processed because they qualify for clustering.
getNCommits() - Method in class com.sleepycat.je.TransactionStats
The number of transactions that have committed.
getNConverted() - Method in class com.sleepycat.persist.evolve.EvolveStats
The total number of entities converted during eager evolution.
getNCountMemoryExceeded() - Method in class com.sleepycat.je.PreloadStats
Returns the count of the number of times that the internal memory budget specified by PreloadConfig.setInternalMemoryLimit() was exceeded.
getNDBINsLoaded() - Method in class com.sleepycat.je.PreloadStats
Deprecated.
returns zero for data written using JE 5.0 and later, but may return non-zero values when reading older data.
getNDeltaINFlush() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of Delta INs flushed to the log.
getNDINsLoaded() - Method in class com.sleepycat.je.PreloadStats
Deprecated.
returns zero for data written using JE 5.0 and later, but may return non-zero values when reading older data.
getNDupCountLNsLoaded() - Method in class com.sleepycat.je.PreloadStats
Deprecated.
returns zero for data written using JE 5.0 and later, but may return non-zero values when reading older data.
getNeedReset() - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Tell the MBean if the available set of functionality has changed.
getNeedsAck() - Method in class com.sleepycat.je.rep.stream.Protocol.Commit
 
getNeedSHA1() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoReq
 
getNEntries() - Method in class com.sleepycat.je.tree.IN
 
getNeverLocked() - Method in class com.sleepycat.je.txn.WriteLockInfo
 
getNEvictPasses() - Method in class com.sleepycat.je.EnvironmentStats
Number of eviction passes, an indicator of the eviction activity level.
getNewHostName() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.UpdateAddress
 
getNewLogEntry() - Method in class com.sleepycat.je.log.LogEntryType
 
getNewLsn() - Method in class com.sleepycat.je.log.LogItem
 
getNewName() - Method in class com.sleepycat.persist.evolve.Renamer
Returns the new class or field name specified in the constructor.
getNewOffset(int[], int[], int, int) - Static method in class com.sleepycat.asm.MethodWriter
Computes the future value of a bytecode offset.
getNewOffset(int[], int[], Label) - Static method in class com.sleepycat.asm.MethodWriter
Updates the offset of the given label.
getNewPeriodTarget(RollbackEnd, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
Return the period that should own this foundRBEnd.
getNewPeriodTarget(RollbackStart, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
Return the period that should own this foundRBStart.
getNewPort() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.UpdateAddress
 
getNewRecordClass() - Method in class com.sleepycat.je.sync.RecordMapping
Returns the class used to bind a newly inserted record in a JE Database.
getNewStringFormat() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getNewStringFormat() - Method in class com.sleepycat.persist.impl.Format
For an entity format, returns whether the entity was written using the new String format.
getNext(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getNext(), join cursor is allowed.
getNext(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the next key/data pair and returns that pair.
getNext(DatabaseEntry, DatabaseEntry, LockType, boolean, boolean, RangeConstraint) - Method in class com.sleepycat.je.dbi.CursorImpl
Move the cursor forward and return the next record.
getNext(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.dbi.DiskOrderedCursorImpl
 
getNext(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.DiskOrderedCursor
Moves the cursor to the next key/data pair and returns that pair.
getNext(DatabaseEntry, DatabaseEntry, LockMode) - Method in interface com.sleepycat.je.ForwardCursor
Moves the cursor to the next key/data pair and returns that pair.
getNext(DatabaseEntry, LockMode) - Method in class com.sleepycat.je.JoinCursor
Returns the next primary key resulting from the join operation.
getNext(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.JoinCursor
Returns the next primary key and data resulting from the join operation.
getNext(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getNext(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the next key/data pair and return that pair.
getNext() - Method in class com.sleepycat.je.utilint.VLSN
Return a VLSN which would follow this one.
getNext(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getNextAfterPrefix(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
 
getNextBin(BIN, CacheMode) - Method in class com.sleepycat.je.tree.Tree
Return a reference to the adjacent BIN.
getNextDup(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getNextDup(), no join cursor allowed.
getNextDup(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
If the next key/data pair of the database is a duplicate data record for the current key/data pair, moves the cursor to the next key/data pair of the database and returns that pair.
getNextDup(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getNextDup(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
If the next key/data pair of the database is a duplicate data record for the current key/data pair, move the cursor to the next key/data pair of the database and return that pair.
getNextDup(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getNextGeneration() - Static method in class com.sleepycat.je.tree.Generation
 
getNextIN() - Method in class com.sleepycat.je.evictor.PrivateSelector
Returns the next IN, wrapping if necessary.
getNextIN() - Method in class com.sleepycat.je.evictor.SharedSelector
Returns the next IN, wrapping if necessary.
getNextIN() - Method in class com.sleepycat.je.evictor.TargetSelector
Returns the next IN in the INList(s), wrapping if necessary.
getNextLocalNodeId() - Method in class com.sleepycat.je.dbi.NodeSequence
We get a new node ID of the appropriate kind when creating a new node.
getNextLsn() - Method in class com.sleepycat.je.log.FileManager
Return the next available LSN in the log.
getNextNodeId() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Increments the node ID sequence and returns it.
getNextNoDup(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getNext(), join cursor is allowed.
getNextNoDup(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the next non-duplicate key/data pair and returns that pair.
getNextNoDup(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getNextNoDup(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the next non-duplicate key/data pair and return that pair.
getNextNoDup(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getNextReplicatedTxnId() - Method in class com.sleepycat.je.txn.TxnManager
 
getNextSyncStart() - Method in class com.sleepycat.je.sync.impl.LogChangeSet
 
getNextSyncStart() - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.StartInfo
 
getNextTransientLsn() - Method in class com.sleepycat.je.dbi.NodeSequence
Assign the next available transient LSN.
getNextTxnId() - Method in class com.sleepycat.je.txn.TxnManager
Get the next transaction id for a non-replicated transaction.
getNFeedersCreated() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of Feeder threads since this node was started.
getNFeedersShutdown() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of Feeder threads that were shut down, either because this node, or the Replica terminated the connection.
getNFileOpens() - Method in class com.sleepycat.je.EnvironmentStats
The number of times a log file has been opened.
getNFormats() - Method in class com.sleepycat.persist.impl.PersistCatalog
Returns the number of stored formats.
getNFSyncRequests() - Method in class com.sleepycat.je.EnvironmentStats
The number of fsyncs requested through the group commit manager.
getNFSyncRequests() - Method in class com.sleepycat.je.log.FileManager
 
getNFSyncRequests() - Method in class com.sleepycat.je.log.FSyncManager
 
getNFSyncs() - Method in class com.sleepycat.je.EnvironmentStats
The number of fsyncs issued through the group commit manager.
getNFSyncs() - Method in class com.sleepycat.je.log.FileManager
 
getNFSyncs() - Method in class com.sleepycat.je.log.FSyncManager
 
getNFSyncTimeouts() - Method in class com.sleepycat.je.EnvironmentStats
The number of fsync requests submitted to the group commit manager which timed out.
getNFSyncTimeouts() - Method in class com.sleepycat.je.log.FileManager
 
getNFullBINFlush() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of full BINs flushed to the log.
getNFullINFlush() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of full INs flushed to the log.
getNGets() - Method in class com.sleepycat.je.SequenceStats
Returns the number of times that Sequence.get was called successfully.
getNINCompactKey() - Method in class com.sleepycat.je.evictor.Evictor
 
getNINCompactKeyIN() - Method in class com.sleepycat.je.EnvironmentStats
Number of INs that use a compact key representation to minimize the key object representation overhead.
getNINNoTarget() - Method in class com.sleepycat.je.EnvironmentStats
Number of INs that use a compact representation when none of its child nodes are in the cache.
getNINNoTarget() - Method in class com.sleepycat.je.evictor.Evictor
 
getNINsCleaned() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of INs cleaned.
getNINsDead() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of INs that were not found in the tree anymore (deleted).
getNINsLoaded() - Method in class com.sleepycat.je.PreloadStats
Returns the number of INs that were loaded into the cache during the preload() operation.
getNINsMigrated() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of INs migrated.
getNINsObsolete() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of INs obsolete.
getNINSparseTarget() - Method in class com.sleepycat.je.EnvironmentStats
Number of INs that use a compact sparse array representation to point to child nodes in the cache.
getNINSparseTarget() - Method in class com.sleepycat.je.evictor.Evictor
 
getNLNQueueHits() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs processed without a tree lookup.
getNLNsCleaned() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs cleaned.
getNLNsDead() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs that were not found in the tree anymore (deleted).
getNLNsFetch() - Method in class com.sleepycat.je.EnvironmentStats
Number of LNs (data records) requested by btree operations.
getNLNsFetchMiss() - Method in class com.sleepycat.je.EnvironmentStats
Number of LNs (data records) requested by btree operations that were not in cache.
getNLNsLoaded() - Method in class com.sleepycat.je.PreloadStats
Returns the number of LNs that were loaded into the cache during the preload() operation.
getNLNsLocked() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs encountered that were locked.
getNLNsMarked() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs that were marked for migration during cleaning.
getNLNsMigrated() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs encountered that were migrated forward in the log.
getNLNsObsolete() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs obsolete.
getNLogBuffers() - Method in class com.sleepycat.je.EnvironmentStats
The number of log buffers currently instantiated.
getNLogFSyncs() - Method in class com.sleepycat.je.EnvironmentStats
The total number of fsyncs of the JE log.
getNMarkedLNsProcessed() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs processed because they were previously marked for migration.
getnMaxReplicaLag() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
getNMaxReplicaLag() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The lag (in VLSNs) associated with the replica that's farthest behind in replaying the replication stream.
getnMaxReplicaLagName() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
getNMaxReplicaLagName() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The name of the replica that's farthest behind in replaying the replication stream.
getNNodesExplicitlyEvicted() - Method in class com.sleepycat.je.EnvironmentStats
Number of nodes selected and removed from the cache.
getNNodesScanned() - Method in class com.sleepycat.je.EnvironmentStats
Number of nodes scanned in order to select the eviction set, an indicator of eviction overhead.
getNNodesSelected() - Method in class com.sleepycat.je.EnvironmentStats
Number of nodes which pass the first criteria for eviction, an indicator of eviction efficiency.
getNNotResident() - Method in class com.sleepycat.je.EnvironmentStats
The number of requests for database objects not contained within the in memory data structures.
getNoArgsConstructor(Class<?>) - Static method in class com.sleepycat.je.log.entry.BaseEntry
 
getNoCleaningDistance(long, long, long) - Static method in class com.sleepycat.je.utilint.DbLsn
Return the logsize in bytes between these two LSNs.
getNoComparators() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getNode(int) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Get the node, if it's present, regardless of its membership state.
getNode(String) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Get the node, if it's present, regardless of its membership state.
getNode() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureNode
 
getNodeHostname() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns the hostname component of the nodeHost property.
getNodeHostname() - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the hostname component of the nodeHost property.
getNodeHostPort() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns the hostname and port associated with this node.
getNodeHostPort() - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the hostname and port associated with this node.
getNodeId() - Method in class com.sleepycat.je.log.entry.INLogEntry
 
getNodeId() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the nodeId associated with this replication node.
getNodeId() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getNodeId() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getNodeId(ReplicatedEnvironment) - Static method in class com.sleepycat.je.rep.RepInternal
 
getNodeId() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
getNodeId() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolVersion
The nodeId of the sender
getNodeId() - Method in class com.sleepycat.je.tree.BINReference
 
getNodeId() - Method in class com.sleepycat.je.tree.IN
 
getNodeIdSequence() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the current highest node ID currently in use by the group.
getNodeMaster() - Method in class com.sleepycat.je.rep.stream.MasterStatus
Returns the Node's current idea of the Master.
getNodeMasterNameId() - Method in class com.sleepycat.je.rep.stream.MasterStatus
 
getNodeMaxDupTreeEntries() - Method in class com.sleepycat.je.DatabaseConfig
Deprecated.
this property no longer has any effect and zero is always returned; DatabaseConfig.getNodeMaxEntries() should be used instead.
getNodeMaxEntries() - Method in class com.sleepycat.je.DatabaseConfig
Returns the maximum number of children a B+Tree node can have.
getNodeMaxTreeEntries() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getNodeName() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getNodeName() - Method in class com.sleepycat.je.EnvironmentConfig
Returns the user defined nodeName for the Environment.
getNodeName() - Method in class com.sleepycat.je.rep.elections.MasterValue
 
getNodeName() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateRequest
 
getNodeName() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getNodeName() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the nodeName associated with this replication node.
getNodeName() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateRequest
 
getNodeName() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
getNodeName() - Method in class com.sleepycat.je.rep.monitor.Monitor
Returns the group-wide unique name associated with the monitor
getNodeName() - Method in class com.sleepycat.je.rep.monitor.MonitorChangeEvent
Returns the name of the node associated with the event.
getNodeName() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns the unique name associated with this monitor.
getNodeName() - Method in class com.sleepycat.je.rep.NodeState
Returns the name of the node whose state is requested.
getNodeName() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Returns the unique name used to identify this replicated environment.
getNodeName() - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the unique name associated with this node.
getNodeName() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
getNodeNameList() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferMaster
 
getNodePort() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns the port component of the nodeHost property.
getNodePort() - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the port component of the nodeHost property.
getNodePriority() - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Returns the election priority associated with the node.
getNodes() - Method in class com.sleepycat.je.rep.ReplicationGroup
Returns administrative information for all the nodes in the group.
getNodeSequence() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getNodeSocketAddress() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
getNodeSocketAddress() - Method in class com.sleepycat.je.rep.ReplicationConfig
 
getNodeState() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getNodeState() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
getNodeState() - Method in class com.sleepycat.je.rep.NodeState
Returns the replication state of this node.
getNodeState() - Method in class com.sleepycat.je.rep.util.DbPing
 
getNodeState(ReplicationNode, int) - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Returns the state of a replicated node and state of the application where the node is running in.
getNodeStats() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getNodeType() - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the type (ELECTABLE, MONITOR) of this node.
getNodeType() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
getNoFormatString(byte[]) - Static method in class com.sleepycat.je.tree.Key
Print the string w/out XML format.
getNoFormatString(long) - Static method in class com.sleepycat.je.utilint.DbLsn
 
getNonEmptyBins() - Method in class com.sleepycat.je.EnvironmentStats
The number of BINs encountered by the INCompressor that were not actually empty when the compressor ran.
getNonObsoleteCount() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns the number of non-obsolete LN and IN entries.
getNOpenFiles() - Method in class com.sleepycat.je.EnvironmentStats
The number of files currently open in the file cache.
getNoSort() - Method in class com.sleepycat.je.JoinConfig
Returns whether automatic sorting of the input cursors is disabled.
getNoSync() - Method in class com.sleepycat.je.TransactionConfig
Deprecated.
getNotificationInfo() - Method in class com.sleepycat.je.jmx.JEMBean
Get notification metadata for this MBean.
getNotificationInfo(Environment) - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
No notifications are supported.
getNoWait() - Method in class com.sleepycat.je.TransactionConfig
Returns true if the transaction is configured to not wait if a lock request cannot be immediately granted.
getNOwners() - Method in class com.sleepycat.je.EnvironmentStats
Total lock owners in lock table.
getNOwners() - Method in class com.sleepycat.je.LockStats
Deprecated.
Total lock owners in lock table.
getNPendingLNsLocked() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of pending LNs that could not be locked for migration because of a long duration application lock.
getNPendingLNsProcessed() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs processed because they were previously locked.
getNProtocolBytesRead() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of bytes of Replication Stream read over the network.
getNProtocolBytesWritten() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of Replication Stream bytes written over the network.
getNProtocolMessagesRead() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of Replication Stream messages read over the network.
getNProtocolMessagesWritten() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of Replication Stream messages written over the network.
getNRandomReadBytes() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes read which required repositioning the disk head more than 1MB from the previous file position.
getNRandomReads() - Method in class com.sleepycat.je.EnvironmentStats
The number of disk reads which required repositioning the disk head more than 1MB from the previous file position.
getNRandomWriteBytes() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes written which required repositioning the disk head more than 1MB from the previous file position.
getNRandomWrites() - Method in class com.sleepycat.je.EnvironmentStats
The number of disk writes which required repositioning the disk head by more than 1MB from the previous file position.
getNRead() - Method in class com.sleepycat.persist.evolve.EvolveStats
The total number of entities read during eager evolution.
getNReadLocks() - Method in class com.sleepycat.je.EnvironmentStats
Total read locks currently held.
getNReadLocks() - Method in class com.sleepycat.je.LockStats
Deprecated.
Total read locks currently held.
getNReadsFromWriteQueue() - Method in class com.sleepycat.je.EnvironmentStats
The number of file read operations which were fulfilled by reading out of the pending write queue.
getNReleases() - Method in class com.sleepycat.je.EnvironmentStats
Number of releases of the lock table latch.
getNReleases() - Method in class com.sleepycat.je.LockStats
Deprecated.
Number of releases of the lock table latch.
getNRepeatFaultReads() - Method in class com.sleepycat.je.EnvironmentStats
The number of reads which had to be repeated when faulting in an object from disk because the read chunk size controlled by je.log.faultReadSize is too small.
getNRepeatIteratorReads() - Method in class com.sleepycat.je.EnvironmentStats
The number of times we tried to read a log entry larger than the read buffer size and couldn't grow the log buffer to accommodate the large object.
getNRepeatIteratorReads() - Method in class com.sleepycat.je.log.FileReader
 
getNRepeatIteratorReads() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
getNReplayAborts() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of abort records which were replayed while the node was in the Replica state.
getNReplayCommitAcks() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of commit log records that needed to be acknowledged to the Master by this node when it was a Replica.
getNReplayCommitNoSyncs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of commitNoSync() calls executed when satisfying transaction commit acknowledgment requests from the Master.
getNReplayCommits() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of commit log records that were replayed by this node when it was a Replica.
getNReplayCommitSyncs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of commitSync() calls executed when satisfying transaction commit acknowledgment requests from the Master.
getNReplayCommitWriteNoSyncs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of commitNoSync() calls executed when satisfying transaction commit acknowledgment requests from the Master.
getNReplayLNs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of data records (creation, update, deletion) which were replayed while the node was in the Replica state.
getNReplayNameLNs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of NameLN records which were replayed while the node was in the Replica state.
getNReposition() - Method in class com.sleepycat.je.rep.stream.VLSNReader
 
getNRequests() - Method in class com.sleepycat.je.EnvironmentStats
Total number of lock requests to date.
getNRequests() - Method in class com.sleepycat.je.LockStats
Deprecated.
Total number of lock requests to date.
getNRootNodesEvicted() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of database root nodes evicted.
getNScanned() - Method in class com.sleepycat.je.rep.stream.VLSNReader
 
getNSequentialReadBytes() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes read which did not require repositioning the disk head more than 1MB from the previous file position.
getNSequentialReads() - Method in class com.sleepycat.je.EnvironmentStats
The number of disk reads which did not require repositioning the disk head more than 1MB from the previous file position.
getNSequentialWriteBytes() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes written which did not require repositioning the disk head more than 1MB from the previous file position.
getNSequentialWrites() - Method in class com.sleepycat.je.EnvironmentStats
The number of disk writes which did not require repositioning the disk head by more than 1MB from the previous file position.
getNSharedCacheEnvironments() - Method in class com.sleepycat.je.dbi.DbEnvPool
 
getNSharedCacheEnvironments() - Method in class com.sleepycat.je.EnvironmentStats
The number of environments using the shared cache.
getNTempBufferWrites() - Method in class com.sleepycat.je.EnvironmentStats
The number of writes which had to be completed using the temporary marshalling buffer because the fixed size log buffers specified by je.log.totalBufferBytes and je.log.numBuffers were not large enough.
getNThreadUnavailable() - Method in class com.sleepycat.je.EnvironmentStats
Number of eviction tasks that were submitted to the background evictor pool, but were refused because all eviction threads were busy.
getNTimeouts() - Method in class com.sleepycat.je.log.FSyncManager
 
getNToBeCleanedLNsProcessed() - Method in class com.sleepycat.je.EnvironmentStats
The accumulated number of LNs processed because they are soon to be cleaned.
getNTotalEntries() - Method in class com.sleepycat.je.dbi.LSNAccumulator
 
getNTotalLocks() - Method in class com.sleepycat.je.EnvironmentStats
Total locks currently in lock table.
getNTotalLocks() - Method in class com.sleepycat.je.LockStats
Deprecated.
Total locks currently in lock table.
getNTxnsAcked() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of transactions that were successfully acknowledged based upon the Durability.ReplicaAckPolicy policy associated with the transaction commit.
getNTxnsNotAcked() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of transactions that were not acknowledged as required by the Durability.ReplicaAckPolicy policy associated with the transaction commit.
getNumBatchesStatDef() - Method in enum com.sleepycat.je.evictor.Evictor.EvictionSource
 
getNumberOfDBs() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.EnvInfo
 
getNumberOfFiles() - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Returns the number of files in the profile.
getNumCompletedDumps() - Method in class com.sleepycat.utilint.ActivityCounter
For unit test support.
getNumCompletedDumps() - Method in class com.sleepycat.utilint.StatsTracker
For unit test support.
getNumCurrentAckFeeders(VLSN) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Returns a count of the number of feeders whose replicas have acknowledged txn-end VLSNs >= the commitVLSN argument.
getNumDeltas() - Method in class com.sleepycat.je.tree.BINDelta
 
getNumDeltas(BIN) - Static method in class com.sleepycat.je.tree.BINDelta
 
getNumEntries() - Method in class com.sleepycat.je.recovery.DirtyINMap
 
getNumericVersionString() - Method in class com.sleepycat.je.JEVersion
The numeric version string, without the patch tag.
getNumExplicitlySetParams() - Method in class com.sleepycat.je.EnvironmentMutableConfig
Testing support
getNumFromName(String) - Method in class com.sleepycat.je.log.FileManager
Get the file number from a file name.
getNumLevels() - Method in class com.sleepycat.je.recovery.DirtyINMap
 
getNumOffsets() - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
 
getNumOffsets() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
getNumPassedCommits() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
 
getNumProcessed() - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
 
getNumRead() - Method in class com.sleepycat.je.log.FileReader
 
getNumRecords() - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
getNumRetries() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns the number of times a ping thread attempts to contact a node before deeming it unreachable.
getNumSegments() - Method in class com.sleepycat.je.utilint.BitMap
 
getNUpperINsEvictedCacheMode() - Method in class com.sleepycat.je.EnvironmentStats
Number of upper INs evicted from the cache in due to an explicitly set CacheMode.
getNUpperINsEvictedCritical() - Method in class com.sleepycat.je.EnvironmentStats
Number of upper INs evicted from the cache in the course of executing operations that will cause the cache to go over budget.
getNUpperINsEvictedDaemon() - Method in class com.sleepycat.je.EnvironmentStats
Number of upper INs evicted from the cache by JE daemon threads.
getNUpperINsEvictedEvictorThread() - Method in class com.sleepycat.je.EnvironmentStats
Number of upper INs evicted from the cache by an evictor pool thread.
getNUpperINsEvictedManual() - Method in class com.sleepycat.je.EnvironmentStats
Number of upper INs evicted from the cache by the Environment.evictMemory() method, which is called during Environment startup, or by application code.
getNUpperINsFetch() - Method in class com.sleepycat.je.EnvironmentStats
Number of upper INs (non bottom internal nodes) requested by btree operations.
getNUpperINsFetchMiss() - Method in class com.sleepycat.je.EnvironmentStats
Number of upper INs (non-bottom internal nodes) requested by btree operations that were not in cache.
getNWaiters() - Method in class com.sleepycat.je.EnvironmentStats
Total transactions waiting for locks.
getNWaiters() - Method in class com.sleepycat.je.LockStats
Deprecated.
Total transactions waiting for locks.
getNWaits() - Method in class com.sleepycat.je.EnvironmentStats
Total number of lock waits to date.
getNWaits() - Method in class com.sleepycat.je.LockStats
Deprecated.
Total number of lock waits to date.
getNWakeupRequests() - Method in class com.sleepycat.je.cleaner.Cleaner
 
getNWakeupRequests() - Method in interface com.sleepycat.je.utilint.DaemonRunner
 
getNWakeupRequests() - Method in class com.sleepycat.je.utilint.DaemonThread
For unit testing.
getNWriteLocks() - Method in class com.sleepycat.je.EnvironmentStats
Total write locks currently held.
getNWriteLocks() - Method in class com.sleepycat.je.LockStats
Deprecated.
Total write locks currently held.
getNWriteQueueOverflow() - Method in class com.sleepycat.je.EnvironmentStats
The number of writes operations which would overflow the Write Queue.
getNWriteQueueOverflowFailures() - Method in class com.sleepycat.je.EnvironmentStats
The number of writes operations which would overflow the Write Queue and could not be queued.
getNWritesFromWriteQueue() - Method in class com.sleepycat.je.EnvironmentStats
The number of file writes operations executed from the pending write queue.
getNXAAborts() - Method in class com.sleepycat.je.TransactionStats
The number of XA transactions that have aborted.
getNXACommits() - Method in class com.sleepycat.je.TransactionStats
The number of XA transactions that have committed.
getNXAPrepares() - Method in class com.sleepycat.je.TransactionStats
The number of XA transactions that have been prepared.
getObjectType(String) - Static method in class com.sleepycat.asm.Type
Returns the Java type corresponding to the given internal name.
getObsoleteDetail(Long, boolean) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Returns the stored/packed obsolete offsets offsets for the given file.
getObsoleteINSize() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns the approximate byte size of all obsolete IN entries.
getObsoleteLNSize() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns the approximate byte size of all obsolete LN entries, using the default average LN size for LN sizes that were not counted.
getObsoleteLNSize(float) - Method in class com.sleepycat.je.cleaner.FileSummary
Returns the approximate byte size of all obsolete LN entries, using the given average LN size for LN sizes that were not counted.
getObsoleteOffsets() - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Returns obsolete offsets as an array of longs, or null if none.
getObsoleteOffsets() - Method in class com.sleepycat.je.tree.FileSummaryLN
Returns the obsolete offsets for the file.
getObsoleteSize() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns an estimate of the total bytes that are obsolete, using getObsoleteLNSize instead of getMaxObsoleteLNSize.
getObsoleteSize(float) - Method in class com.sleepycat.je.cleaner.FileSummary
Returns an estimate of the total bytes that are obsolete, using a given correction factor for LN sizes that were not counted.
getOffset() - Method in class com.sleepycat.asm.Label
Returns the offset corresponding to this label.
getOffset() - Method in class com.sleepycat.je.DatabaseEntry
Returns the byte offset into the data array.
getOldKeyName(String) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getOldKeyName(String) - Method in class com.sleepycat.persist.impl.Format
For an entity class or subclass, returns the old key name for the given key name that has been renamed, or returns the given key name if it has not been renamed.
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.Accept
 
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.Accepted
 
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.MasterQuery
 
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.MasterQueryResponse
 
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.Propose
 
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.Reject
 
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.Result
 
getOp() - Method in class com.sleepycat.je.rep.elections.Protocol.Shutdown
 
getOp() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateRequest
 
getOp() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.Done
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoReq
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoResp
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileEnd
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoReq
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoResp
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileListReq
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileListResp
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileReq
 
getOp() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
getOp() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateRequest
 
getOp() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureNode
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureOK
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.Fail
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupRequest
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupResponse
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.RemoveMember
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferMaster
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferOK
 
getOp() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.UpdateAddress
 
getOp() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Fail
 
getOp() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Message
 
getOp() - Method in class com.sleepycat.je.rep.impl.TextProtocol.OK
 
getOp() - Method in class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
getOp() - Method in class com.sleepycat.je.rep.monitor.Protocol.GroupChange
 
getOp() - Method in class com.sleepycat.je.rep.monitor.Protocol.JoinGroup
 
getOp() - Method in class com.sleepycat.je.rep.monitor.Protocol.LeaveGroup
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.Ack
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.AlternateMatchpoint
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.Commit
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.DuplicateNodeReject
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.Entry
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.EntryNotFound
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.EntryRequest
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.FeederJEVersions
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.FeederProtocolVersion
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.Heartbeat
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.HeartbeatResponse
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.JEVersionsReject
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoOK
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoReject
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.ReplicaJEVersions
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.ReplicaProtocolVersion
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.RestoreRequest
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.RestoreResponse
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.ShutdownRequest
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.ShutdownResponse
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPRequest
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
getOp() - Method in class com.sleepycat.je.rep.stream.Protocol.StartStream
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.BlockInfo
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.BlockListEnd
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.BlockListStart
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.DbBlocks
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.DbMismatch
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.DiffAreaEnd
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.DiffAreaStart
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.Done
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.EnvDiff
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.EnvInfo
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.Error
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
getOp() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
getOp() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.ClientVersion
 
getOp() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.IncompatibleVersion
 
getOp() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.Message
 
getOp() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolError
 
getOp() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.ServerVersion
 
getOpcode(int) - Method in class com.sleepycat.asm.Type
Returns a JVM instruction opcode adapted to this Java type.
getOpenDbBackup() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager.Lease
 
getOpenTimeout() - Method in class com.sleepycat.je.rep.impl.TextProtocol
 
getOperationList(Environment) - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Get mbean operation metadata for this environment.
getOperationRepContext(DbOperationType, DatabaseId) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Return a ReplicationContext that includes information on how to logically replicate database operations.
getOperationRepContext(DbOperationType) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Convenience overloading.
getOperations() - Method in interface com.sleepycat.je.sync.ChangeReader.ChangeTxn
Returns an iterator over the changes in this transactions, for a single data set (specified by getDataSetName).
getOperations() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChangeTxn
 
getOperationType() - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
 
getOpId() - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageOp
 
getOpId() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.MessageOp
 
getOpsOverflow() - Method in class com.sleepycat.utilint.Latency
 
getOpType() - Method in class com.sleepycat.je.rep.monitor.Protocol.GroupChange
 
getOrCreateFormat(Catalog, String, boolean) - Static method in class com.sleepycat.persist.impl.PersistEntityBinding
Utility method for getting or creating a format as appropriate for bindings and key creators.
getOrFetchRootIN(DatabaseImpl, long) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
Returns the root IN, latched shared.
getOriginateTimestamp() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPRequest
 
getOriginateTimestamp() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
getOverrideBtreeComparator() - Method in class com.sleepycat.je.DatabaseConfig
Returns the override setting for the btree comparator.
getOverrideDuplicateComparator() - Method in class com.sleepycat.je.DatabaseConfig
Returns the override setting for the duplicate comparator.
getOverrideTriggers() - Method in class com.sleepycat.je.DatabaseConfig
 
getOwnedLockType(Long, Locker) - Method in class com.sleepycat.je.txn.DummyLockManager
 
getOwnedLockType(Locker) - Method in interface com.sleepycat.je.txn.Lock
Returns the LockType if the given locker owns this lock, or null if the lock is not owned.
getOwnedLockType(Locker) - Method in class com.sleepycat.je.txn.LockImpl
 
getOwnedLockType(Long, Locker) - Method in class com.sleepycat.je.txn.LockManager
Returns the LockType if the given locker owns a lock on the given node, or null if the lock is not owned.
getOwnedLockType(Long, Locker) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
getOwnedLockType(Locker) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
getOwnedLockTypeInternal(Long, Locker, int) - Method in class com.sleepycat.je.txn.LockManager
 
getOwner() - Method in class com.sleepycat.asm.Handle
Returns the internal name of the field or method designed by this handle.
getOwners(Long) - Method in class com.sleepycat.je.txn.DummyLockManager
 
getOwners(Long) - Method in class com.sleepycat.je.txn.LockManager
Returns the Lockers that own a lock on the given LSN.
getOwners(Long) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
getOwnersClone() - Method in interface com.sleepycat.je.txn.Lock
Get a new Set of the owners.
getOwnersClone() - Method in class com.sleepycat.je.txn.LockImpl
Get a new Set of the owners.
getOwnersClone() - Method in class com.sleepycat.je.txn.ThinLockImpl
 
getOwnersInternal(Long, int) - Method in class com.sleepycat.je.txn.LockManager
 
getOwnerTxnIds() - Method in exception com.sleepycat.je.LockConflictException
Returns an array of longs containing transaction ids of owners at the the time of the timeout.
getPackedIntByteLength() - Method in class com.sleepycat.bind.tuple.TupleInput
Returns the byte length of a packed integer.
getPackedIntLogSize(int) - Static method in class com.sleepycat.je.log.LogUtils
 
getPackedLongByteLength() - Method in class com.sleepycat.bind.tuple.TupleInput
Returns the byte length of a packed long integer.
getPackedLongLogSize(long) - Static method in class com.sleepycat.je.log.LogUtils
 
getParentBINForChildLN(TreeLocation, byte[], boolean, boolean, CacheMode) - Method in class com.sleepycat.je.tree.Tree
Return a reference to the parent of this LN.
getParentId() - Method in class com.sleepycat.je.TransactionStats.Active
The transaction ID of the parent transaction (or 0, if no parent).
getParentINForChildIN(IN, boolean, CacheMode) - Method in class com.sleepycat.je.tree.Tree
GetParentNode without optional tracking.
getParentINForChildIN(IN, boolean, CacheMode, int, List<TrackingInfo>) - Method in class com.sleepycat.je.tree.Tree
Return a reference to the parent or possible parent of the child.
getParentINForChildIN(long, boolean, byte[], boolean, CacheMode, int, List<TrackingInfo>, boolean) - Method in class com.sleepycat.je.tree.Tree
Return a reference to the parent or possible parent of the child.
getParser() - Static method in class com.sleepycat.je.rep.elections.MasterValue
Returns a parser that can convert a wire format value into a MasterValue
getParser() - Static method in class com.sleepycat.je.rep.elections.TimebasedProposalGenerator
Returns the parser used to convert wire representations into Proposal instances.
getPartial() - Method in class com.sleepycat.je.DatabaseEntry
Returns whether this DatabaseEntry is configured to read or write partial records.
getPartialLength() - Method in class com.sleepycat.je.DatabaseEntry
Returns the byte length of the partial record being read or written by the application, in bytes.
getPartialMapping() - Method in class com.sleepycat.je.sync.RecordMapping
Returns true if the field map is a partial mapping and other field names that match should be transferred, or false if it is a complete mapping and omitted names should not be transferred.
getPartialOffset() - Method in class com.sleepycat.je.DatabaseEntry
Returns the offset of the partial record being read or written by the application, in bytes.
getPassedCheckpointEnd() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
 
getPassword() - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
getPatch() - Method in class com.sleepycat.je.JEVersion
Patch number of the release version.
getPdescriptor(Class) - Static method in class com.sleepycat.util.ConfigBeanInfoBase
 
getPendingDBs() - Method in class com.sleepycat.je.cleaner.FileSelector
Returns an array of DatabaseIds for DBs that were pending deletion in a prior cleaning attempt, or null if no DBs are pending.
getPendingLNs() - Method in class com.sleepycat.je.cleaner.FileSelector
Returns a map of LNInfo for LNs that could not be migrated in a prior cleaning attempt, or null if no LNs are pending.
getPeriodList() - Method in class com.sleepycat.je.recovery.RollbackTracker
 
getPermissibleLag(TimeUnit) - Method in class com.sleepycat.je.rep.TimeConsistencyPolicy
Returns the allowed time lag associated with this policy.
getPersistentFields() - Method in class com.sleepycat.persist.model.ClassMetadata
Returns an unmodifiable list of metadata for the persistent fields in this class, or null if the default rules for persistent fields should be used.
getPort() - Method in class com.sleepycat.je.rep.elections.MasterValue
 
getPort() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns the port used by the replication node.
getPort() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getPort() - Method in interface com.sleepycat.je.rep.ReplicationNode
Returns the port number associated with the node.
getPort(String) - Static method in class com.sleepycat.je.rep.utilint.HostPortPair
Parses and returns the port of a hostport pair
getPreciseLsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.BackwardVLSNScanner
 
getPreciseLsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.ForwardVLSNScanner
 
getPredefinedMessageCount() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
getPreemptable() - Method in class com.sleepycat.je.txn.Locker
Returns whether my locks can be stolen/preemted.
getPrepared() - Method in class com.sleepycat.je.Transaction
For internal use.
getPrepared() - Method in class com.sleepycat.je.txn.Txn
 
getPreserveVLSN() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns true if the VLSN is preserved as the record version.
getPreserveVLSN() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns true if the VLSN is preserved as the record version.
getPrev(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getPrev(), no join cursor allowed.
getPrev(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the previous key/data pair and returns that pair.
getPrev(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getPrev(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the previous key/data pair and return that pair.
getPrev() - Method in class com.sleepycat.je.utilint.VLSN
Return a VLSN which would precede this one.
getPrev(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getPrevBin(BIN, CacheMode) - Method in class com.sleepycat.je.tree.Tree
Return a reference to the previous BIN.
getPrevDeltaLsn() - Method in class com.sleepycat.je.log.entry.BINDeltaLogEntry
 
getPrevDeltaLsn() - Method in interface com.sleepycat.je.log.entry.INContainingEntry
 
getPrevDeltaLsn() - Method in class com.sleepycat.je.log.entry.INLogEntry
 
getPrevDeltaLsn() - Method in class com.sleepycat.je.tree.BINDelta
 
getPrevDup(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getPrevDup(), no join cursor allowed.
getPrevDup(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
If the previous key/data pair of the database is a duplicate data record for the current key/data pair, moves the cursor to the previous key/data pair of the database and returns that pair.
getPrevDup(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getPrevDup(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
If the previous key/data pair of the database is a duplicate data record for the current key/data pair, move the cursor to the previous key/data pair of the database and return that pair.
getPrevDup(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getPrevEntryOffset() - Method in class com.sleepycat.je.log.FileManager
 
getPrevFullLsn() - Method in class com.sleepycat.je.log.entry.BINDeltaLogEntry
 
getPrevFullLsn() - Method in interface com.sleepycat.je.log.entry.INContainingEntry
 
getPrevFullLsn() - Method in class com.sleepycat.je.log.entry.INLogEntry
 
getPreviousVersion() - Method in class com.sleepycat.persist.impl.Format
Returns the previous version of this format in the linked list of versions, or null if this is the only version.
getPrevNoDup(boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getPrevNoDup(), no join cursor allowed.
getPrevNoDup(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the previous non-duplicate key/data pair and returns that pair.
getPrevNoDup(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getPrevNoDup(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the previous non-duplicate key/data pair and return that pair.
getPrevNoDup(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getPrevOffset() - Method in class com.sleepycat.je.log.LastFileReader
 
getPrevOffset() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getPriKeyField() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getPriKeyField() - Method in class com.sleepycat.persist.impl.RawAccessor
 
getPriKeyFieldInfo() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
getPrimaryConfig(Class) - Method in class com.sleepycat.persist.EntityStore
Returns the default primary database Berkeley DB engine API configuration for an entity class.
getPrimaryConfig(Class) - Method in class com.sleepycat.persist.impl.Store
 
getPrimaryDatabase() - Method in class com.sleepycat.je.SecondaryCursor
Returns the primary Database associated with this cursor.
getPrimaryDatabase() - Method in class com.sleepycat.je.SecondaryDatabase
Returns the primary database associated with this secondary database.
getPrimaryIndex(Class<PK>, Class<E>) - Method in class com.sleepycat.persist.EntityStore
Returns the primary index for a given entity class, opening it if necessary.
getPrimaryIndex(Class<PK>, String, Class<E>, String) - Method in class com.sleepycat.persist.impl.Store
A getPrimaryIndex with extra parameters for opening a raw store.
getPrimaryIndex(String) - Method in class com.sleepycat.persist.raw.RawStore
Opens the primary index for a given entity class.
getPrimaryIndex() - Method in class com.sleepycat.persist.SecondaryIndex
Returns the primary index associated with this secondary index.
getPrimaryKey() - Method in exception com.sleepycat.je.SecondaryReferenceException
Returns the primary key being access during the failure.
getPrimaryKey() - Method in class com.sleepycat.persist.model.ClassMetadata
Returns the primary key metadata for a key declared in this class, or null if none is declared.
getPrimaryKey() - Method in class com.sleepycat.persist.model.EntityMetadata
Returns the primary key metadata for this entity.
getPrimaryKeyThang() - Method in class com.sleepycat.collections.DataCursor
Returns the internal primary key entry, which is the same object as the key entry if the cursor is not for a secondary database.
getPrimitiveBinding(Class<T>) - Static method in class com.sleepycat.bind.tuple.TupleBinding
Creates a tuple binding for a primitive Java class.
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
getPrimitiveLength() - Method in class com.sleepycat.persist.impl.SimpleFormat
 
getPrimitiveWrapperClass(int) - Static method in class com.sleepycat.persist.model.BytecodeEnhancer
Returns the wrapper class for a primitive.
getPrintInfo() - Method in class com.sleepycat.je.VerifyConfig
Returns true if the Environment.verify and Database.verify are configured to print basic verification information to System.out.
getPriority() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
getPrivateSecondaryConfig() - Method in class com.sleepycat.je.SecondaryDatabase
Returns the secondary config without cloning, for internal use.
getProcessedBins() - Method in class com.sleepycat.je.EnvironmentStats
The number of BINs that were successfully processed by the IN Compressor.
getProcessor() - Method in class com.sleepycat.je.sync.SyncDataSet
Returns the SyncProcessor that manages this data set.
getProgressListener() - Method in class com.sleepycat.je.PreloadConfig
Return the ProgressListener for this PreloadConfig.
getPromotion() - Method in class com.sleepycat.je.txn.LockUpgrade
This method is called when getUpgrade returns non-null to determine whether the upgrade is a true promotion or can be granted immediately.
getPropagateExceptions() - Method in class com.sleepycat.je.VerifyConfig
Returns true if the Environment.verify and Database.verify are configured to propagate exceptions found during verification.
getPropertiesInfo(Class) - Static method in class com.sleepycat.util.ConfigBeanInfoBase
 
getPropertyDescriptors() - Method in class com.sleepycat.je.CheckpointConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.CursorConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.DatabaseConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.DiskOrderedCursorConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.EnvironmentConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.EnvironmentMutableConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.JoinConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.PreloadConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.rep.monitor.MonitorConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.rep.NetworkRestoreConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.rep.ReplicationConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.rep.ReplicationMutableConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.SecondaryConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.SequenceConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.StatsConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.TransactionConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.je.VerifyConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.persist.evolve.EvolveConfigBeanInfo
 
getPropertyDescriptors() - Method in class com.sleepycat.persist.StoreConfigBeanInfo
 
getPropertyDescriptors(Class) - Method in class com.sleepycat.util.ConfigBeanInfoBase
Gets the bean's PropertyDescriptors.
getPropertyString(ReplicaConsistencyPolicy) - Static method in class com.sleepycat.je.rep.utilint.RepUtils
Converts a policy into a string suitable for use as a property value in a je.properties file or elsewhere.
getProposal() - Method in class com.sleepycat.je.rep.elections.Protocol.Accepted
 
getProposal() - Method in class com.sleepycat.je.rep.elections.Protocol.Propose
 
getProposerStats() - Method in class com.sleepycat.je.rep.elections.Proposer
Returns the current proposer statistics.
getProps(EnvironmentMutableConfig) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentMutableConfig.getProps
getProps() - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
getProps() - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
 
getProtocol() - Method in class com.sleepycat.je.rep.elections.Elections
 
getProtocol() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
getProtocol() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Message
Returns the protocol associated with this message
getProtocol(RepNode) - Static method in class com.sleepycat.je.rep.stream.Protocol
 
getProtocolBytesReadRate() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
Bytes read throughput, in terms of bytes received from the replication network channels per second.
getProtocolBytesWriteRate() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
Bytes written throughput, in terms of bytes written to the replication network channels per second.
getProtocolMessageReadRate() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
Incoming replication message throughput, in terms of messages received from the replication network channels per second.
getProtocolMessageWriteRate() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
Outgoing message throughput, in terms of message written to the replication network channels per second.
getProtocolReadNanos() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of nanoseconds spent reading from the network channel.
getProtocolStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.Feeder
 
getProtocolStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
getProtocolStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.Replica
 
getProtocolWriteNanos() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of nanoseconds spent writing to the network channel.
getProvisional() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getProxiedClassName() - Method in class com.sleepycat.persist.model.ClassMetadata
Returns the class name of the proxied class if this class is a PersistentProxy, or null otherwise.
getProxiedFormat() - Method in class com.sleepycat.persist.impl.Format
Returns the format that is proxied by this format.
getPushLevel(String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Get the push level for the MemoryHandler.
getPutWaitVLSN() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
For unit test only.
getQueueSize() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Returns the maximum number of entries in the queue before the DiskOrderedCursor producer thread blocks.
getRange() - Method in class com.sleepycat.collections.DataCursor
Returns the range for this cursor.
getRange() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
All range points (first, last, etc) ought to be seen as one consistent group.
getRange() - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
getRangeFirst() - Method in exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.InsufficientVLSNRangeException
 
getRangeFirst() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoResp
 
getRangeLast() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoResp
 
getRangeMax() - Method in class com.sleepycat.je.SequenceConfig
Returns the maximum value for the sequence.
getRangeMin() - Method in class com.sleepycat.je.SequenceConfig
Returns the minimum value for the sequence.
getRanking(Proposer.Proposal) - Method in interface com.sleepycat.je.rep.elections.Acceptor.SuggestionGenerator
The importance associated with the above suggestion.
getRanking(Proposer.Proposal) - Method in class com.sleepycat.je.rep.stream.MasterSuggestionGenerator
 
getRawType(String) - Method in class com.sleepycat.persist.model.EntityModel
Returns the type information for the current version of a given class, or null if the class is not currently persistent.
getRawTypeVersion(String, int) - Method in class com.sleepycat.persist.model.EntityModel
Returns the type information for a given version of a given class, or null if the given version of the class is unknown.
getReadableLocker(Environment, Transaction, boolean, boolean) - Static method in class com.sleepycat.je.txn.LockerFactory
Get a locker for a read or cursor operation.
getReadableLocker(Environment, Database, Locker, boolean) - Static method in class com.sleepycat.je.txn.LockerFactory
Get a locker for this database handle for a read or cursor operation.
getReadBufferByLsn(long) - Method in class com.sleepycat.je.log.LogBufferPool
Find a buffer that contains the given LSN location.
getReadBufferByLsn(long) - Method in class com.sleepycat.je.log.LogManager
Return a log buffer locked for reading, or null if no log buffer holds this LSN location.
getReadCommitted() - Method in class com.sleepycat.je.CursorConfig
Returns true if read operations performed by the cursor are configured to obey read committed isolation.
getReadCommitted() - Method in class com.sleepycat.je.TransactionConfig
Returns true if the transaction is configured for read committed isolation.
getReader() - Method in class com.sleepycat.persist.impl.Format
Returns the object for reading objects of the latest format.
getReadIntLength(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
Returns the number of bytes that would be read by PackedInteger.readInt(byte[], int).
getReadLockIds() - Method in class com.sleepycat.je.txn.Txn
 
getReadLongLength(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
Returns the number of bytes that would be read by PackedInteger.readLong(byte[], int).
getReadOnly() - Method in class com.sleepycat.je.DatabaseConfig
Returns true if the database is configured in read-only mode.
getReadOnly() - Method in class com.sleepycat.je.EnvironmentConfig
Returns true if the database environment is configured to be read only.
getReadOnly() - Method in class com.sleepycat.je.log.FileManager
 
getReadOnly() - Method in class com.sleepycat.persist.StoreConfig
Returns the read-only configuration property.
getReadSortedIntLength(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
Returns the number of bytes that would be read by PackedInteger.readSortedInt(byte[], int).
getReadSortedLongLength(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
Returns the number of bytes that would be read by PackedInteger.readSortedLong(byte[], int).
getReadTimeout() - Method in class com.sleepycat.je.rep.impl.TextProtocol
 
getReadUncommitted(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getReadUncommitted() - Method in class com.sleepycat.je.CursorConfig
Returns true if read operations performed by the cursor are configured to return modified but not yet committed data.
getReadUncommitted() - Method in class com.sleepycat.je.TransactionConfig
Returns true if read operations performed by the transaction are configured to return modified but not yet committed data.
getReadyLatch() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getReason() - Method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
getReason() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.Fail
 
getRecalcToggle() - Method in class com.sleepycat.je.tree.IN
 
getReceiveBufferSize() - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
Returns the size of the receive buffer associated with the socket used to transfer files during the NetworkRestore operation.
getReceiveTimestamp() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPRequest
 
getReceiveTimestamp() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
getRecentAvgLNSizes() - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
getReconnectDelay() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Return the delay, in milliseconds, between reconnect attempts.
getRecordCount() - Method in class com.sleepycat.je.dbi.TruncateResult
 
getRecordNumber(DatabaseEntry) - Static method in class com.sleepycat.compat.DbCompat
 
getRecoveryProgressListener() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getRecoveryProgressListener() - Method in class com.sleepycat.je.EnvironmentConfig
Return the ProgressListener to be used at this environment startup.
getReference() - Method in class com.sleepycat.je.jca.ra.JEConnectionFactoryImpl
 
getReferringHandleCount() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getReferringHandles() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns a copy of the referring database handles.
getRefreshAll() - Method in class com.sleepycat.je.sync.ImportConfig
 
getRefreshVLSN() - Method in exception com.sleepycat.je.rep.InsufficientLogException
 
getRelatches() - Method in class com.sleepycat.je.BtreeStats
Returns the number of latch upgrades (relatches) required while operating on this database's BTree.
getRelatchesRequired() - Method in class com.sleepycat.je.EnvironmentStats
Returns the number of latch upgrades (relatches) required while operating on this Environment.
getRelatedEntity() - Method in class com.sleepycat.persist.model.SecondaryKeyMetadata
Returns the class name of the related (foreign) entity, for which foreign key constraints are specified using the SecondaryKey.relatedEntity() annotation.
getRelationship() - Method in class com.sleepycat.persist.model.SecondaryKeyMetadata
Returns the relationship between instances of the entity class and the secondary keys.
getRemainingLockedNodes() - Method in class com.sleepycat.je.txn.TxnChain
Returns LSNs for all nodes that should remain locked by the txn.
getRemoteBeginData() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
getRemoteBeginKey() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
getRemoteDiffSize() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
getRemovedNodes() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
 
getRemovedNodes() - Method in class com.sleepycat.je.rep.ReplicationGroup
 
getRenamer(String, int, String) - Method in class com.sleepycat.persist.evolve.Mutations
Returns the renamer mutation for the given class, version and field, or null if none exists.
getRenamers() - Method in class com.sleepycat.persist.evolve.Mutations
Returns an unmodifiable collection of all renamer mutations.
getRenumbering(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getRepConfig() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Return the replication configuration that has been used to create this handle.
getRepContext() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Return a ReplicationContext that will indicate if this operation should broadcast data records for this database as part the replication stream.
getRepEnvState() - Method in class com.sleepycat.je.rep.impl.node.NodeState
 
getRepenvUUID() - Method in class com.sleepycat.je.CommitToken
 
getRepGroup() - Method in class com.sleepycat.je.rep.monitor.GroupChangeEvent
Returns the current description of the replication group.
getRepGroupDB() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getRepGroupDbChange() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
getRepGroupImpl(ReplicationGroup) - Static method in class com.sleepycat.je.rep.RepInternal
 
getRepGroupImpl() - Method in class com.sleepycat.je.rep.ReplicationGroup
 
getRepImpl() - Method in class com.sleepycat.je.rep.elections.Elections
 
getRepImpl() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getRepImpl(ReplicatedEnvironment) - Static method in class com.sleepycat.je.rep.RepInternal
 
getRepImpl() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
 
getReplay() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getReplayElapsedTxnTime() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The total elapsed time in milliseconds spent replaying committed and aborted transactions.
getReplayMaxCommitProcessingNanos() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The maximum time taken to replay a transaction commit operation.
getReplayMinCommitProcessingNanos() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The minimum time taken to replay a transaction commit operation.
getReplayStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.Replica
Returns the replay statistics associated with the Replica.
getReplayTotalCommitProcessingNanos() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The total time spent to replay all commit operations.
getReplayTxnTimeout() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getReplayTxnTimeout() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getReplica() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getReplicaAck() - Method in class com.sleepycat.je.Durability
Returns the replica acknowledgment policy used by the master when committing changes to a replicated environment.
getReplicaAckTimeout(TimeUnit) - Method in class com.sleepycat.je.rep.ReplicationConfig
Returns the configured replica timeout value.
getReplicaCloseCatchupMs() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getReplicaConfig(EnvironmentImpl) - Method in class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
Create a database config for use on the replica which contains all the configuration options that were conveyed by way of this class.
getReplicaConsistencyPolicy(String) - Static method in class com.sleepycat.je.rep.utilint.RepUtils
Converts a property string into a policy instance.
getReplicaFeederChannel() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
getReplicaFeederSyncupHook() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
getReplicaNameIdPair() - Method in class com.sleepycat.je.rep.impl.node.Feeder
 
getReplicaNameIdPair() - Method in class com.sleepycat.je.rep.stream.FeederReplicaHandshake
Returns the replica node ID.
getReplicaNameIdPair() - Method in exception com.sleepycat.je.rep.stream.FeederReplicaSyncup.NetworkRestoreException
 
getReplicaSync() - Method in class com.sleepycat.je.Durability
Returns the transaction synchronization policy to be used by the replica as it replays a transaction that needs an acknowledgment.
getReplicaSyncPolicy() - Method in class com.sleepycat.je.rep.stream.Protocol.Commit
 
getReplicated() - Method in class com.sleepycat.je.DatabaseConfig
For internal use only.
getReplicated(DatabaseConfig) - Static method in class com.sleepycat.je.DbInternal
 
getReplicated() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getReplicated() - Method in class com.sleepycat.persist.StoreConfig
 
getReplicatedCreateConfig() - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
 
getReplicatorNodeId() - Method in class com.sleepycat.je.rep.txn.MasterTxn
A masterTxn always writes its own id into the commit or abort.
getReplicatorNodeId() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
getReplicatorNodeId() - Method in class com.sleepycat.je.txn.Txn
 
getReplicaTxnEndVLSN() - Method in class com.sleepycat.je.rep.impl.node.Feeder
Returns the latest commit VLSN that was acked by the replica, or NULL_VLSN if no commit was acked since the time the feeder was established.
getRepMutableConfig() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
 
getRepNode() - Method in class com.sleepycat.je.rep.elections.Elections
 
getRepNode() - Method in class com.sleepycat.je.rep.impl.node.Feeder
 
getRepNode() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getRepNode() - Method in exception com.sleepycat.je.rep.InsufficientLogException
 
getRepNodeImplArray(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
 
getRepStats(StatsConfig) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Returns statistics associated with this environment.
getRequestMessage(SocketChannel) - Method in class com.sleepycat.je.rep.impl.TextProtocol
Reads the channel and returns a read request.
getRequestMessage() - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
 
getRequiredAckCount() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
getRequiredEvictBytes() - Method in class com.sleepycat.je.EnvironmentStats
The number of bytes that must be evicted in order to get within the memory budget.
getRequiredNodeCount() - Method in exception com.sleepycat.je.rep.InsufficientReplicasException
Returns the number of nodes (including the master) that were required to be active in order to satisfy the Replica ack policy.
getResidentRootIN(DatabaseImpl) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
The default behavior returns (and latches shared) the IN if it is resident in the Btree, or null otherwise.
getResidentRootIN(boolean) - Method in class com.sleepycat.je.tree.Tree
 
getResolvedItem(DatabaseImpl) - Method in class com.sleepycat.je.log.entry.BaseEntry
By default, this log entry is complete and does not require fetching additional entries.
getResolvedItem(DatabaseImpl) - Method in class com.sleepycat.je.log.entry.BINDeltaLogEntry
Resolve a BINDelta item by fetching the full BIN and merging the delta.
getResolvedItem(DatabaseImpl) - Method in interface com.sleepycat.je.log.entry.LogEntry
Construct a complete item from a item entry, fetching additional log entries as needed.
getResolvedModel() - Method in class com.sleepycat.persist.impl.PersistCatalog
Returns the model parameter, default model or stored model.
getResponse(TextProtocol.RequestMessage) - Method in class com.sleepycat.je.rep.impl.GroupService.GroupServiceRunnable
 
getResponse(TextProtocol.RequestMessage) - Method in class com.sleepycat.je.rep.impl.NodeStateService.NodeStateServiceRunnable
 
getResponse(TextProtocol.RequestMessage) - Method in class com.sleepycat.je.rep.monitor.MonitorService.MonitorServiceRunnable
 
getResponse(TextProtocol.RequestMessage) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingRunnable
 
getResponse() - Method in exception com.sleepycat.je.rep.utilint.ServiceDispatcher.ServiceConnectFailedException
 
getResponseMessage() - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
Returns the response message.
getRestart() - Method in class com.sleepycat.je.txn.LockConflict
This method is called when getAllowed returns false to determine whether an exception should be thrown to cause the requester's operation to be restarted.
getResultsList() - Method in class com.sleepycat.je.jmx.plugin.Stats
 
getRetainLogFiles() - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
Returns a boolean indicating whether existing log files should be retained or deleted.
getRetryInterval() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns the number of milliseconds between ping thread retries.
getReturnType(String) - Static method in class com.sleepycat.asm.Type
Returns the Java type corresponding to the return type of the given method descriptor.
getReturnType(Method) - Static method in class com.sleepycat.asm.Type
Returns the Java type corresponding to the return type of the given method.
getReturnType() - Method in class com.sleepycat.asm.Type
Returns the return type of methods of this type.
getRewriteAllowed() - Method in class com.sleepycat.je.log.LogBuffer
 
getRollbackMsg() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
If 1 or more commits was passed, construct a message that can be used by RollbackException and RollbackProhibitedException.
getRollbackStart() - Method in class com.sleepycat.je.txn.RollbackEnd
 
getRollingChksum() - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
getRootIN(DatabaseImpl, long) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
The default behavior fetches the rootIN from the log and latches it shared.
getRootIN(CacheMode) - Method in class com.sleepycat.je.tree.Tree
Helper to obtain the root IN with shared root latching.
getRootINLatchedExclusive(CacheMode) - Method in class com.sleepycat.je.tree.Tree
Helper to obtain the root IN with exclusive root latching.
getRootLsn() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getRootLsn() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getRootLsn() - Method in class com.sleepycat.je.tree.Tree
Get LSN of the rootIN.
getRootSplits() - Method in class com.sleepycat.je.BtreeStats
The number of times the root of the BTree was split.
getRowCount() - Method in class com.sleepycat.je.jmx.plugin.Stats.StatsTableModel
 
getRunnable(SocketChannel) - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateService
 
getRunnable(SocketChannel) - Method in class com.sleepycat.je.rep.impl.GroupService
 
getRunnable(SocketChannel) - Method in class com.sleepycat.je.rep.impl.NodeStateService
 
getRunnable(SocketChannel) - Method in class com.sleepycat.je.rep.monitor.MonitorService
 
getRunnable(SocketChannel) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffService
 
getRunnable(SocketChannel) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingService
 
getRuntimeMaxMemory() - Static method in class com.sleepycat.je.dbi.MemoryBudget
Returns Runtime.maxMemory(), accounting for a MacOS bug.
getSavedExceptions() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
getSavedShutdownException() - Method in class com.sleepycat.je.utilint.StoppableThread
Returns the exception if any that provoked the shutdown
getScanIterator() - Method in class com.sleepycat.je.evictor.PrivateSelector
 
getScanIterator() - Method in class com.sleepycat.je.evictor.SharedSelector
 
getScanIterator() - Method in class com.sleepycat.je.evictor.TargetSelector
 
getScanner() - Method in class com.sleepycat.je.recovery.RollbackTracker
A Scanner is a cursor over the tracker's rollback periods.
getScannerTarget(long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
getSearchBoth(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the specified key/data pair, where both the key and data items must match.
getSearchBoth(Transaction, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Database
Retrieves the key/data pair with the given key and data value, that is, both the key and data items must match.
getSearchBoth(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
This operation is not allowed with this method signature.
getSearchBoth(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the specified secondary and primary key, where both the primary and secondary key items must match.
getSearchBoth(Transaction, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryDatabase
This operation is not allowed with this method signature.
getSearchBoth(Transaction, DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryDatabase
Retrieves the key/data pair with the specified secondary and primary key, that is, both the primary and secondary key items must match.
getSearchBoth(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getSearchBothRange(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the specified key and closest matching data item of the database.
getSearchBothRange(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
This operation is not allowed with this method signature.
getSearchBothRange(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the specified secondary key and closest matching primary key of the database.
getSearchBothRange(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getSearchKey(Object, Object, boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getSearchKey(), no join cursor allowed.
getSearchKey(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the given key of the database, and returns the datum associated with the given key.
getSearchKey(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getSearchKey(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the given key of the database, and return the datum associated with the given key.
getSearchKey() - Method in class com.sleepycat.je.tree.BINDelta
Returns a key that can be used to find the BIN associated with this delta.
getSearchKey(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getSearchKeyRange(Object, Object, boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.getSearchKeyRange(), no join cursor allowed.
getSearchKeyRange(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Moves the cursor to the closest matching key of the database, and returns the data item associated with the matching key.
getSearchKeyRange(DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
 
getSearchKeyRange(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.SecondaryCursor
Move the cursor to the closest matching key of the database, and return the data item associated with the matching key.
getSearchKeyRange(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getSearchRecordNumber(Cursor, DatabaseEntry, DatabaseEntry, LockMode) - Static method in class com.sleepycat.compat.DbCompat
 
getSearchRecordNumber(SecondaryCursor, DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Static method in class com.sleepycat.compat.DbCompat
 
getSearchRecordNumber(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
getSecondaryBulkLoad() - Method in class com.sleepycat.persist.StoreConfig
Returns the bulk-load-secondaries configuration property.
getSecondaryConfig() - Method in class com.sleepycat.je.SecondaryDatabase
Deprecated.
As of JE 4.0.13, replaced by SecondaryDatabase.getConfig().

getSecondaryConfig(Class, String) - Method in class com.sleepycat.persist.EntityStore
Returns the default secondary database Berkeley DB engine API configuration for an entity class and key name.
getSecondaryConfig(Class, String) - Method in class com.sleepycat.persist.impl.Store
 
getSecondaryDatabaseName() - Method in exception com.sleepycat.je.SecondaryReferenceException
Returns the name of the secondary database being access during the failure.
getSecondaryDatabases() - Method in class com.sleepycat.je.Database
Returns a list of all SecondaryDatabase objects associated with a primary database.
getSecondaryIndex(PrimaryIndex<PK, E>, Class<SK>, String) - Method in class com.sleepycat.persist.EntityStore
Returns a secondary index for a given primary index and secondary key, opening it if necessary.
getSecondaryIndex(PrimaryIndex<PK, E1>, Class<E2>, String, Class<SK>, String, String) - Method in class com.sleepycat.persist.impl.Store
A getSecondaryIndex with extra parameters for opening a raw store.
getSecondaryIndex(String, String) - Method in class com.sleepycat.persist.raw.RawStore
Opens the secondary index for a given entity class and secondary key name.
getSecondaryKey() - Method in exception com.sleepycat.je.SecondaryReferenceException
Returns the secondary key being access during the failure.
getSecondaryKeyMetadataByFieldName(Map<String, SecondaryKeyMetadata>, String) - Static method in class com.sleepycat.persist.impl.ComplexFormat
The secondary key metadata map (ClassMetadata.getSecondaryKeys) is keyed by key name, not field name.
getSecondaryKeys() - Method in class com.sleepycat.persist.model.ClassMetadata
Returns an unmodifiable map of key name (which may be different from field name) to secondary key metadata for all secondary keys declared in this class, or null if no secondary keys are declared in this class.
getSecondaryKeys() - Method in class com.sleepycat.persist.model.EntityMetadata
Returns an unmodifiable map of key name to secondary key metadata, or an empty map if no secondary keys are defined for this entity.
getSelector() - Method in class com.sleepycat.je.evictor.Evictor
 
getSenderId() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Message
 
getSendVersion() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Message
 
getSequence() - Method in class com.sleepycat.je.utilint.VLSN
 
getSequence(String) - Method in class com.sleepycat.persist.EntityStore
Returns a named sequence for using Berkeley DB engine API directly, opening it if necessary.
getSequence(String) - Method in class com.sleepycat.persist.impl.Store
 
getSequenceConfig(String) - Method in class com.sleepycat.persist.EntityStore
Returns the default Berkeley DB engine API configuration for a named key sequence.
getSequenceConfig(String) - Method in class com.sleepycat.persist.impl.Store
 
getSequenceKeyFormat() - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
getSequenceKeyFormat() - Method in class com.sleepycat.persist.impl.Format
Validates and returns the simple integer key format for a sequence key associated with this format.
getSequenceKeyFormat() - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
getSequenceKeyFormat() - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
getSequenceKeyFormat() - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
getSequenceKeyFormat() - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
getSequenceName() - Method in class com.sleepycat.persist.model.PrimaryKeyMetadata
Returns the name of the sequence for assigning key values.
getSerialBufferSize() - Method in class com.sleepycat.bind.serial.SerialBase
Returns the initial byte size of the output buffer.
getSerializableIsolation() - Method in class com.sleepycat.je.TransactionConfig
Returns true if the transaction has been explicitly configured to have serializable (degree 3) isolation.
getSerialOutput(Object) - Method in class com.sleepycat.bind.serial.SerialBase
Returns an empty SerialOutput instance that will be used by the serial binding or key creator.
getServiceDispatcher() - Method in class com.sleepycat.je.rep.elections.Elections
 
getServiceDispatcher() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getServiceOutputStream(Socket, String) - Static method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
Used by the client to establish an output stream for the service on the socket.
getSetupTimeout() - Method in class com.sleepycat.je.rep.impl.node.JoinGroupTimeouts
Returns the setup timeout
getSHA1Digest(File, long) - Static method in class com.sleepycat.je.rep.impl.networkRestore.LogFileFeeder
Returns the SHA1 has associated with the file.
getSharedCache() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getSharedCache() - Method in class com.sleepycat.je.EnvironmentConfig
Returns true if the shared cache is used by this environment.
getSharedCacheTotalBytes() - Method in class com.sleepycat.je.EnvironmentStats
The total amount of the shared JE cache in use, in bytes.
getSharedLatches() - Static method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getSharedLogEntry() - Method in class com.sleepycat.je.log.LogEntryType
 
getShort(ShortConfigParam) - Method in class com.sleepycat.je.dbi.DbConfigManager
Get this parameter from the environment wide configuration settings.
getShowProgressInterval() - Method in class com.sleepycat.je.StatsConfig
Returns the showProgressInterval value, if set.
getShowProgressInterval() - Method in class com.sleepycat.je.VerifyConfig
Returns the showProgressInterval value, if set.
getShowProgressStream() - Method in class com.sleepycat.je.StatsConfig
Returns the PrintStream on which the progress messages will be displayed during long running statistics gathering operations.
getShowProgressStream() - Method in class com.sleepycat.je.VerifyConfig
Returns the PrintStream on which the progress messages will be displayed during long running verify operations.
getShutdownTimeMs() - Method in class com.sleepycat.je.rep.stream.Protocol.ShutdownRequest
 
getShutdownVLSN() - Method in exception com.sleepycat.je.rep.GroupShutdownException
For internal use only.
getSingleKey() - Method in class com.sleepycat.util.keyrange.KeyRange
Returns the key of a single-key range, or null if not a single-key range.
getSingleKeyThang() - Method in class com.sleepycat.collections.DataView
Returns the key thang for a single key range, or null if a single key range is not used.
getSize() - Method in class com.sleepycat.asm.AnnotationWriter
Returns the size of this annotation writer list.
getSize(ClassWriter, byte[], int, int, int) - Method in class com.sleepycat.asm.Attribute
Returns the size of all the attributes in this attribute list.
getSize() - Method in class com.sleepycat.asm.FieldWriter
Returns the size of this field.
getSize() - Method in class com.sleepycat.asm.MethodWriter
Returns the size of the bytecode of this method.
getSize() - Method in class com.sleepycat.asm.Type
Returns the size of values of this type.
getSize() - Method in class com.sleepycat.je.DatabaseEntry
Returns the byte size of the data array.
getSize() - Method in class com.sleepycat.je.dbi.INList
 
getSize() - Method in class com.sleepycat.je.log.entry.DeletedDupLNLogEntry
Extend super class to add in extra key.
getSize() - Method in class com.sleepycat.je.log.entry.INLogEntry
 
getSize() - Method in class com.sleepycat.je.log.entry.LNLogEntry
#see LogEntry#getSize
getSize() - Method in interface com.sleepycat.je.log.entry.LogEntry
 
getSize() - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
Extends its super class to add in database operation information.
getSize() - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
getSize() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getSizeMinusChecksum() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getSocket() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getSocket() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getSocket(String) - Static method in class com.sleepycat.je.rep.utilint.HostPortPair
Parses a hostPort pair into the socket it represents.
getSocketAddress() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getSocketAddress() - Method in class com.sleepycat.je.rep.monitor.NewMasterEvent
Returns the socket address associated with the new master
getSocketAddress() - Method in interface com.sleepycat.je.rep.ReplicationNode
The socket address used by other nodes in the replication group to communicate with this node.
getSocketAddress() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
Returns the socket associated with the dispatcher
getSocketConnectTimeout() - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Returns the socketConnection timeout, in milliseconds, used when the ping thread attempts to establish a connection with a replication node.
getSockets(String) - Static method in class com.sleepycat.je.rep.utilint.HostPortPair
Parses hostPort pairs into sockets it represents.
getSort() - Method in class com.sleepycat.asm.Type
Returns the sort of this Java type.
getSortedBigDecimalByteLength() - Method in class com.sleepycat.bind.tuple.TupleInput
Returns the byte length of a sorted BigDecimal.
getSortedBigDecimalMaxByteLength(BigDecimal) - Static method in class com.sleepycat.bind.tuple.TupleOutput
Returns the maximum byte length that would be output for a given BigDecimal value if TupleOutput.writeSortedBigDecimal(java.math.BigDecimal) were called.
getSortedCursors(JoinCursor) - Static method in class com.sleepycat.je.DbInternal
Proxy to JoinCursor.getSortedCursors()
getSortedCursors() - Method in class com.sleepycat.je.JoinCursor
For unit testing.
getSortedDuplicates(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getSortedDuplicates() - Method in class com.sleepycat.je.DatabaseConfig
Returns true if the database is configured to support records with duplicate keys.
getSortedDuplicates() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getSortedDuplicates(byte) - Static method in class com.sleepycat.je.dbi.DatabaseImpl
 
getSortedPackedIntByteLength() - Method in class com.sleepycat.bind.tuple.TupleInput
Returns the byte length of a sorted packed integer.
getSortedPackedLongByteLength() - Method in class com.sleepycat.bind.tuple.TupleInput
Returns the byte length of a sorted packed long integer.
getSplitBins() - Method in class com.sleepycat.je.EnvironmentStats
The number of BINs encountered by the INCompressor that were split between the time they were put on the compressor queue and when the compressor ran.
getStackTrace(Throwable) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Return a String version of a stack trace
getStackTrace() - Static method in class com.sleepycat.je.utilint.LoggerUtils
Return the stack trace of the caller, for debugging.
getStartingLsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.BackwardVLSNScanner
 
getStartingLsn(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.ForwardVLSNScanner
Use the <= mapping to the requested VLSN to find the starting lsn to use for a scan.
getStartMs() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
getStartTime() - Method in class com.sleepycat.je.rep.impl.node.MasterTransfer
 
getStartupTracker() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getState() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns the current state associated with this ReplicatedEnvironment
getState() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Returns the current state of the node associated with this replication environment.
getState() - Method in class com.sleepycat.je.rep.StateChangeEvent
Returns the state that the node has transitioned to.
getState() - Method in class com.sleepycat.je.Transaction
Returns the current state of the transaction.
getState() - Method in class com.sleepycat.je.tree.ChildReference
 
getState() - Method in class com.sleepycat.je.tree.DeltaInfo
 
getState(int) - Method in class com.sleepycat.je.tree.IN
 
getState() - Method in class com.sleepycat.je.txn.Txn
 
getStateChangeEvent() - Method in class com.sleepycat.je.rep.impl.node.NodeState
 
getStateChangeEvent() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns the state change event that transitioned the ReplicatedEnviroment to its current state.
getStateChangeListener() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Returns the listener used to receive asynchronous replication node state change events.
getStatGroups() - Method in class com.sleepycat.je.EnvironmentStats
 
getStatGroups() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
 
getStatGroupTitles() - Static method in class com.sleepycat.je.EnvironmentStats
 
getStatGroupTitles() - Static method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
 
GETSTATIC - Static variable in interface com.sleepycat.asm.Opcodes
 
getStatistics() - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
getStats(StatsConfig) - Method in class com.sleepycat.je.Database
Returns database statistics.
getStats(StatsConfig) - Method in class com.sleepycat.je.Environment
Returns the general database environment statistics.
getStats() - Method in class com.sleepycat.je.rep.elections.Elections
Statistics used during testing.
getStats() - Method in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackup
Returns statistics associated with the NetworkBackup execution.
getStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.Replay
Returns a copy of the statistics associated with Replay
getStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the accumulated statistics for this node.
getStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getStats() - Method in class com.sleepycat.je.rep.stream.FeederTxns
 
getStats(StatsConfig) - Method in class com.sleepycat.je.rep.stream.FeederTxns
 
getStats(StatsConfig) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
getStats(StatsConfig) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Returns the statistics associated with the VLSNIndex
getStats(StatsConfig) - Method in class com.sleepycat.je.Sequence
Returns statistical information about the sequence.
getStats() - Method in class com.sleepycat.je.utilint.StatGroup
 
getStats() - Method in class com.sleepycat.persist.evolve.EvolveEvent
The cummulative statistics gathered during eager evolution.
getStatsConfig(Object[]) - Method in class com.sleepycat.je.jmx.JEMBean
Helper for creating a StatsConfig object to use as an operation parameter.
getStatsGroup() - Method in class com.sleepycat.je.evictor.Evictor
 
getStatus() - Method in class com.sleepycat.je.PreloadStats
Returns the PreloadStatus value for the preload() operation.
getStoreName() - Method in class com.sleepycat.persist.EntityStore
Returns the name of this store.
getStoreName() - Method in class com.sleepycat.persist.impl.Store
 
getStoreName() - Method in class com.sleepycat.persist.raw.RawStore
Returns the name of this store.
getStoreNames(Environment) - Static method in class com.sleepycat.persist.EntityStore
Returns the names of all entity stores in the given environment.
getStoreNames(Environment) - Static method in class com.sleepycat.persist.impl.Store
 
getStreamHeader() - Static method in class com.sleepycat.bind.serial.SerialOutput
Returns the fixed stream header used for all serialized streams in PROTOCOL_VERSION_2 format.
getString() - Method in class com.sleepycat.je.rep.elections.Protocol.StringValue
 
getString(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
Reconstitutes the string serialized by the above method.
getString(String, int) - Static method in class com.sleepycat.je.rep.utilint.HostPortPair
 
getString(StatDefinition) - Method in class com.sleepycat.je.utilint.StatGroup
 
getStringArray(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
Reconstitutes an array of strings.
getStringByteLength() - Method in class com.sleepycat.bind.tuple.TupleInput
Returns the byte length of a null-terminated UTF string in the data buffer, including the terminator.
getStringLogSize(String) - Static method in class com.sleepycat.je.log.LogUtils
 
getSubclassFormats(Format) - Method in class com.sleepycat.persist.impl.Evolver
Returns the set of formats for a specific superclass format, or null if the superclass is not a complex type or has not subclasses.
getSubclassIndex(PrimaryIndex<PK, E1>, Class<E2>, Class<SK>, String) - Method in class com.sleepycat.persist.EntityStore
Returns a secondary index for a secondary key in an entity subclass, opening it if necessary.
getSubclassMap() - Method in class com.sleepycat.persist.impl.PersistCatalog
Returns a map from format to a set of its superclass formats.
getSuggestion() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
getSuggestionGenerator() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getSuggestionRanking() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
getSuper() - Method in class com.sleepycat.persist.raw.RawObject
Returns the instance of the superclass, or null if the superclass is Object or Enum.
getSuperFormat() - Method in class com.sleepycat.persist.impl.Format
Returns the format of the superclass.
getSuperName() - Method in class com.sleepycat.asm.ClassReader
Returns the internal of name of the super class (see getInternalName).
getSuperType() - Method in class com.sleepycat.persist.impl.Format
 
getSuperType() - Method in interface com.sleepycat.persist.raw.RawType
Returns the type of the superclass, or null if the superclass is Object or this is not a complex type (in other words, this is a simple type or an array type).
getSuppressGroupDBUpdates() - Static method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNUpdater
 
getSync() - Method in class com.sleepycat.je.TransactionConfig
Returns true if the transaction is configured to write and synchronously flush the log it when commits.
getSyncCleanerBarrier() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getSyncDB() - Method in class com.sleepycat.je.sync.SyncProcessor
 
getSyncDbs() - Method in class com.sleepycat.je.sync.impl.LogChangeReader
 
getSyncStart(String) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier
 
getSyncupProgressListener() - Method in class com.sleepycat.je.rep.ReplicationConfig
Return the ProgressListener to be used at this environment startup.
getSyncupVLSN() - Method in class com.sleepycat.je.rep.stream.Protocol.HeartbeatResponse
 
getSystemLoad() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
getSystemLoad() - Method in class com.sleepycat.je.rep.NodeState
Returns the system load average for the last minute.
getSystemLoad() - Static method in class com.sleepycat.je.utilint.JVMSystemUtils
 
getTabs() - Method in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
getTag() - Method in class com.sleepycat.asm.Handle
Returns the kind of field or method designated by this handle.
getTagName() - Method in class com.sleepycat.je.txn.TxnAbort
 
getTagName() - Method in class com.sleepycat.je.txn.TxnCommit
 
getTagName() - Method in class com.sleepycat.je.txn.TxnEnd
 
getTagName() - Method in class com.sleepycat.je.txn.TxnPrepare
 
getTarget() - Method in class com.sleepycat.je.tree.ChildReference
Return the target for this ChildReference.
getTarget(int) - Method in class com.sleepycat.je.tree.IN
Return the idx'th target.
getTargets() - Method in class com.sleepycat.je.tree.IN
 
getTemporary() - Method in class com.sleepycat.je.DatabaseConfig
Returns the temporary database option.
getTemporary() - Method in class com.sleepycat.persist.StoreConfig
Returns the temporary configuration property.
getterAndSetterMethods - Static variable in class com.sleepycat.util.ConfigBeanInfoBase
 
getTestDelayMs() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
getThread() - Method in class com.sleepycat.je.utilint.DaemonThread
For testing.
getThreadLocalReferenceCount() - Static method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getThreadLockers(Thread) - Method in class com.sleepycat.je.txn.LockManager
Returns an iterator over all thread lockers for the given thread, or an empty iterator if none.
getThreadName() - Method in class com.sleepycat.je.ExceptionEvent
Returns the name of the daemon thread that threw the exception.
getThreadPool() - Method in class com.sleepycat.je.evictor.Evictor
 
getThreadPool() - Method in class com.sleepycat.je.rep.elections.Elections
 
getThreadTransaction(Environment) - Static method in class com.sleepycat.compat.DbCompat
 
getThreadTransaction() - Method in class com.sleepycat.je.Environment
Returns the transaction associated with this thread if implied transactions are being used.
getThreadWaitInterval() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getThreshold() - Method in exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.LoadThresholdExceededException
 
getThrown(LogRecord, StringBuilder) - Method in class com.sleepycat.je.utilint.TracerFormatter
 
getTime() - Method in class com.sleepycat.je.txn.TxnEnd
 
getTime() - Method in class com.sleepycat.je.utilint.Timestamp
 
getTimeout(TimeUnit) - Method in class com.sleepycat.je.rep.CommitPointConsistencyPolicy
Return the timeout specified when creating this consistency policy.
getTimeOut() - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
 
getTimeout() - Method in class com.sleepycat.je.rep.impl.node.JoinGroupTimeouts
Returns the currently active timeout, adjusted for the time that has already elapsed.
getTimeout(TimeUnit) - Method in class com.sleepycat.je.rep.impl.PointConsistencyPolicy
 
getTimeout() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferMaster
 
getTimeout(TimeUnit) - Method in class com.sleepycat.je.rep.NoConsistencyRequiredPolicy
Always returns 0, no timeout is needed for this policy.
getTimeout(TimeUnit) - Method in class com.sleepycat.je.rep.TimeConsistencyPolicy
Returns the consistency timeout associated with this policy.
getTimeout(TimeUnit) - Method in interface com.sleepycat.je.ReplicaConsistencyPolicy
The timeout associated with the consistency policy.
getTimeoutMillis() - Method in exception com.sleepycat.je.LockConflictException
 
getTimeoutMs() - Method in class com.sleepycat.je.rep.impl.node.DbCache
Returns the configured timeout in ms.
getTimer() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the timer associated with this RepNode
getTimeStamp() - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
 
getTimestampLogSize(Timestamp) - Static method in class com.sleepycat.je.log.LogUtils
 
getTips() - Method in class com.sleepycat.je.EnvironmentStats
 
getTips() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
 
getTModel() - Method in class com.sleepycat.je.jmx.plugin.Stats
 
getToBeCleanedFiles() - Method in class com.sleepycat.je.cleaner.FileSelector
Returns a read-only copy of TO_BE_CLEANED files that can be accessed without synchronization.
getTotalCpuTime() - Method in class com.sleepycat.je.utilint.StoppableThread
Returns the total cpu time associated with the thread, after the thread has been shutdown.
getTotalLogSize() - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Returns an approximation of the total log size.
getTotalLogSize() - Method in class com.sleepycat.je.EnvironmentStats
An approximation of the current total log size in bytes.
getTotalOps() - Method in class com.sleepycat.utilint.Latency
 
getTotals() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
getTotalTxnMs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The total time in milliseconds spent in replicated transactions.
getTotalUserTime() - Method in class com.sleepycat.je.utilint.StoppableThread
Returns the total cpu time associated with the thread, after the thread has been shutdown.
getTrackedDbs() - Method in class com.sleepycat.je.cleaner.LocalUtilizationTracker
 
getTrackedFile(long) - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Returns one file from the snapshot of tracked files, or null if the given file number is not in the snapshot array.
getTrackedFiles() - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Returns a snapshot of the files being tracked as of the last time a log entry was added.
getTrackedSummary() - Method in class com.sleepycat.je.tree.FileSummaryLN
Returns the tracked summary, or null if setTrackedSummary was not called.
getTrackerBudget() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
getTrackerLagConsistencyWaitMs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The total time (in msec) for which a Replica held back a Environment.beginTransaction(Transaction,TransactionConfig) operation to satisfy the TimeConsistencyPolicy.
getTrackerLagConsistencyWaits() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of times a Replica held back a Environment.beginTransaction(Transaction,TransactionConfig) operation to satisfy the TimeConsistencyPolicy.
getTrackerStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.Replica
 
getTrackerVLSNConsistencyWaitMs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The total time (in msec) for which a Replica held back a Environment.beginTransaction(Transaction,TransactionConfig) operation to satisfy the CommitPointConsistencyPolicy.
getTrackerVLSNConsistencyWaits() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
The number of times a Replica held back a Environment.beginTransaction(Transaction,TransactionConfig) operation to satisfy the CommitPointConsistencyPolicy.
getTransaction() - Method in class com.sleepycat.collections.CurrentTransaction
Returns the transaction associated with the current thread for this environment, or null if no transaction is active.
getTransaction() - Method in class com.sleepycat.je.jca.ra.JEConnection
 
getTransaction() - Method in class com.sleepycat.je.jca.ra.JELocalTransaction
 
getTransaction() - Method in class com.sleepycat.je.txn.BuddyLocker
Forwards this call to the buddy locker.
getTransaction() - Method in class com.sleepycat.je.txn.Locker
Returns a Transaction is the locker is transctional, or null otherwise.
getTransaction() - Method in class com.sleepycat.je.txn.Txn
 
getTransactional() - Method in class com.sleepycat.je.DatabaseConfig
Returns true if the database open is enclosed within a transaction.
getTransactional() - Method in class com.sleepycat.je.EnvironmentConfig
Returns true if the database environment is configured for transactions.
getTransactional() - Method in class com.sleepycat.persist.StoreConfig
Returns the transactional configuration property.
getTransactionConfig() - Method in class com.sleepycat.collections.TransactionRunner
getTransactionConfig() - Method in class com.sleepycat.je.jca.ra.JERequestInfo
 
getTransactionId() - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
Not used.
getTransactionId() - Method in class com.sleepycat.je.cleaner.DbFileSummary
Never called.
getTransactionId() - Method in class com.sleepycat.je.cleaner.FileSummary
Never called.
getTransactionId() - Method in class com.sleepycat.je.cleaner.PackedOffsets
Never called.
getTransactionId() - Method in class com.sleepycat.je.dbi.DatabaseId
 
getTransactionId() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getTransactionId() - Method in class com.sleepycat.je.dbi.DbTree
 
getTransactionId() - Method in class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
 
getTransactionId() - Method in enum com.sleepycat.je.log.entry.DbOperationType
 
getTransactionId() - Method in class com.sleepycat.je.log.entry.INLogEntry
 
getTransactionId() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getTransactionId() - Method in interface com.sleepycat.je.log.entry.LogEntry
 
getTransactionId() - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
getTransactionId() - Method in class com.sleepycat.je.log.FileHeader
 
getTransactionId() - Method in interface com.sleepycat.je.log.Loggable
 
getTransactionId() - Method in class com.sleepycat.je.log.Trace
 
getTransactionId() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
getTransactionId() - Method in class com.sleepycat.je.recovery.CheckpointStart
 
getTransactionId() - Method in interface com.sleepycat.je.sync.ChangeReader.ChangeTxn
Returns the transction ID that can be shared with the external system.
getTransactionId() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChangeTxn
 
getTransactionId() - Method in class com.sleepycat.je.tree.BINDelta
 
getTransactionId() - Method in class com.sleepycat.je.tree.ChildReference
 
getTransactionId() - Method in class com.sleepycat.je.tree.DeltaInfo
 
getTransactionId() - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
getTransactionId() - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
getTransactionId() - Method in class com.sleepycat.je.tree.Node
 
getTransactionId() - Method in class com.sleepycat.je.tree.Tree
 
getTransactionId() - Method in class com.sleepycat.je.txn.RollbackEnd
 
getTransactionId() - Method in class com.sleepycat.je.txn.RollbackStart
 
getTransactionId() - Method in class com.sleepycat.je.txn.Txn
 
getTransactionId() - Method in class com.sleepycat.je.txn.TxnEnd
 
getTransactionId() - Method in class com.sleepycat.je.utilint.Matchpoint
 
getTransactionId() - Method in class com.sleepycat.je.utilint.VLSN
 
getTransactionStats(StatsConfig) - Method in class com.sleepycat.je.Environment
Returns the database environment's transactional statistics.
getTransactionTimeout() - Method in class com.sleepycat.je.XAEnvironment
 
getTransmitTimestamp() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
getTree() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
getTreeAdminMemory() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Figure out how much memory is used by the DbFileSummaryMap.
getTreeAdminMemory() - Method in class com.sleepycat.je.dbi.DbTree
 
getTreeAdminMemorySize() - Method in class com.sleepycat.je.tree.BIN
Returns the treeAdmin memory in objects referenced by this BIN.
getTreeAdminMemorySize() - Method in class com.sleepycat.je.tree.IN
Returns the treeAdmin memory in objects referenced by this IN.
getTreeAdminMemoryUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
getTreeMemoryUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget
Used for unit testing.
getTreeStats() - Method in class com.sleepycat.je.tree.Tree
 
getTriggerDbs() - Method in class com.sleepycat.je.txn.Txn
Returns the set of databases for which transaction commit/abort triggers must be run.
getTriggerLatch() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the shared trigger latch.
getTriggerLSN() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.VLSNAwaitLatch
 
getTriggers() - Method in class com.sleepycat.je.DatabaseConfig
 
getTriggers() - Method in class com.sleepycat.je.dbi.DatabaseImpl
This method should be the only method used to obtain triggers after reading the MapLN from the log.
getTriggerVLSN() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.VLSNAwaitLatch
 
getTruncateOldDbId() - Method in class com.sleepycat.je.log.DbOpReplicationContext
 
getTruncateOldDbId() - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
 
getTruncationFileNumber() - Method in exception com.sleepycat.je.rep.RollbackProhibitedException
 
getTruncationFileOffset() - Method in exception com.sleepycat.je.rep.RollbackProhibitedException
The JE log must be truncated to this offset in the specified file in order for this node to rejoin the group.
getTupleBufferSize() - Method in class com.sleepycat.bind.tuple.TupleBase
Returns the initial byte size of the output buffer.
getTupleOutput(BigDecimal) - Method in class com.sleepycat.bind.tuple.BigDecimalBinding
 
getTupleOutput(BigInteger) - Method in class com.sleepycat.bind.tuple.BigIntegerBinding
 
getTupleOutput(Boolean) - Method in class com.sleepycat.bind.tuple.BooleanBinding
 
getTupleOutput(Byte) - Method in class com.sleepycat.bind.tuple.ByteBinding
 
getTupleOutput(Character) - Method in class com.sleepycat.bind.tuple.CharacterBinding
 
getTupleOutput(Double) - Method in class com.sleepycat.bind.tuple.DoubleBinding
 
getTupleOutput(Float) - Method in class com.sleepycat.bind.tuple.FloatBinding
 
getTupleOutput(Integer) - Method in class com.sleepycat.bind.tuple.IntegerBinding
 
getTupleOutput(Long) - Method in class com.sleepycat.bind.tuple.LongBinding
 
getTupleOutput(Integer) - Method in class com.sleepycat.bind.tuple.PackedIntegerBinding
 
getTupleOutput(Long) - Method in class com.sleepycat.bind.tuple.PackedLongBinding
 
getTupleOutput(Short) - Method in class com.sleepycat.bind.tuple.ShortBinding
 
getTupleOutput(BigDecimal) - Method in class com.sleepycat.bind.tuple.SortedBigDecimalBinding
 
getTupleOutput(Double) - Method in class com.sleepycat.bind.tuple.SortedDoubleBinding
 
getTupleOutput(Float) - Method in class com.sleepycat.bind.tuple.SortedFloatBinding
 
getTupleOutput(Integer) - Method in class com.sleepycat.bind.tuple.SortedPackedIntegerBinding
 
getTupleOutput(Long) - Method in class com.sleepycat.bind.tuple.SortedPackedLongBinding
 
getTupleOutput(String) - Method in class com.sleepycat.bind.tuple.StringBinding
 
getTupleOutput(E) - Method in class com.sleepycat.bind.tuple.TupleBase
Returns an empty TupleOutput instance that will be used by the tuple binding or key creator.
getTxn(Transaction) - Static method in class com.sleepycat.je.DbInternal
 
getTxn() - Method in class com.sleepycat.je.Transaction
 
getTxnAbortId() - Method in class com.sleepycat.je.log.LNFileReader
Get the last txn abort id seen by the reader.
getTxnCommitId() - Method in class com.sleepycat.je.log.LNFileReader
Get the last txn commit id seen by the reader.
getTxnEndVLSN() - Method in class com.sleepycat.je.rep.stream.Protocol.HeartbeatResponse
 
getTxnForThread() - Method in class com.sleepycat.je.txn.TxnManager
Retrieve a Txn object for this Thread.
getTxnFromXid(Xid) - Method in class com.sleepycat.je.txn.TxnManager
Retrieve a Txn object from an Xid.
getTxnId() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getTxnId() - Method in class com.sleepycat.je.log.LNFileReader
 
getTxnId() - Method in class com.sleepycat.je.rep.stream.Protocol.Ack
 
getTxnLocker() - Method in class com.sleepycat.je.txn.BasicLocker
No transactional locker is available.
getTxnLocker() - Method in class com.sleepycat.je.txn.BuddyLocker
Forwards this call to the buddy locker.
getTxnLocker() - Method in class com.sleepycat.je.txn.Locker
Returns the underlying Txn if the locker is transactional, or null if the locker is non-transactional.
getTxnLocker() - Method in class com.sleepycat.je.txn.Txn
This is a transactional locker.
getTxnManager() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getTxnNoSync() - Method in class com.sleepycat.je.EnvironmentMutableConfig
getTxnPrepareId() - Method in class com.sleepycat.je.log.LNFileReader
Get the last txn prepare id seen by the reader.
getTxnPrepareXid() - Method in class com.sleepycat.je.log.LNFileReader
Get the last txn prepare Xid seen by the reader.
getTxnReadCommitted(EnvironmentConfig) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentConfig.setTxnReadCommitted()
getTxnReadCommitted() - Method in class com.sleepycat.je.EnvironmentConfig
For unit testing, to set readCommitted as the default.
getTxnSerializableIsolation() - Method in class com.sleepycat.je.EnvironmentConfig
Returns true if all transactions for this environment has been configured to have Serializable (Degree 3) isolation.
getTxnStartMillis() - Method in class com.sleepycat.je.txn.Locker
 
getTxnTimeout() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getTxnTimeout(TimeUnit) - Method in class com.sleepycat.je.EnvironmentConfig
Returns the transaction timeout.
getTxnTimeout() - Method in class com.sleepycat.je.EnvironmentConfig
Deprecated.
getTxnTimeout(TimeUnit) - Method in class com.sleepycat.je.Transaction
Returns the timeout value for the transaction lifetime.
getTxnTimeout() - Method in class com.sleepycat.je.txn.BuddyLocker
Returns the transaction timeout of the buddy locker, since this locker has no independent timeout.
getTxnTimeout() - Method in class com.sleepycat.je.txn.Locker
Get the transaction timeout period for this locker, in milliseconds public for jca/ra/JELocalTransaction.
getTxnVLSN() - Method in class com.sleepycat.je.rep.impl.node.Replay.TxnInfo
 
getTxnWriteNoSync() - Method in class com.sleepycat.je.EnvironmentMutableConfig
getType(String) - Static method in class com.sleepycat.asm.Type
Returns the Java type corresponding to the given type descriptor.
getType(Class<?>) - Static method in class com.sleepycat.asm.Type
Returns the Java type corresponding to the given class.
getType(Constructor<?>) - Static method in class com.sleepycat.asm.Type
Returns the Java method type corresponding to the given constructor.
getType(Method) - Static method in class com.sleepycat.asm.Type
Returns the Java method type corresponding to the given method.
getType() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getType() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
getType() - Method in interface com.sleepycat.je.rep.ReplicationNode
Returns the type associated with the node.
getType() - Method in interface com.sleepycat.je.sync.ChangeReader.Change
Returns the operation type of this change.
getType() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.JEChange
 
getType() - Method in class com.sleepycat.je.tree.INArrayRep
 
getType() - Method in class com.sleepycat.je.tree.INKeyRep.Default
 
getType() - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
getType() - Method in class com.sleepycat.je.tree.INTargetRep.Default
 
getType() - Method in class com.sleepycat.je.tree.INTargetRep.None
 
getType() - Method in class com.sleepycat.je.tree.INTargetRep.Sparse
 
getType() - Method in class com.sleepycat.je.tree.Node
 
getType() - Method in class com.sleepycat.persist.impl.FieldInfo
 
getType() - Method in class com.sleepycat.persist.impl.Format
Returns the class that this format represents.
getType() - Method in interface com.sleepycat.persist.raw.RawField
Returns the type of the field, without expanding parameterized types, or null if the type is an interface type or the Object class.
getType() - Method in class com.sleepycat.persist.raw.RawObject
Returns the raw type information for this raw object.
getTypeNum() - Method in class com.sleepycat.je.log.LogEntryType
 
getUnconvertedDataLength() - Method in class com.sleepycat.je.log.entry.LNLogEntry
This method is only used when the converted length is not needed, for example by StatsFileReader.
getUnconvertedKeyLength() - Method in class com.sleepycat.je.log.entry.LNLogEntry
This method is only used when the converted length is not needed, for example by StatsFileReader.
getUnexpectedMessage() - Method in exception com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolException
 
getUnflushableTrackedSummary(long) - Method in class com.sleepycat.je.cleaner.UtilizationTracker
Returns a tracked summary for the given file which will not be flushed.
getUnflushableTrackedSummary(long) - Method in class com.sleepycat.je.log.LogManager
Returns a tracked summary for the given file which will not be flushed.
getUnflushableTrackedSummary(long) - Method in class com.sleepycat.je.log.SyncedLogManager
 
getUnflushableTrackedSummaryInternal(long) - Method in class com.sleepycat.je.log.LogManager
 
getUnsortedDuplicates(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getUpcomingVLSN() - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
Return the VLSN that should come after the lastVLSN.
getUpdate(VLSNRange) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
Incorporate the information in "other" in this range.
getUpdateForNewMapping(VLSN, byte) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
A new VLSN->LSN mapping has been registered in a bucket.
getUpgrade(LockType) - Method in class com.sleepycat.je.txn.LockType
Returns the LockUpgrade that results when this lock type is held and the given lock type is requested by the same locker.
getUpgrade() - Method in class com.sleepycat.je.txn.LockUpgrade
This method is called first to determine whether an upgrade to a new lock type is needed, and what the new lock type should be.
getUpperINStatDef() - Method in enum com.sleepycat.je.evictor.Evictor.EvictionSource
 
getURL() - Method in class com.sleepycat.je.sync.jdbc.JDBCConnectionConfig
 
getURL() - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
getUseExistingConfig() - Method in class com.sleepycat.je.DatabaseConfig
Return the value of the useExistingConfig property.
getUserKeyData(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.log.entry.LNLogEntry
Translates two-part keys in duplicate DBs back to the original user operation params.
getUserName() - Method in class com.sleepycat.je.jca.ra.JEConnectionMetaData
 
getUserName() - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
getUserTxn() - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
getUseWriteQueue() - Method in class com.sleepycat.je.log.FileManager
For unit tests.
getUtilizationCalculator() - Method in class com.sleepycat.je.cleaner.Cleaner
 
getUtilizationProfile() - Method in class com.sleepycat.je.cleaner.Cleaner
 
getUtilizationProfile() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the UtilizationProfile.
getUtilizationRepairDone() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Is public for unit testing.
getUtilizationTracker() - Method in class com.sleepycat.je.cleaner.Cleaner
 
getUtilizationTracker() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Returns the UtilizationTracker.
getUUID() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the UUID associated with the replicated environment.
getUUID() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
returns the unique UUID associated with the replicated environment.
getUUID() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getUUID() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
getUUID() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoOK
 
getVal(Properties, ConfigParam) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for environment and replication configuration classes.
getVal(Properties, ConfigParam, String) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for environment and replication configuration classes.
getValidateParams() - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
getValidateParams() - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
 
getValue() - Method in class com.sleepycat.collections.MapEntryParameter
Returns the value of this entry.
getValue(Object) - Method in class com.sleepycat.collections.StoredContainer
 
getValue() - Method in class com.sleepycat.je.rep.elections.Protocol.Accept
 
getValue() - Method in class com.sleepycat.je.rep.elections.Protocol.Accepted
 
getValue() - Method in class com.sleepycat.je.SequenceStats
Returns the current cached value of the sequence.
getValue() - Method in class com.sleepycat.je.utilint.Adler32
Returns current checksum value.
getValueAt(int, int) - Method in class com.sleepycat.je.jmx.plugin.Stats.StatsTableModel
 
getValueBinding() - Method in class com.sleepycat.je.sync.RecordMapping
Returns the value binding, or null if an entity binding is used.
getValues() - Method in class com.sleepycat.persist.raw.RawObject
Returns a map of field name to value for a complex type, or null for an array type or an enum type.
getValueThang() - Method in class com.sleepycat.collections.DataCursor
Returns the internal value entry.
getVariableCacheUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
getVariablePortionSize() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getVerbose() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Return whether or not the operation will output information on its success or failure.
getVerbose() - Method in class com.sleepycat.persist.model.ClassEnhancer
Gets verbose mode.
getVersion() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getVersion() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the version of the representation (the schema) in use by this group instance in the database.
getVersion() - Method in class com.sleepycat.je.rep.stream.Protocol.JEVersions
 
getVersion() - Method in class com.sleepycat.je.rep.stream.Protocol.ProtocolVersion
 
getVersion() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
Returns the version associated with this protocol instance.
getVersion() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolVersion
 
getVersion() - Method in class com.sleepycat.persist.impl.Format
 
getVersion() - Method in class com.sleepycat.persist.model.ClassMetadata
Returns the version of this persistent class.
getVersion() - Method in interface com.sleepycat.persist.raw.RawType
Returns the class version for this type.
getVersionHeader() - Static method in exception com.sleepycat.je.DatabaseException
For internal use only.
getVersionString() - Method in class com.sleepycat.je.JEVersion
Release version, suitable for display.
getView() - Method in class com.sleepycat.collections.DataCursor
Returns the view for this cursor.
getVLSN() - Method in class com.sleepycat.je.CommitToken
 
getVLSN() - Method in class com.sleepycat.je.dbi.RecordVersion
 
getVLSN() - Method in class com.sleepycat.je.log.LNFileReader
Return the VLSN if this entry is in replicated stream.
getVLSN() - Method in class com.sleepycat.je.log.LogEntryHeader
 
getVLSN() - Method in class com.sleepycat.je.rep.impl.node.MasterTransfer.VLSNProgress
 
getVlsn() - Method in exception com.sleepycat.je.rep.stream.FeederReplicaSyncup.NetworkRestoreException
 
getVLSN() - Method in class com.sleepycat.je.rep.stream.InputWireRecord
 
getVLSN() - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
 
getVLSN() - Method in class com.sleepycat.je.rep.stream.Protocol.VLSNMessage
 
getVLSN() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
getVLSN() - Method in class com.sleepycat.je.rep.util.ldiff.Record
 
getVLSN(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
 
getVLSN(int, boolean) - Method in class com.sleepycat.je.tree.BIN
Returns the VLSN.
getVLSNCache() - Method in class com.sleepycat.je.tree.BIN
For unit testing.
getVLSNFreezeLatch() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getVLSNIndex() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
getVLSNIndex() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
getVLSNProxy() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
getVLSNProxy() - Method in class com.sleepycat.je.log.INFileReader
 
getVLSNProxy() - Method in class com.sleepycat.je.rep.impl.RepImpl
Used by environment recovery to get a tracker to collect VLSN-LSN mappings that are within the recovery part of the log.
getVLSNSequence() - Method in class com.sleepycat.je.tree.LN
Called by CursorImpl to get the record version.
getVLSNSequence() - Method in class com.sleepycat.je.tree.VersionedLN
 
getWaitersListClone() - Method in interface com.sleepycat.je.txn.Lock
Get a list of waiters for debugging and error messages.
getWaitersListClone() - Method in class com.sleepycat.je.txn.LockImpl
Get a list of waiters for debugging and error messages.
getWaitersListClone() - Method in class com.sleepycat.je.txn.ThinLockImpl
 
getWaiterTxnIds() - Method in exception com.sleepycat.je.LockConflictException
Returns an array of longs containing transaction ids of waiters at the the time of the timeout.
getWaitIfBusy() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Return whether or not the operation will wait for the remote service to become available if the remote service is busy.
getWaitingFor() - Method in class com.sleepycat.je.txn.Locker
 
getWakeupPeriod(DbConfigManager) - Static method in class com.sleepycat.je.recovery.Checkpointer
Figure out the wakeup period.
getWinner() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferOK
 
getWireRecord(VLSN, int) - Method in interface com.sleepycat.je.rep.stream.FeederSource
 
getWireRecord(VLSN, int) - Method in class com.sleepycat.je.rep.stream.MasterFeederSource
 
getWireRecord() - Method in class com.sleepycat.je.rep.stream.Protocol.Entry
 
getWireSize() - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
Support for reading and writing FeedRecords to network.
getWireSize() - Method in class com.sleepycat.je.rep.stream.Protocol.Entry
 
getWithCleaningDistance(long, FileManager, long, long) - Static method in class com.sleepycat.je.utilint.DbLsn
Return the logsize in bytes between these two LSNs.
getWrap() - Method in class com.sleepycat.je.SequenceConfig
Returns true if the sequence will wrap around when it is incremented (decremented) past the specified maximum (minimum) value.
getWrapperFormat() - Method in class com.sleepycat.persist.impl.Format
For primitive types only, returns their associated wrapper type.
getWrapperFormat() - Method in class com.sleepycat.persist.impl.SimpleFormat
 
getWritableLocker(Environment, Transaction, boolean, boolean, boolean) - Static method in class com.sleepycat.je.txn.LockerFactory
Get a locker for a write operation, checking whether the db and environment is transactional or not.
getWritableLocker(Environment, Transaction, boolean, boolean, boolean, TransactionConfig) - Static method in class com.sleepycat.je.txn.LockerFactory
Get a locker for a write operation.
getWriteBuffer(int, boolean) - Method in class com.sleepycat.je.log.LogBufferPool
Get a log buffer for writing sizeNeeded bytes.
getWriteCursor(CursorConfig) - Static method in class com.sleepycat.compat.DbCompat
 
getWriteIntLength(int) - Static method in class com.sleepycat.util.PackedInteger
Returns the number of bytes that would be written by PackedInteger.writeInt(byte[], int, int).
getWriteLockIds() - Method in class com.sleepycat.je.txn.Txn
 
getWriteLockInfo(long) - Method in class com.sleepycat.je.txn.BasicLocker
 
getWriteLockInfo(long) - Method in class com.sleepycat.je.txn.Locker
 
getWriteLockInfo() - Method in class com.sleepycat.je.txn.LockResult
Returns the write lock info for a transactional write lock that was granted.
getWriteLockInfo(long) - Method in class com.sleepycat.je.txn.ReadCommittedLocker
 
getWriteLockInfo(long) - Method in class com.sleepycat.je.txn.Txn
 
getWriteLockMode() - Method in class com.sleepycat.collections.CurrentTransaction
Return the LockMode.RMW or null, depending on whether locking is enabled.
getWriteLongLength(long) - Static method in class com.sleepycat.util.PackedInteger
Returns the number of bytes that would be written by PackedInteger.writeLong(byte[], int, long).
getWriteNoSync() - Method in class com.sleepycat.je.TransactionConfig
Deprecated.
getWriteOwnerLocker(long) - Method in class com.sleepycat.je.txn.BasicLocker
Get the txn that owns the lock on this node.
getWriteOwnerLocker(Long) - Method in class com.sleepycat.je.txn.DummyLockManager
 
getWriteOwnerLocker() - Method in interface com.sleepycat.je.txn.Lock
Return the locker that has a write ownership on this lock.
getWriteOwnerLocker() - Method in class com.sleepycat.je.txn.LockImpl
Return the locker that has a write ownership on this lock.
getWriteOwnerLocker(Long) - Method in class com.sleepycat.je.txn.LockManager
 
getWriteOwnerLocker(Long) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
getWriteOwnerLocker() - Method in class com.sleepycat.je.txn.ThinLockImpl
 
getWriteOwnerLockerInternal(Long, int) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of getWriteOwnerLocker.
getWriteSortedIntLength(int) - Static method in class com.sleepycat.util.PackedInteger
Returns the number of bytes that would be written by PackedInteger.writeSortedInt(byte[], int, int).
getWriteSortedLongLength(long) - Static method in class com.sleepycat.util.PackedInteger
Returns the number of bytes that would be written by PackedInteger.writeSortedLong(byte[], int, long).
getXAResource() - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
getXATransaction(Xid) - Method in class com.sleepycat.je.XAEnvironment
Used to get the Transaction object given an XA Xid.
getXi(byte[]) - Static method in class com.sleepycat.je.rep.util.ldiff.LDiffUtil
Each byte (Xi in the tech report) is replaced by a 32 bit Adler checksum of the bytes representing the concatenation of the key/value pair.
getXid() - Method in class com.sleepycat.je.txn.TxnPrepare
 
getXidSize(Xid) - Static method in class com.sleepycat.je.log.LogUtils
The byte[]'s in Xid's are known to be 255 or less in length.
getZeroTerminatedByteLength(byte[], int) - Static method in class com.sleepycat.util.UtfOps
Returns the byte length of a null terminated UTF string, not including the terminator.
GhostBucket - Class in com.sleepycat.je.rep.vlsn
A ghost bucket stands in as a placeholder for a set of vlsns that are unknown.
GhostBucket(VLSN, long, long) - Constructor for class com.sleepycat.je.rep.vlsn.GhostBucket
 
giveUp(String) - Method in class com.sleepycat.je.rep.impl.node.MasterTransfer
Informs this Master Transfer operation that the named Feeder is shutting down, because its replica connection has been lost.
GlobalCBVLSN - Class in com.sleepycat.je.rep.impl.node
Represents this node's view of the global CBVLSN.
GlobalCBVLSN(RepNode) - Constructor for class com.sleepycat.je.rep.impl.node.GlobalCBVLSN
 
globalCBVLSN - Variable in class com.sleepycat.je.rep.impl.node.RepNode
 
GOTO - Static variable in interface com.sleepycat.asm.Opcodes
 
greater - Variable in class com.sleepycat.je.tree.CountEstimator.KeyRatios
 
group - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupResponse
 
GROUP_CHANGE_REQ - Variable in class com.sleepycat.je.rep.monitor.Protocol
 
GROUP_DESC - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.incomp.INCompStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.latch.LatchStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackupStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.impl.node.FeederManagerStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.impl.node.ReplicaStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.impl.RepImplStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.stream.FeederTxnStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.utilint.SizeAwaitMapStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.rep.vlsn.VLSNIndexStatDefinition
 
GROUP_DESC - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
GROUP_KEY - Static variable in class com.sleepycat.je.rep.impl.RepGroupDB
 
GROUP_NAME - Static variable in class com.sleepycat.je.cleaner.CleanerStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.dbi.BTreeStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.incomp.INCompStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.latch.LatchStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.recovery.CheckpointStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackupStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.impl.node.FeederManagerStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.impl.node.ReplicaStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.impl.RepImplStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.impl.RepParams
Names the Replication group.
GROUP_NAME - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The name for the replication group.
GROUP_NAME - Static variable in class com.sleepycat.je.rep.stream.FeederTxnStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.utilint.SizeAwaitMapStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.rep.vlsn.VLSNIndexStatDefinition
 
GROUP_NAME - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
GROUP_REQ - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
GROUP_RESP - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
GroupChangeEvent - Class in com.sleepycat.je.rep.monitor
The event generated when the group composition changes.
GroupChangeEvent(ReplicationGroup, String, GroupChangeEvent.GroupChangeType) - Constructor for class com.sleepycat.je.rep.monitor.GroupChangeEvent
 
GroupChangeEvent.GroupChangeType - Enum in com.sleepycat.je.rep.monitor
The kind of GroupChangeEvent.
groupKeyEntry - Static variable in class com.sleepycat.je.rep.impl.RepGroupDB
 
GroupService - Class in com.sleepycat.je.rep.impl
 
GroupService(ServiceDispatcher, RepNode) - Constructor for class com.sleepycat.je.rep.impl.GroupService
 
GroupService.GroupServiceRunnable - Class in com.sleepycat.je.rep.impl
 
GroupService.GroupServiceRunnable(SocketChannel, RepGroupProtocol) - Constructor for class com.sleepycat.je.rep.impl.GroupService.GroupServiceRunnable
 
GroupShutdownException - Exception in com.sleepycat.je.rep
Thrown when an attempt is made to access an environment that was shutdown by the Master as a result of a call to ReplicatedEnvironment.shutdownGroup(long, TimeUnit).
GroupShutdownException(Logger, RepNode, long) - Constructor for exception com.sleepycat.je.rep.GroupShutdownException
For internal use only.
groupSync() - Method in class com.sleepycat.je.log.FileManager
Flush a file using the group sync mechanism, trying to amortize off other syncs.

H

H_GETFIELD - Static variable in interface com.sleepycat.asm.Opcodes
 
H_GETSTATIC - Static variable in interface com.sleepycat.asm.Opcodes
 
H_INVOKEINTERFACE - Static variable in interface com.sleepycat.asm.Opcodes
 
H_INVOKESPECIAL - Static variable in interface com.sleepycat.asm.Opcodes
 
H_INVOKESTATIC - Static variable in interface com.sleepycat.asm.Opcodes
 
H_INVOKEVIRTUAL - Static variable in interface com.sleepycat.asm.Opcodes
 
H_NEWINVOKESPECIAL - Static variable in interface com.sleepycat.asm.Opcodes
 
H_PUTFIELD - Static variable in interface com.sleepycat.asm.Opcodes
 
H_PUTSTATIC - Static variable in interface com.sleepycat.asm.Opcodes
 
HALT_ON_COMMIT_AFTER_CHECKSUMEXCEPTION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
HALT_ON_COMMIT_AFTER_CHECKSUMEXCEPTION - Static variable in class com.sleepycat.je.EnvironmentConfig
By default, if a checksum exception is found at the end of the log during Environment startup, JE will assume the checksum is due to previously interrupted I/O and will quietly truncate the log and restart.
HANDLE - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_MethodHandle constant pool items.
Handle - Class in com.sleepycat.asm
A reference to a field or a method.
Handle(int, String, String, String) - Constructor for class com.sleepycat.asm.Handle
Constructs a new field or method handle.
HANDLE_BASE - Static variable in class com.sleepycat.asm.ClassWriter
The base value for all CONSTANT_MethodHandle constant pool items.
handleClosed(boolean, boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Called after a handle onto this DB is closed.
handleException(Exception, boolean) - Method in class com.sleepycat.collections.StoredContainer
 
handleException(Exception, int, int) - Method in class com.sleepycat.collections.TransactionRunner
Handles exceptions that occur during a transaction, and may implement transaction retry policy.
HandleLocker - Class in com.sleepycat.je.txn
Extends BasicLocker to share locks with another Locker that is being used to open a database.
HandleLocker(EnvironmentImpl, Locker) - Constructor for class com.sleepycat.je.txn.HandleLocker
Creates a HandleLocker.
Handler - Class in com.sleepycat.asm
Information about an exception handler block.
Handler() - Constructor for class com.sleepycat.asm.Handler
 
handler - Variable in class com.sleepycat.asm.Handler
Beginning of the exception handler's code.
HARD_RECOVERY - Static variable in class com.sleepycat.je.rep.impl.RepImplStatDefinition
 
HARD_RECOVERY_INFO - Static variable in class com.sleepycat.je.rep.impl.RepImplStatDefinition
 
hasBound() - Method in class com.sleepycat.util.keyrange.KeyRange
Returns whether this range has a begin or end bound.
HASH_METHOD - Static variable in class com.sleepycat.compat.DbCompat
 
hashCode() - Method in class com.sleepycat.asm.Handle
 
hashCode - Variable in class com.sleepycat.asm.Item
The hash code value of this constant pool item.
hashCode() - Method in class com.sleepycat.asm.Type
Returns a hash code value for this type.
hashCode() - Method in class com.sleepycat.collections.MapEntryParameter
Computes a hash code as specified by Map.Entry.hashCode().
hashCode() - Method in class com.sleepycat.collections.StoredCollection
 
hashCode() - Method in class com.sleepycat.collections.StoredList
 
hashCode() - Method in class com.sleepycat.collections.StoredMap
 
hashCode() - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
hashCode() - Method in class com.sleepycat.je.cleaner.UtilizationCalculator.AverageSize
 
hashCode() - Method in class com.sleepycat.je.CommitToken
 
hashCode() - Method in class com.sleepycat.je.DatabaseEntry
Returns a hash code based on the data value.
hashCode() - Method in class com.sleepycat.je.dbi.CursorImpl
 
hashCode() - Method in class com.sleepycat.je.dbi.DatabaseId
 
hashCode() - Method in class com.sleepycat.je.Durability
 
hashCode() - Method in class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
hashCode() - Method in class com.sleepycat.je.jca.ra.JERequestInfo
 
hashCode() - Method in class com.sleepycat.je.JEVersion
 
hashCode() - Method in class com.sleepycat.je.log.LogEntryType
This is used as a hash key.
hashCode() - Method in class com.sleepycat.je.log.LogUtils.XidImpl
 
hashCode() - Method in class com.sleepycat.je.log.Trace
Just in case it's ever used as a hash key.
hashCode() - Method in class com.sleepycat.je.recovery.Checkpointer.CheckpointReference
 
hashCode() - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
hashCode() - Method in class com.sleepycat.je.rep.CommitPointConsistencyPolicy
 
hashCode() - Method in class com.sleepycat.je.rep.elections.MasterValue
 
hashCode() - Method in class com.sleepycat.je.rep.elections.Protocol.Accept
 
hashCode() - Method in class com.sleepycat.je.rep.elections.Protocol.Accepted
 
hashCode() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
hashCode() - Method in class com.sleepycat.je.rep.elections.Protocol.Propose
 
hashCode() - Method in class com.sleepycat.je.rep.elections.Protocol.Reject
 
hashCode() - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
 
hashCode() - Method in class com.sleepycat.je.rep.impl.PointConsistencyPolicy
 
hashCode() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl.BarrierState
 
hashCode() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
 
hashCode() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
hashCode() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Fail
 
hashCode() - Method in class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
hashCode() - Method in class com.sleepycat.je.rep.impl.TextProtocol.RequestMessage
 
hashCode() - Method in class com.sleepycat.je.rep.impl.TextProtocol.ResponseMessage
 
hashCode() - Method in class com.sleepycat.je.rep.impl.TextProtocol.StringFormatable
 
hashCode() - Method in class com.sleepycat.je.rep.NoConsistencyRequiredPolicy
 
hashCode() - Method in class com.sleepycat.je.rep.TimeConsistencyPolicy
 
hashCode() - Method in class com.sleepycat.je.rep.util.ldiff.Record
 
hashCode() - Method in class com.sleepycat.je.Transaction
For internal use.
hashCode() - Method in class com.sleepycat.je.tree.BINReference
 
hashCode() - Method in class com.sleepycat.je.tree.IN
We would like as even a hash distribution as possible so that the Evictor's LRU is as accurate as possible.
hashCode() - Method in class com.sleepycat.je.tree.Key
Support HashSet of Key in BINReference.
hashCode() - Method in class com.sleepycat.je.txn.TxnChain.CompareSlot
 
hashCode() - Method in class com.sleepycat.je.utilint.StatDefinition
 
hashCode() - Method in class com.sleepycat.je.utilint.VLSN
 
hashCode() - Method in class com.sleepycat.persist.evolve.Converter
 
hashCode() - Method in class com.sleepycat.persist.evolve.EntityConverter
 
hashCode() - Method in class com.sleepycat.persist.evolve.Mutation
 
hashCode() - Method in class com.sleepycat.persist.evolve.Mutations
 
hashCode() - Method in class com.sleepycat.persist.evolve.Renamer
 
hashCode() - Method in class com.sleepycat.persist.impl.FieldInfo
 
hashCode() - Method in class com.sleepycat.persist.model.ClassMetadata
 
hashCode(Object) - Static method in class com.sleepycat.persist.model.ClassMetadata
 
hashCode() - Method in class com.sleepycat.persist.model.EntityMetadata
 
hashCode() - Method in class com.sleepycat.persist.model.FieldMetadata
 
hashCode() - Method in class com.sleepycat.persist.model.PrimaryKeyMetadata
 
hashCode() - Method in class com.sleepycat.persist.model.SecondaryKeyMetadata
 
hashCode() - Method in class com.sleepycat.persist.raw.RawObject
 
HASHMAP_ENTRY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
HASHMAP_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
HASHSET_ENTRY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
HASHSET_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
hasNext() - Method in class com.sleepycat.collections.BlockIterator
 
hasNext() - Method in class com.sleepycat.collections.StoredIterator
Returns true if this iterator has more elements when traversing in the forward direction.
hasNext(SortedMap<Long, FileSummary>) - Method in class com.sleepycat.je.cleaner.FilesToMigrate
Returns whether there are more files to be migrated.
hasNext() - Method in class com.sleepycat.je.cleaner.PackedOffsets.Iterator
 
hasNext() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.LogChangeIterator
 
hasNext() - Method in class com.sleepycat.je.utilint.TinyHashSet.SingleElementIterator
 
hasNext() - Method in class com.sleepycat.persist.BasicIterator
 
hasNullId() - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
 
hasOpenHandles() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns whether one or more handles are open.
hasPinnedChildren() - Method in class com.sleepycat.je.tree.BIN
Note that the IN may or may not be latched when this method is called.
hasPinnedChildren() - Method in class com.sleepycat.je.tree.IN
Returns whether any resident children are not LNs (are INs).
hasPrevious() - Method in class com.sleepycat.collections.BlockIterator
 
hasPrevious() - Method in class com.sleepycat.collections.StoredIterator
Returns true if this iterator has more elements when traversing in the reverse direction.
hasQueuedWrites() - Method in class com.sleepycat.je.log.FileManager
Returns whether anything is in the write queue.
hasQueuedWrites() - Method in class com.sleepycat.je.log.FileManager.LogEndFileDescriptor
Returns whether anything is in the write queue.
hasRecNumAccess() - Method in class com.sleepycat.collections.DataCursor
Returns whether record number access is allowed.
hasRemaining() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
hasResidentChildren() - Method in class com.sleepycat.je.tree.IN
Returns whether any child is non-null.
hasRollbackEnd() - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
hasRoom(int) - Method in class com.sleepycat.je.log.LogBuffer
Check capacity of buffer.
hasStringKey(byte[]) - Static method in class com.sleepycat.je.tree.FileSummaryLN
Returns true if the given key for this LN is a String file number key.
hasTriggers() - Method in class com.sleepycat.je.Database
Returns whether any triggers are currently associated with this primary.
hasUnknownUUID() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
 
hasUserTriggers() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
hasValues() - Method in class com.sleepycat.collections.StoredCollection
 
hasValues() - Method in class com.sleepycat.collections.StoredEntrySet
 
hasValues() - Method in class com.sleepycat.collections.StoredKeySet
 
hasValues() - Method in class com.sleepycat.collections.StoredList
 
hasValues() - Method in class com.sleepycat.collections.StoredValueSet
 
header - Variable in class com.sleepycat.asm.ClassReader
Start index of the class header information (access, name...) in b.
header - Variable in class com.sleepycat.je.log.LogItem
 
header - Variable in class com.sleepycat.je.rep.stream.WireRecord
 
header - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
headerBytes - Variable in class com.sleepycat.je.log.StatsFileReader.EntryInfo
 
headMap(K) - Method in class com.sleepycat.collections.StoredSortedMap
Returns a view of the portion of this sorted set whose keys are strictly less than toKey.
headMap(K, boolean) - Method in class com.sleepycat.collections.StoredSortedMap
Returns a view of the portion of this sorted map whose elements are strictly less than toKey, optionally including toKey.
headSet(Map.Entry<K, V>) - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns a view of the portion of this sorted set whose elements are strictly less than toMapEntry.
headSet(Map.Entry<K, V>, boolean) - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns a view of the portion of this sorted set whose elements are strictly less than toMapEntry, optionally including toMapEntry.
headSet(K) - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns a view of the portion of this sorted set whose elements are strictly less than toKey.
headSet(K, boolean) - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns a view of the portion of this sorted set whose elements are strictly less than toKey, optionally including toKey.
headSet(E) - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns a view of the portion of this sorted set whose elements are strictly less than toValue.
headSet(E, boolean) - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns a view of the portion of this sorted set whose elements are strictly less than toValue, optionally including toValue.
HEARTBEAT - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
HEARTBEAT_INTERVAL - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
HEARTBEAT_RESPONSE - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
HELPER_HOSTS - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
HELPER_HOSTS - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The string identifying one or more helper host and port pairs in this format:
helpers - Variable in class com.sleepycat.je.rep.utilint.DbNullNode
 
HEX - Static variable in class com.sleepycat.je.tree.Key.DumpType
 
hexDeserializeNode(String) - Static method in class com.sleepycat.je.rep.impl.RepGroupImpl
Deserializes the object serialized by RepGroupImpl.serializeHex()
HexFormatter - Class in com.sleepycat.je.utilint
 
HexFormatter() - Constructor for class com.sleepycat.je.utilint.HexFormatter
 
hookSetup() - Method in interface com.sleepycat.je.utilint.TestHook
 
hookSetup() - Method in class com.sleepycat.je.utilint.TestHookAdapter
 
HostPortPair - Class in com.sleepycat.je.rep.utilint
Encapsulates the functionality around dealing with HostPort string pairs having the format: host[:port]
HostPortPair() - Constructor for class com.sleepycat.je.rep.utilint.HostPortPair
 

I

I2B - Static variable in interface com.sleepycat.asm.Opcodes
 
I2C - Static variable in interface com.sleepycat.asm.Opcodes
 
I2D - Static variable in interface com.sleepycat.asm.Opcodes
 
I2F - Static variable in interface com.sleepycat.asm.Opcodes
 
I2L - Static variable in interface com.sleepycat.asm.Opcodes
 
I2S - Static variable in interface com.sleepycat.asm.Opcodes
 
IADD - Static variable in interface com.sleepycat.asm.Opcodes
 
IALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
IAND - Static variable in interface com.sleepycat.asm.Opcodes
 
IASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
ICONST_0 - Static variable in interface com.sleepycat.asm.Opcodes
 
ICONST_1 - Static variable in interface com.sleepycat.asm.Opcodes
 
ICONST_2 - Static variable in interface com.sleepycat.asm.Opcodes
 
ICONST_3 - Static variable in interface com.sleepycat.asm.Opcodes
 
ICONST_4 - Static variable in interface com.sleepycat.asm.Opcodes
 
ICONST_5 - Static variable in interface com.sleepycat.asm.Opcodes
 
ICONST_M1 - Static variable in interface com.sleepycat.asm.Opcodes
 
id - Variable in class com.sleepycat.je.rep.stream.MatchpointSearchResults.PassedTxnInfo
 
id - Variable in class com.sleepycat.je.txn.Locker
 
id - Variable in class com.sleepycat.je.txn.TxnEnd
 
ID_BIGDEC - Static variable in class com.sleepycat.persist.impl.Format
BigDecimal
ID_BIGINT - Static variable in class com.sleepycat.persist.impl.Format
BigInteger
ID_BOOL - Static variable in class com.sleepycat.persist.impl.Format
Boolean
ID_BOOL_W - Static variable in class com.sleepycat.persist.impl.Format
 
ID_BYTE - Static variable in class com.sleepycat.persist.impl.Format
Byte
ID_BYTE_W - Static variable in class com.sleepycat.persist.impl.Format
 
ID_CHAR - Static variable in class com.sleepycat.persist.impl.Format
Character
ID_CHAR_W - Static variable in class com.sleepycat.persist.impl.Format
 
ID_DATE - Static variable in class com.sleepycat.persist.impl.Format
Date
ID_DB_ID - Static variable in class com.sleepycat.je.dbi.DbTree
 
ID_DOUBLE - Static variable in class com.sleepycat.persist.impl.Format
Double
ID_DOUBLE_W - Static variable in class com.sleepycat.persist.impl.Format
 
ID_FLOAT - Static variable in class com.sleepycat.persist.impl.Format
Float
ID_FLOAT_W - Static variable in class com.sleepycat.persist.impl.Format
 
ID_INT - Static variable in class com.sleepycat.persist.impl.Format
Integer
ID_INT_W - Static variable in class com.sleepycat.persist.impl.Format
 
ID_LONG - Static variable in class com.sleepycat.persist.impl.Format
Long
ID_LONG_W - Static variable in class com.sleepycat.persist.impl.Format
 
ID_NULL - Static variable in class com.sleepycat.persist.impl.Format
Null reference.
ID_NUMBER - Static variable in class com.sleepycat.persist.impl.Format
Number
ID_OBJECT - Static variable in class com.sleepycat.persist.impl.Format
Object
ID_PREDEFINED - Static variable in class com.sleepycat.persist.impl.Format
Last predefined ID, after which dynamic IDs are assigned.
ID_SHORT - Static variable in class com.sleepycat.persist.impl.Format
Short
ID_SHORT_W - Static variable in class com.sleepycat.persist.impl.Format
 
ID_SIMPLE_MAX - Static variable in class com.sleepycat.persist.impl.Format
Last simple type.
ID_SIMPLE_MIN - Static variable in class com.sleepycat.persist.impl.Format
First simple type.
ID_STRING - Static variable in class com.sleepycat.persist.impl.Format
String
IdentityHashMap<K,V> - Class in com.sleepycat.je.utilint
The Harmony IdentityHashMap implementation has a bug in entrySet() where it returns a set of Map.Entry's which, when setValue() is called, do not actually mutate the underlying Map.
IdentityHashMap() - Constructor for class com.sleepycat.je.utilint.IdentityHashMap
 
IDIV - Static variable in interface com.sleepycat.asm.Opcodes
 
idKey - Variable in class com.sleepycat.je.tree.BINReference
 
idxs - Variable in class com.sleepycat.je.tree.INTargetRep.Sparse
 
IF_ACMPEQ - Static variable in interface com.sleepycat.asm.Opcodes
 
IF_ACMPNE - Static variable in interface com.sleepycat.asm.Opcodes
 
IF_ICMPEQ - Static variable in interface com.sleepycat.asm.Opcodes
 
IF_ICMPGE - Static variable in interface com.sleepycat.asm.Opcodes
 
IF_ICMPGT - Static variable in interface com.sleepycat.asm.Opcodes
 
IF_ICMPLE - Static variable in interface com.sleepycat.asm.Opcodes
 
IF_ICMPLT - Static variable in interface com.sleepycat.asm.Opcodes
 
IF_ICMPNE - Static variable in interface com.sleepycat.asm.Opcodes
 
IFEQ - Static variable in interface com.sleepycat.asm.Opcodes
 
IFGE - Static variable in interface com.sleepycat.asm.Opcodes
 
IFGT - Static variable in interface com.sleepycat.asm.Opcodes
 
IFLE - Static variable in interface com.sleepycat.asm.Opcodes
 
IFLT - Static variable in interface com.sleepycat.asm.Opcodes
 
IFNE - Static variable in interface com.sleepycat.asm.Opcodes
 
IFNONNULL - Static variable in interface com.sleepycat.asm.Opcodes
 
IFNULL - Static variable in interface com.sleepycat.asm.Opcodes
 
ignoreException(Exception) - Method in interface com.sleepycat.je.dbi.SortedLSNTreeWalker.ExceptionPredicate
 
ignoreMethods - Static variable in class com.sleepycat.util.ConfigBeanInfoBase
 
IINC - Static variable in interface com.sleepycat.asm.Opcodes
 
IINC_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the IINC instruction.
ILLEGAL - Static variable in class com.sleepycat.je.txn.LockUpgrade
 
ILOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
IMETH - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_InterfaceMethodref constant pool items.
IMPLVAR_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of instructions with an implicit local variable index argument.
ImportConfig - Class in com.sleepycat.je.sync
Optional import parameters that may be passed to a sync operation.
ImportConfig() - Constructor for class com.sleepycat.je.sync.ImportConfig
 
IMUL - Static variable in interface com.sleepycat.asm.Opcodes
 
in - Variable in class com.sleepycat.je.dbi.SortedLSNTreeWalker.INEntry
 
IN - Class in com.sleepycat.je.tree
An IN represents an Internal Node in the JE tree.
IN() - Constructor for class com.sleepycat.je.tree.IN
Create an empty IN, with no node ID, to be filled in from the log.
IN(DatabaseImpl, byte[], int, int) - Constructor for class com.sleepycat.je.tree.IN
Create a new IN.
IN(SizeofMarker) - Constructor for class com.sleepycat.je.tree.IN
For Sizeof, set all array fields to null, since they are not part of the fixed overhead.
IN_FIXED_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
INArrayRep<ARRAY_BASE_TYPE,REP_ENUM_TYPE,ELEMENT_TYPE> - Class in com.sleepycat.je.tree
The base class for the various array representations used by fields associated with an IN node.
INArrayRep() - Constructor for class com.sleepycat.je.tree.INArrayRep
 
inBounds(byte[]) - Method in interface com.sleepycat.je.dbi.RangeConstraint
 
incBackupCount() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
incBINEvictStats(Evictor.EvictionSource) - Method in class com.sleepycat.je.evictor.Evictor
 
incBINFetchStats(boolean) - Method in class com.sleepycat.je.evictor.Evictor
 
incBINsLoaded() - Method in class com.sleepycat.je.PreloadStats
 
incDBINsLoaded() - Method in class com.sleepycat.je.PreloadStats
 
incDINsLoaded() - Method in class com.sleepycat.je.PreloadStats
 
incDupCountLNsLoaded() - Method in class com.sleepycat.je.PreloadStats
 
incEvictStats(Evictor.EvictionSource) - Method in class com.sleepycat.je.tree.BIN
 
incEvictStats(Evictor.EvictionSource) - Method in class com.sleepycat.je.tree.IN
We categorize eviction stats by the type of IN, so IN subclasses update different stats.
incFetchStats(EnvironmentImpl, boolean) - Method in class com.sleepycat.je.tree.BIN
 
incFetchStats(EnvironmentImpl, boolean) - Method in class com.sleepycat.je.tree.IN
 
incFetchStats(EnvironmentImpl, boolean) - Method in class com.sleepycat.je.tree.LN
 
incFetchStats(EnvironmentImpl, boolean) - Method in class com.sleepycat.je.tree.Node
We categorize fetch stats by the type of node, so node subclasses update different stats.
incINEvictStats(Evictor.EvictionSource) - Method in class com.sleepycat.je.evictor.Evictor
 
incINFetchStats(boolean) - Method in class com.sleepycat.je.evictor.Evictor
 
incINsLoaded() - Method in class com.sleepycat.je.PreloadStats
 
incInternalMemoryUsage(long) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
incLNFetchStats(boolean) - Method in class com.sleepycat.je.evictor.Evictor
Update the appropriate fetch stat, based on node type.
incLNsLoaded() - Method in class com.sleepycat.je.PreloadStats
 
include(RepNodeImpl) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl.Predicate
 
incMemoryExceeded() - Method in class com.sleepycat.je.PreloadStats
 
incNumAux() - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
Keep track of auxiliary log entries processed during this pass.
incNumDeleted() - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
 
incNumProcessed() - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
 
incNumRead() - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
 
INCOMP_CURSORS_BINS - Static variable in class com.sleepycat.je.incomp.INCompStatDefinition
 
INCOMP_DBCLOSED_BINS - Static variable in class com.sleepycat.je.incomp.INCompStatDefinition
 
INCOMP_NAME - Static variable in class com.sleepycat.je.Environment
 
INCOMP_NON_EMPTY_BINS - Static variable in class com.sleepycat.je.incomp.INCompStatDefinition
 
INCOMP_PROCESSED_BINS - Static variable in class com.sleepycat.je.incomp.INCompStatDefinition
 
INCOMP_QUEUE_SIZE - Static variable in class com.sleepycat.je.incomp.INCompStatDefinition
 
INCOMP_SPLIT_BINS - Static variable in class com.sleepycat.je.incomp.INCompStatDefinition
 
INCOMPATIBLE_VERSION - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
IncompatibleClassException - Exception in com.sleepycat.persist.evolve
A class has been changed incompatibly and no mutation has been configured to handle the change or a new class version number has not been assigned.
IncompatibleClassException(String) - Constructor for exception com.sleepycat.persist.evolve.IncompatibleClassException
 
INCompressor - Class in com.sleepycat.je.incomp
JE compression consists of removing deleted entries from BINs, and pruning empty IN/BINs from the tree which is also called a reverse split.
INCompressor(EnvironmentImpl, long, String) - Constructor for class com.sleepycat.je.incomp.INCompressor
 
INCompStatDefinition - Class in com.sleepycat.je.incomp
Per-stat Metadata for JE INCompressor statistics.
INCompStatDefinition() - Constructor for class com.sleepycat.je.incomp.INCompStatDefinition
 
INContainingEntry - Interface in com.sleepycat.je.log.entry
An INContainingEntry is a log entry that contains internal nodes.
incOpenCount() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
incRelatchesRequired() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
increment(FileReader, byte) - Method in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
increment() - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
increment() - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
increment() - Method in class com.sleepycat.je.utilint.IntStat
 
increment() - Method in class com.sleepycat.je.utilint.LongStat
 
incrementBufferPosition(int) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
incrementChangeVersion() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Increments the object change version.
incrementDeletedLNCount() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
incrementDeletedLNCount() - Method in interface com.sleepycat.je.tree.TreeWalkerStatsAccumulator
 
incrementFreezeCounter() - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNTracker
 
incrementLNCount() - Method in class com.sleepycat.je.dbi.CursorImpl
 
incrementLNCount() - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
incrementLNCount() - Method in interface com.sleepycat.je.tree.TreeWalkerStatsAccumulator
 
incrementUseCount() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Increments the use count of this DB to prevent it from being evicted.
incStats(StatGroup) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Accumulates statistics from a terminating feeder.
incThreadLocalReferenceCount() - Static method in class com.sleepycat.je.dbi.EnvironmentImpl
 
INDeleteInfo - Class in com.sleepycat.je.tree.dupConvert
INDeleteInfo encapsulates the information logged about the removal of a child from an IN during IN compression.
INDeleteInfo() - Constructor for class com.sleepycat.je.tree.dupConvert.INDeleteInfo
Used by logging system only.
indent(int) - Static method in class com.sleepycat.je.tree.TreeUtils
For tree dumper.
index - Variable in class com.sleepycat.asm.ClassWriter
Index of the next item to be added in the constant pool.
index - Variable in class com.sleepycat.asm.Item
Index of this item in the constant pool.
index - Variable in class com.sleepycat.je.dbi.SortedLSNTreeWalker.INEntry
 
index - Variable in class com.sleepycat.je.tree.SearchResult
 
index - Variable in class com.sleepycat.je.tree.TrackingInfo
 
index - Variable in class com.sleepycat.je.tree.TreeLocation
 
indexKeyBinding - Variable in class com.sleepycat.bind.serial.SerialSerialKeyCreator
 
IndexNotAvailableException - Exception in com.sleepycat.persist
Thrown by the getPrimaryIndex, getSecondaryIndex and getSubclassIndex when an index has not yet been created.
IndexNotAvailableException(String) - Constructor for exception com.sleepycat.persist.IndexNotAvailableException
For internal use only.
indexOf(Object) - Method in class com.sleepycat.collections.StoredList
Returns the index in this list of the first occurrence of the specified element, or -1 if this list does not contain this element.
INDupDeleteInfo - Class in com.sleepycat.je.tree.dupConvert
INDupDeleteInfo encapsulates the information logged about the removal of a child from a duplicate IN during IN compression.
INDupDeleteInfo() - Constructor for class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
Used by logging system only.
INDY - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_InvokeDynamic constant pool items.
INDYMETH_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the INVOKEDYNAMIC instruction.
INEG - Static variable in interface com.sleepycat.asm.Opcodes
 
INENTRY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
INFileReader - Class in com.sleepycat.je.log
INFileReader supports recovery by scanning log files during the IN rebuild pass.
INFileReader(EnvironmentImpl, int, long, long, boolean, boolean, long, long, RecoveryUtilizationTracker) - Constructor for class com.sleepycat.je.log.INFileReader
Create this reader to start at a given LSN.
INFileReader(EnvironmentImpl, int, long, long, boolean, boolean, long, long, RecoveryUtilizationTracker, Set<DatabaseId>, AtomicBoolean) - Constructor for class com.sleepycat.je.log.INFileReader
Create with logVersion8UpgradeDbs and logVersion8UpgradeDeltas params.
info - Variable in class com.sleepycat.asm.Edge
Information about this control flow graph edge.
info - Variable in class com.sleepycat.asm.Label
Field used to associate user information to a label.
info(Logger, EnvironmentImpl, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
informLearners(Set<InetSocketAddress>, Proposer.WinningProposal, Protocol, ExecutorService, Logger, RepImpl, Formatter) - Static method in class com.sleepycat.je.rep.elections.Learner
A utility method used to broadcast the results of an election to Listeners.
init(EnvironmentImpl) - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
Starts memory budgeting.
INIT - Static variable in class com.sleepycat.je.dbi.DbEnvState
 
init(RandomAccessFile, int) - Method in class com.sleepycat.je.log.FileHandle
Initializes the handle after opening the file and reading the header.
init(String) - Method in class com.sleepycat.je.rep.impl.TextProtocol.StringFormatable
 
init(VLSN) - Method in interface com.sleepycat.je.rep.stream.FeederSource
 
init(VLSN) - Method in class com.sleepycat.je.rep.stream.MasterFeederSource
 
init(Environment) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier
Read the SyncDB to get the LogChangeSet information.
init(DatabaseImpl, byte[], int, int) - Method in class com.sleepycat.je.tree.IN
Initialize IN object.
initAfterClone() - Method in class com.sleepycat.collections.StoredContainer
Override this method to initialize view-dependent fields.
initAfterClone() - Method in class com.sleepycat.collections.StoredMap
Override this method to initialize view-dependent fields.
initAsMaster() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Initialize before this node begins working as a master.
initAtFileStart(long) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
initCacheMemoryUsage(long) - Method in class com.sleepycat.je.dbi.MemoryBudget
Initialize the starting environment memory state.
initCatalog(Catalog) - Method in class com.sleepycat.persist.impl.Format
Initialize transient catalog field after deserialization.
initChildIter() - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
initClassFields() - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
initClassFields() - Method in class com.sleepycat.je.jmx.JEMBean
 
initClassFields() - Method in class com.sleepycat.je.jmx.JEMonitor
 
initClassFields() - Method in class com.sleepycat.je.rep.jmx.RepJEDiagnostics
 
initClassFields() - Method in class com.sleepycat.je.rep.jmx.RepJEMonitor
 
initConfigManager(EnvironmentConfig, RepConfigProxy) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Create a config manager that holds the configuration properties that have been passed in.
initConfigManager(EnvironmentConfig, RepConfigProxy) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
initConfigParams(EnvironmentConfig, RepConfigProxy) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Init configuration params during environment creation.
initConfigParams(EnvironmentConfig, RepConfigProxy) - Method in class com.sleepycat.je.rep.impl.RepImpl
Called by the EnvironmentImpl constructor.
initData() - Method in class com.sleepycat.persist.DataValueAdapter
 
initData() - Method in class com.sleepycat.persist.EntityValueAdapter
 
initData() - Method in class com.sleepycat.persist.KeyValueAdapter
 
initData() - Method in class com.sleepycat.persist.PrimaryKeyValueAdapter
 
initData() - Method in interface com.sleepycat.persist.ValueAdapter
Creates a DatabaseEntry for the data or returns null if the data is not needed.
initEmpty() - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
initEntryLsn(int) - Method in class com.sleepycat.je.tree.IN
 
initExisting(Environment, Locker, DatabaseImpl, String, DatabaseConfig) - Method in class com.sleepycat.je.Database
Opens a database, called by Environment.
initExisting(Environment, Locker, DatabaseImpl, String, DatabaseConfig) - Method in class com.sleepycat.je.SecondaryDatabase
Open a database, called by Environment
initExistingEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.dbi.DbTree
Initialize the db tree during recovery, after instantiating the tree from the log.
initFormatter() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
initFormatter() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
initHandleLocker(EnvironmentImpl, Locker) - Method in class com.sleepycat.je.Database
Called during database open to set the handleLocker field.
initialize(ClassLoader) - Method in interface com.sleepycat.je.DatabaseComparator
Called to initialize a comparator object after it is instantiated or deserialized, and before it is used.
initialize(EntityModel) - Method in interface com.sleepycat.persist.evolve.Conversion
Initializes the conversion, allowing it to obtain raw type information from the entity model.
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.EnumFormat
 
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.FieldInfo
 
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.Format
Initializes an uninitialized format, initializing its related formats (superclass formats and array component formats) first.
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.NonPersistentFormat
 
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
initialize(ClassLoader) - Method in class com.sleepycat.persist.impl.PersistComparator
In BDB JE this method will be called after the comparator is deserialized, including during recovery.
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
initialize(Catalog, EntityModel, int) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
initializeConverter(Class[], String[]) - Method in interface com.sleepycat.je.sync.RecordConverter
Initializes the converter with the external field/column names and data types.
initializeConverter(Class[], String[]) - Method in class com.sleepycat.je.sync.RecordMapping
Called internally to initialize the converter.
initializeIfNeeded(Catalog, EntityModel) - Method in class com.sleepycat.persist.impl.Format
Called by the Catalog to initialize a format, and may also be called during initialize() for a related format to ensure that the related format is initialized.
initializeMessageOps(TextProtocol.MessageOp[]) - Method in class com.sleepycat.je.rep.impl.TextProtocol
The messages as defined by the subclass.
initializeMessageOps(BinaryProtocol.MessageOp[]) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
initializeProxy(Collection<E>) - Method in class com.sleepycat.persist.impl.CollectionProxy
 
initializeProxy(Map<K, V>) - Method in class com.sleepycat.persist.impl.MapProxy
 
initializeProxy(T) - Method in interface com.sleepycat.persist.model.PersistentProxy
Copies the state of a given proxied class instance to this proxy instance.
initializeReader(Catalog, EntityModel, int, Format) - Method in class com.sleepycat.persist.impl.ConverterReader
 
initializeReader(Catalog, EntityModel, int, Format) - Method in class com.sleepycat.persist.impl.Format
Called to initialize a separate Reader implementation.
initializeReader(Catalog, EntityModel, int, Format) - Method in interface com.sleepycat.persist.impl.Reader
 
initiateElection(RepGroupImpl, QuorumPolicy, int) - Method in class com.sleepycat.je.rep.elections.Elections
Initiates an election.
initiateElection(RepGroupImpl, QuorumPolicy) - Method in class com.sleepycat.je.rep.elections.Elections
The standard method for requesting and election, we normally want to run elections until we hear of an election result.
initiateSoftShutdown() - Method in class com.sleepycat.je.rep.elections.ElectionAgentThread
 
initiateSoftShutdown() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
initiateSoftShutdown() - Method in class com.sleepycat.je.rep.impl.networkRestore.LogFileFeeder
 
initiateSoftShutdown() - Method in class com.sleepycat.je.rep.impl.node.Replica.ReplayThread
 
initiateSoftShutdown() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Soft shutdown for the RepNode thread.
initiateSoftShutdown() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
 
initiateSoftShutdown() - Method in class com.sleepycat.je.utilint.StoppableThread
Threads that use shutdownThread() must define this method.
initInputFrame(ClassWriter, int, Type[], int) - Method in class com.sleepycat.asm.Frame
Initializes the input frame of the first basic block from the method descriptor.
initIntervals(long, long, long) - Method in class com.sleepycat.je.recovery.Checkpointer
Initializes the checkpoint intervals when no checkpoint is performed while opening the environment.
initKey() - Method in class com.sleepycat.persist.DataValueAdapter
 
initKey() - Method in class com.sleepycat.persist.EntityValueAdapter
 
initKey() - Method in class com.sleepycat.persist.KeyValueAdapter
 
initKey() - Method in class com.sleepycat.persist.PrimaryKeyValueAdapter
 
initKey() - Method in interface com.sleepycat.persist.ValueAdapter
Creates a DatabaseEntry for the key or returns null if the key is not needed.
initMemorySize() - Method in class com.sleepycat.je.tree.IN
Initialize the per-node memory count by computing its memory usage.
initNew(Environment, Locker, String, DatabaseConfig) - Method in class com.sleepycat.je.Database
Creates a database, called by Environment.
initNew(Environment, Locker, String, DatabaseConfig) - Method in class com.sleepycat.je.SecondaryDatabase
Create a database, called by Environment
initPKey() - Method in class com.sleepycat.persist.DataValueAdapter
 
initPKey() - Method in class com.sleepycat.persist.EntityValueAdapter
 
initPKey() - Method in class com.sleepycat.persist.KeyValueAdapter
 
initPKey() - Method in class com.sleepycat.persist.PrimaryKeyValueAdapter
 
initPKey() - Method in interface com.sleepycat.persist.ValueAdapter
Creates a DatabaseEntry for the primary key or returns null if the primary key is not needed.
initRealNodeId() - Method in class com.sleepycat.je.dbi.NodeSequence
Initialize the counters in these methods rather than a constructor so we can control the initialization more precisely.
initScan(VLSN) - Method in class com.sleepycat.je.rep.stream.FeederReader
Set up the FeederReader to start scanning from this VLSN.
initStartingPosition(long, Long) - Method in class com.sleepycat.je.log.FileReader
Helper for determining the starting position and opening up a file at the desired location.
initSyncProcessor(SyncProcessor) - Method in class com.sleepycat.je.sync.SyncDataSet
 
initTabs() - Method in class com.sleepycat.je.jmx.plugin.JEStatsPlugin
 
initTabs() - Method in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
initTabs() - Method in class com.sleepycat.je.rep.jmx.plugin.RepJEStatsPlugin
 
initVariables() - Method in class com.sleepycat.je.jmx.plugin.JEStats
 
initVariables() - Method in class com.sleepycat.je.jmx.plugin.Stats
 
initVariables() - Method in class com.sleepycat.je.rep.jmx.plugin.RepJEStats
 
injectFileForCleaning(Long) - Method in class com.sleepycat.je.cleaner.FileSelector
For unit testing.
INKeyRep - Class in com.sleepycat.je.tree
The abstract class that defines the various representation used to represent the keys associated with the IN node.
INKeyRep() - Constructor for class com.sleepycat.je.tree.INKeyRep
 
INKeyRep.Default - Class in com.sleepycat.je.tree
The default representation that's capable of storing keys of any size.
INKeyRep.Default(int) - Constructor for class com.sleepycat.je.tree.INKeyRep.Default
 
INKeyRep.Default(SizeofMarker) - Constructor for class com.sleepycat.je.tree.INKeyRep.Default
 
INKeyRep.MaxKeySize - Class in com.sleepycat.je.tree
The compact representation that can be used to represent keys LTE 16 bytes in length.
INKeyRep.MaxKeySize(int, short) - Constructor for class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
INKeyRep.MaxKeySize(SizeofMarker) - Constructor for class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
INKeyRep.Type - Enum in com.sleepycat.je.tree
 
INList - Class in com.sleepycat.je.dbi
The INList is a list of in-memory INs for a given environment.
INList(EnvironmentImpl) - Constructor for class com.sleepycat.je.dbi.INList
 
INList(INList, EnvironmentImpl) - Constructor for class com.sleepycat.je.dbi.INList
Used only by tree verifier when validating INList.
INLogContext - Class in com.sleepycat.je.tree
Extends LogContext to add fields used by IN.beforeLog and afterLog methods.
INLogContext() - Constructor for class com.sleepycat.je.tree.INLogContext
 
INLogEntry - Class in com.sleepycat.je.log.entry
INLogEntry embodies all IN log entries.
INLogEntry(Class<? extends IN>) - Constructor for class com.sleepycat.je.log.entry.INLogEntry
Construct a log entry for reading.
INLogEntry(IN) - Constructor for class com.sleepycat.je.log.entry.INLogEntry
Construct a log entry for writing to the log.
INLogItem - Class in com.sleepycat.je.tree
Extends LogItem to add fields used by IN.beforeLog and afterLog methods.
INLogItem() - Constructor for class com.sleepycat.je.tree.INLogItem
 
input - Variable in class com.sleepycat.persist.impl.KeyLocation
 
inputLocals - Variable in class com.sleepycat.asm.Frame
The input stack map frame locals.
inputStack - Variable in class com.sleepycat.asm.Frame
The input stack map frame stack.
inputStackTop - Variable in class com.sleepycat.asm.Label
Start of the output stack relatively to the input stack.
inputToEntry(TupleInput, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.TupleBase
Utility method to set the data in a entry buffer to the data in a tuple input object.
InputWireRecord - Class in com.sleepycat.je.rep.stream
Format for messages received at across the wire for replication.
InputWireRecord(EnvironmentImpl, ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.InputWireRecord
Make a InputWireRecord from an incoming replication message buffer for applying at a replica.
InputWireRecord(EnvironmentImpl, byte, int, int, VLSN, ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.InputWireRecord
Unit test support.
inputWireRecord - Variable in class com.sleepycat.je.rep.stream.Protocol.Entry
 
inReplicationStream() - Method in class com.sleepycat.je.log.ReplicationContext
 
inSameSubroutine(Label) - Method in class com.sleepycat.asm.Label
Returns true if this basic block and the given one belong to a common subroutine.
INSERT_SUCCESS - Static variable in class com.sleepycat.je.tree.IN
 
insertEntry(ChildReference) - Method in class com.sleepycat.je.tree.IN
Inserts the argument ChildReference into this IN.
insertEntry1(ChildReference) - Method in class com.sleepycat.je.tree.IN
Same as insertEntry except that it returns the index where the dup was found instead of false.
insertFileSummary(FileSummaryLN, long, int) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Insert the given LN with the given key values.
INSERTION_ORDERED_DUPLICATES - Static variable in class com.sleepycat.compat.DbCompat
 
INSTANCEOF - Static variable in interface com.sleepycat.asm.Opcodes
 
instantiateComparator(Class<? extends Comparator<byte[]>>, String) - Static method in class com.sleepycat.je.dbi.DatabaseImpl
Used both to read from the log and to validate a comparator when set in DatabaseConfig.
instantiateComparator(Comparator<byte[]>, String) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Used to validate a comparator when set in DatabaseConfig.
instantiateEntry(EnvironmentImpl, ByteBuffer) - Method in class com.sleepycat.je.rep.stream.WireRecord
 
inSubroutine(long) - Method in class com.sleepycat.asm.Label
Returns true is this basic block belongs to the given subroutine.
INSUFFICIENT_REPLICAS_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
INSUFFICIENT_REPLICAS_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The amount of time that a Environment.beginTransaction(com.sleepycat.je.Transaction, com.sleepycat.je.TransactionConfig) on the Master will wait for a sufficient number of Replicas, as determined by the default Durability policy, to contact the Master.
InsufficientAcksException - Exception in com.sleepycat.je.rep
This exception is thrown at the time of a commit in a Master, if the Master could not obtain transaction commit acknowledgments from its Replicas in accordance with the Durability.ReplicaAckPolicy currently in effect.
InsufficientAcksException(MasterTxn, int, int, String) - Constructor for exception com.sleepycat.je.rep.InsufficientAcksException
 
InsufficientLogException - Exception in com.sleepycat.je.rep
This exception indicates that the log files constituting the Environment are insufficient and cannot be used as the basis for continuing with the replication stream provided by the current master.
InsufficientLogException(RepNode, VLSN, Set<ReplicationNode>) - Constructor for exception com.sleepycat.je.rep.InsufficientLogException
 
InsufficientLogException(InsufficientLogException) - Constructor for exception com.sleepycat.je.rep.InsufficientLogException
 
InsufficientReplicasException - Exception in com.sleepycat.je.rep
Thrown by Environment.beginTransaction(com.sleepycat.je.Transaction, com.sleepycat.je.TransactionConfig) and Transaction.commit() when these operations are initiated at a Master which is not in contact with a quorum of Replicas as determined by the Durability.ReplicaAckPolicy that is in effect for the operation.
InsufficientReplicasException(Locker, Durability.ReplicaAckPolicy, int, Set<String>) - Constructor for exception com.sleepycat.je.rep.InsufficientReplicasException
Creates a Commit exception.
INSummary - Class in com.sleepycat.je.cleaner
Used to trace the relative numbers of full INs and BINDeltas that are obsolete vs active.
INSummary() - Constructor for class com.sleepycat.je.cleaner.INSummary
 
inSync() - Method in class com.sleepycat.je.rep.stream.MasterStatus
Predicate to determine whether the group and node have a consistent notion of the Master.
INT - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_Integer constant pool items.
INT - Static variable in class com.sleepycat.asm.Type
The sort of the int type.
INT_BYTES - Static variable in class com.sleepycat.je.log.LogUtils
 
INT_MASK - Static variable in class com.sleepycat.je.utilint.DbLsn
 
INT_TYPE - Static variable in class com.sleepycat.asm.Type
The int type.
INTargetRep - Class in com.sleepycat.je.tree
The abstract class that defines the various representations used to represent an array of target pointers to children of an IN node.
INTargetRep() - Constructor for class com.sleepycat.je.tree.INTargetRep
 
INTargetRep.Default - Class in com.sleepycat.je.tree
 
INTargetRep.Default(int) - Constructor for class com.sleepycat.je.tree.INTargetRep.Default
 
INTargetRep.Default(SizeofMarker) - Constructor for class com.sleepycat.je.tree.INTargetRep.Default
 
INTargetRep.None - Class in com.sleepycat.je.tree
Representation used when an IN has no children cached.
INTargetRep.None(SizeofMarker) - Constructor for class com.sleepycat.je.tree.INTargetRep.None
 
INTargetRep.Sparse - Class in com.sleepycat.je.tree
Representation used when 1-4 children are cached.
INTargetRep.Sparse(int) - Constructor for class com.sleepycat.je.tree.INTargetRep.Sparse
 
INTargetRep.Sparse(SizeofMarker) - Constructor for class com.sleepycat.je.tree.INTargetRep.Sparse
 
INTargetRep.Type - Enum in com.sleepycat.je.tree
 
intArraySize(int) - Static method in class com.sleepycat.je.dbi.MemoryBudget
 
IntConfigParam - Class in com.sleepycat.je.config
A JE configuration parameter with an integer value.
IntConfigParam(String, Integer, Integer, Integer, boolean, boolean) - Constructor for class com.sleepycat.je.config.IntConfigParam
 
INTEGER - Static variable in class com.sleepycat.asm.Frame
The INTEGER type.
INTEGER - Static variable in interface com.sleepycat.asm.Opcodes
 
IntegerBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a Integer primitive wrapper or an int primitive.
IntegerBinding() - Constructor for class com.sleepycat.bind.tuple.IntegerBinding
 
IntegralRateStat - Class in com.sleepycat.je.utilint
A long stat which represents a rate whose value is Integral.
IntegralRateStat(StatGroup, StatDefinition, Stat<? extends Number>, Stat<? extends Number>, long) - Constructor for class com.sleepycat.je.utilint.IntegralRateStat
 
InternalException - Exception in com.sleepycat.je.utilint
Some internal inconsistency exception.
InternalException() - Constructor for exception com.sleepycat.je.utilint.InternalException
 
InternalException(String) - Constructor for exception com.sleepycat.je.utilint.InternalException
 
IntRunningTotalStat - Class in com.sleepycat.je.rep.utilint
Used to create running totals across the lifetime of the StatGroup.
IntRunningTotalStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.rep.utilint.IntRunningTotalStat
 
IntStat - Class in com.sleepycat.je.utilint
An integer JE stat.
IntStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.IntStat
 
IntStat(StatGroup, StatDefinition, int) - Constructor for class com.sleepycat.je.utilint.IntStat
 
intToEntry(int, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.IntegerBinding
Converts a simple int value into an entry buffer.
intToEntry(int, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.PackedIntegerBinding
Converts a simple int value into an entry buffer, using PackedInteger format.
intToEntry(int, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedPackedIntegerBinding
Converts a simple int value into an entry buffer, using SortedPackedInteger format.
intVal - Variable in class com.sleepycat.asm.Item
Value of this item, for an integer item.
INVALID - Static variable in class com.sleepycat.je.dbi.DbEnvState
 
invalidate() - Method in class com.sleepycat.je.Database
Invalidates the handle when the transaction used to open the database is aborted.
invalidate(EnvironmentFailureException) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Invalidate the environment.
invalidate(Error) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Invalidate the environment when a Java Error is thrown.
invalidate(Database) - Static method in class com.sleepycat.je.DbInternal
Proxy to Database.invalidate()
invalidate(EnvironmentFailureException) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
invalidate(long) - Method in class com.sleepycat.je.util.DbBackup
 
invalidateBackups(long) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
invalidatesEnvironment() - Method in enum com.sleepycat.je.dbi.EnvironmentFailureReason
 
invalidFrames - Variable in class com.sleepycat.asm.ClassWriter
true if the stack map tables of this class are invalid.
invoke(String, Object[], String[]) - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
invoke(Environment, String, Object[], String[]) - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Invoke an operation for the given environment.
invoke(String, Object[], String[]) - Method in class com.sleepycat.je.jmx.JEMonitor
 
invoke(String, Object[], String[]) - Method in class com.sleepycat.je.rep.jmx.RepJEMonitor
 
invokeAddRemoveTriggers(Locker, List<Trigger>, List<Trigger>) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invoke the triggers associated with the addition or removal of the trigger itself.
invokeCheckpoint(CheckpointConfig, String) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Invoke a checkpoint programmatically.
invokeCleaner() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
invokeCompressor() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Invoke a compress programatically.
INVOKEDYNAMIC - Static variable in interface com.sleepycat.asm.Opcodes
 
invokeEvictor() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
INVOKEINTERFACE - Static variable in interface com.sleepycat.asm.Opcodes
 
INVOKESPECIAL - Static variable in interface com.sleepycat.asm.Opcodes
 
INVOKESTATIC - Static variable in interface com.sleepycat.asm.Opcodes
 
INVOKEVIRTUAL - Static variable in interface com.sleepycat.asm.Opcodes
 
IO_EXCEPTION_TESTING_ON_READ - Static variable in class com.sleepycat.je.log.FileManager
 
IO_EXCEPTION_TESTING_ON_WRITE - Static variable in class com.sleepycat.je.log.FileManager
 
IOExceptionWrapper - Exception in com.sleepycat.util
An IOException that can contain nested exceptions.
IOExceptionWrapper(Throwable) - Constructor for exception com.sleepycat.util.IOExceptionWrapper
 
IOR - Static variable in interface com.sleepycat.asm.Opcodes
 
IREM - Static variable in interface com.sleepycat.asm.Opcodes
 
IRETURN - Static variable in interface com.sleepycat.asm.Opcodes
 
IS_DALVIK - Static variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
isAbort() - Method in class com.sleepycat.je.log.LNFileReader
 
isActive() - Method in enum com.sleepycat.je.rep.ReplicatedEnvironment.State
 
isActive(long) - Method in class com.sleepycat.je.rep.utilint.NamedChannelWithTimeout
Method invoked by the time thread to check on the channel on a periodic basis.
isActivePrimary() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns true if the node is a designated Primary that has been activated.
isAlwaysLatchedExclusively() - Method in class com.sleepycat.je.tree.BIN
 
isAlwaysLatchedExclusively() - Method in class com.sleepycat.je.tree.IN
 
isArray() - Method in class com.sleepycat.persist.impl.Format
 
isArray() - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
isArray() - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
isArray() - Method in interface com.sleepycat.persist.raw.RawType
Returns whether this is an array type.
isAssignableTo(Format) - Method in class com.sleepycat.persist.impl.Format
Called by EntityOutput in rawAccess mode to determine whether an object type is allowed to be assigned to a given field type.
isAssignableTo(Format) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
isAuthoritativeMaster() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns a definitive answer to whether this node is currently the master by checking both its status as a master and that at least a simple majority of nodes agrees that it's the master based on the number of feeder connections to it.
isAutoCommitAllowed() - Method in class com.sleepycat.collections.CurrentTransaction
Returns whether auto-commit may be performed by the collections API.
isAutoTxn() - Method in class com.sleepycat.je.txn.Txn
Determines whether this is an auto transaction.
isBIN() - Method in class com.sleepycat.je.tree.BIN
 
isBIN() - Method in class com.sleepycat.je.tree.Node
 
isBINDelta() - Method in class com.sleepycat.je.log.CleanerFileReader
 
isBINDelta() - Method in class com.sleepycat.je.log.INFileReader
 
isBusy() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffService
 
isCacheFull() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
See Evictor.isCacheFull
isCacheFull() - Method in class com.sleepycat.je.evictor.Arbiter
Returns true if the JE cache level is above the point where it is likely that the cache has filled, and is staying full.
isCacheFull() - Method in class com.sleepycat.je.evictor.Evictor
 
isCDBCursorOpen(Database) - Method in class com.sleepycat.collections.CurrentTransaction
Returns true if a CDB cursor is open and therefore a Database write operation should not be attempted since a self-deadlock may result.
isCdbMode() - Method in class com.sleepycat.collections.CurrentTransaction
Returns whether this is a Concurrent Data Store environment.
isCheckpointEnd() - Method in class com.sleepycat.je.log.CheckpointFileReader
 
isCheckpointNeeded() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns whether this database's MapLN must be flushed during a checkpoint.
isCheckpointStart() - Method in class com.sleepycat.je.log.CheckpointFileReader
 
isClass() - Method in class com.sleepycat.je.dbi.DatabaseImpl.ComparatorReader
 
isClassConverted(Format) - Method in class com.sleepycat.persist.impl.Evolver
 
isClosed() - Method in class com.sleepycat.je.dbi.CursorImpl
 
isClosed() - Method in class com.sleepycat.je.dbi.DiskOrderedCursorImpl
 
isClosed() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isClosed(ReplicatedEnvironment) - Static method in class com.sleepycat.je.rep.RepInternal
 
isClosed() - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Determines if this replicated environment handle has been closed.
isClosed() - Method in class com.sleepycat.je.txn.Txn
 
isClosing() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isCodeAttribute() - Method in class com.sleepycat.asm.Attribute
Returns true if this type of attribute is a code attribute.
isCommit() - Method in class com.sleepycat.je.log.LNFileReader
 
isCompressible() - Method in class com.sleepycat.je.tree.BIN
 
isCompressible() - Method in class com.sleepycat.je.tree.Node
 
isConfigParamSet(String) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
isCorrectionEstablished() - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Returns whether enough adjustments have been made to conclude that the the LN size correction factor has been established, or at least unnecessary because very few LN sizes are uncounted.
isCurrentData(Object) - Method in class com.sleepycat.collections.BaseIterator
 
isCurrentData(Object) - Method in class com.sleepycat.collections.BlockIterator
 
isCurrentData(Object) - Method in class com.sleepycat.collections.StoredIterator
 
isCurrentVersion() - Method in class com.sleepycat.persist.impl.Format
Returns whether this format is the current format for its class.
isDalvik() - Static method in class com.sleepycat.compat.DbCompat
 
isDataSearch() - Method in enum com.sleepycat.je.dbi.CursorImpl.SearchMode
Returns true when the data value is included in the search, i.e., for BOTH and BOTH_RANGE.
isDbLoggingDisabled() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isDbRoot - Variable in class com.sleepycat.je.recovery.Checkpointer.CheckpointReference
 
isDbRoot() - Method in class com.sleepycat.je.tree.IN
 
isDbTree() - Method in class com.sleepycat.je.log.CheckpointFileReader
 
isDbTree() - Method in class com.sleepycat.je.log.CleanerFileReader
 
isDebugNameAvailable() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns whether getDebugName returns a DB name rather than a DB ID.
isDeferredWriteMode() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
isDelete() - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.StartInfo
 
isDeleted() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
isDeleted() - Method in class com.sleepycat.je.log.entry.BaseEntry
Returns true if this item should be counted as obsoleted when logged.
isDeleted() - Method in class com.sleepycat.je.log.entry.LNLogEntry
Returns true for a deleted LN to count it immediately as obsolete.
isDeleted() - Method in interface com.sleepycat.je.log.entry.LogEntry
Returns true if this item should be counted as obsolete when logged.
isDeleted() - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
isDeleted() - Method in class com.sleepycat.je.tree.LN
 
isDeleted() - Method in class com.sleepycat.je.tree.MapLN
 
isDeleted() - Method in class com.sleepycat.je.tree.NameLN
 
isDeleted() - Method in class com.sleepycat.persist.impl.Format
Returns whether the class for this format was deleted.
isDeleted() - Method in interface com.sleepycat.persist.raw.RawType
Returns whether this type has been deleted using a class Deleter mutation.
isDeleteFinished() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
isDeleteInfo() - Method in class com.sleepycat.je.log.INFileReader
 
isDelta - Variable in class com.sleepycat.je.tree.INLogItem
Indicates that a BINDelta is logged.
isDesignatedPrimary() - Method in class com.sleepycat.je.rep.impl.RepImpl
Returns true, if the node has been designated a Primary.
isDesignatedPrimary() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
isDetached() - Method in enum com.sleepycat.je.rep.ReplicatedEnvironment.State
 
isDirty(int) - Method in class com.sleepycat.je.tree.IN
 
isDirty() - Method in class com.sleepycat.je.tree.LN
 
isDirtyUtilization() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns whether this database has new (unflushed) utilization info.
isDupDeleteInfo() - Method in class com.sleepycat.je.log.INFileReader
 
isDupRootDeletion() - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
Returns true if we are certain that this log entry reflects deletion of a DIN root.
isDurableDeferredWrite() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
isEmpty() - Method in class com.sleepycat.collections.DataView
Returns whether no records are present in the view.
isEmpty() - Method in class com.sleepycat.collections.StoredContainer
Returns true if this map or collection contains no mappings or elements.
isEmpty() - Method in class com.sleepycat.je.cleaner.FileSelector.CheckpointStartCleanerState
 
isEmpty() - Method in class com.sleepycat.je.cleaner.FileSummary
Returns whether this summary contains any non-zero totals.
isEmpty() - Method in class com.sleepycat.je.dbi.LSNAccumulator
 
isEmpty() - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
isEmpty() - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
isEmpty() - Method in class com.sleepycat.je.rep.vlsn.VLSNRecoveryTracker
 
isEmpty() - Method in class com.sleepycat.persist.evolve.Mutations
Returns true if no mutations are present.
isEmpty() - Method in class com.sleepycat.utilint.LatencyStat
 
isEnhanced(Class) - Static method in class com.sleepycat.persist.impl.EnhancedAccessor
Returns whether a given class is a (registered) enhanced class.
isEntity() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
isEntity() - Method in class com.sleepycat.persist.impl.Format
Returns whether this format class is an entity class.
isEntityClass() - Method in class com.sleepycat.persist.model.ClassMetadata
Returns whether this class is an entity class.
isEntryKnownDeleted(int) - Method in class com.sleepycat.je.tree.IN
 
isEntryPendingDeleted(int) - Method in class com.sleepycat.je.tree.IN
 
isEnum() - Method in class com.sleepycat.persist.impl.EnumFormat
 
isEnum() - Method in class com.sleepycat.persist.impl.Format
 
isEnum() - Method in interface com.sleepycat.persist.raw.RawType
Returns whether this is an enum type.
isEqualTo(Item) - Method in class com.sleepycat.asm.Item
Indicates if the given item is equal to this one.
isEvictable(BIN, int, boolean) - Method in class com.sleepycat.je.cleaner.Cleaner
Returns whether the given BIN entry may be stripped by the evictor.
isEvictable() - Method in class com.sleepycat.je.tree.IN
Returns whether this node can be evicted.
isEvictable(long) - Method in class com.sleepycat.je.tree.LN
Returns true by default, but is overridden by MapLN to prevent eviction of open databases.
isEvictable(long) - Method in class com.sleepycat.je.tree.MapLN
Does a guaranteed check by acquiring the write-lock and then calling isEvictableInexact.
isEvictableInexact() - Method in class com.sleepycat.je.tree.LN
Returns true by default, but is overridden by MapLN to prevent eviction of open databases.
isEvictableInexact() - Method in class com.sleepycat.je.tree.MapLN
Does a fast check without acquiring the MapLN write-lock.
isEvictionProhibited() - Method in class com.sleepycat.je.tree.BIN
Note that the IN may or may not be latched when this method is called.
isEvictionProhibited() - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
isEvictionProhibited() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
isEvictionProhibited() - Method in class com.sleepycat.je.tree.IN
Returns whether the node is not evictable, irrespective of the status of the children nodes.
isExactSearch() - Method in enum com.sleepycat.je.dbi.CursorImpl.SearchMode
Returns true when the key or key/data search is exact, i.e., for SET and BOTH.
isFeederDeathEvent() - Method in class com.sleepycat.je.rep.impl.node.MasterTransfer.VLSNProgress
 
isFileCleaningInProgress(Long) - Method in class com.sleepycat.je.cleaner.FileSelector
Returns whether the file is in any stage of the cleaning process.
isFileHeader() - Method in class com.sleepycat.je.log.CleanerFileReader
 
isFileUncounted(Long, long) - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Returns whether file summary information for the given LSN is not already counted.
isFileUncounted(Long, long) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Overrides this method for recovery and returns whether the FileSummaryLN for the given file is prior to the given LSN.
isFileValid(long) - Method in class com.sleepycat.je.log.FileManager
For assertions that check whether a file is valid or has been deleted via log cleaning.
isFirstBin - Variable in class com.sleepycat.je.tree.BINBoundary
The first BIN was returned.
isFirstSyncDataSet() - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier
 
isFlushedToDisk() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
isFlushedToDisk() - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
isFormatChanged(Format) - Method in class com.sleepycat.persist.impl.Evolver
Returns whether the given format was changed during evolution.
isForReplication() - Method in class com.sleepycat.je.config.ConfigParam
 
isForward() - Method in enum com.sleepycat.je.dbi.GetMode
 
isGhost() - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
 
isGhost() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
isGroupMaster() - Method in class com.sleepycat.je.rep.stream.MasterStatus
Returns true if it's the master from the Group's perspective
ISHL - Static variable in interface com.sleepycat.asm.Opcodes
 
ISHR - Static variable in interface com.sleepycat.asm.Opcodes
 
isIN() - Method in class com.sleepycat.je.log.CleanerFileReader
 
isIN() - Method in class com.sleepycat.je.tree.IN
 
isIN() - Method in class com.sleepycat.je.tree.Node
 
isInInit() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isInitialized() - Method in class com.sleepycat.persist.impl.Format
 
isInitialized() - Method in class com.sleepycat.util.keyrange.RangeCursor
Returns whether the cursor is initialized at a valid position.
isInternal() - Method in enum com.sleepycat.je.dbi.DbType
Returns true if this is an internal DB, or false if it is a user DB.
isInternalDb() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
isInternalDbCursor() - Method in class com.sleepycat.je.dbi.CursorImpl
 
isInternalHandle() - Method in class com.sleepycat.je.Environment
 
isINType() - Method in class com.sleepycat.je.log.LogEntryType
 
isInUse() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Returns whether this DB is in use and cannot be evicted.
isInUseDuringDbRemove() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Checks whether a database is in use during a remove or truncate database operation.
isInvalid() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Predicate used to determine whether the EnvironmentImpl is valid.
isInvisible() - Method in class com.sleepycat.je.log.LNFileReader
 
isInvisible() - Method in class com.sleepycat.je.log.LogEntryHeader
 
isKeyInBounds(byte[]) - Method in class com.sleepycat.je.tree.IN
Returns whether the given key is greater than or equal to the first key in the IN and less than or equal to the last key in the IN.
isKnownDeleted() - Method in class com.sleepycat.je.tree.ChildReference
 
isKnownDeleted() - Method in class com.sleepycat.je.tree.DeltaInfo
 
isLast() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPRequest
 
isLastBin - Variable in class com.sleepycat.je.tree.BINBoundary
The last BIN was returned.
isLatchOwnerForRead() - Method in class com.sleepycat.je.tree.IN
 
isLatchOwnerForWrite() - Method in class com.sleepycat.je.tree.IN
 
isLN() - Method in class com.sleepycat.je.log.CleanerFileReader
 
isLN() - Method in class com.sleepycat.je.log.LNFileReader
 
isLN() - Method in class com.sleepycat.je.tree.LN
 
isLN() - Method in class com.sleepycat.je.tree.Node
 
isLNDeleted() - Method in class com.sleepycat.je.log.CleanerFileReader
 
isLNDeleted() - Method in class com.sleepycat.je.log.LNFileReader
 
isLNType(LogEntryType) - Static method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Returns whether the given type is an LN; a null type is assumed to be an LN.
isLNType() - Method in class com.sleepycat.je.log.LogEntryType
 
isLocalAdditional() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
isLocked(Long) - Method in class com.sleepycat.je.txn.DummyLockManager
 
isLocked(Long) - Method in class com.sleepycat.je.txn.LockManager
Test the status of the lock on LSN.
isLocked(Long) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
isLockedInternal(Long, int) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of isLocked.
isLockingMode() - Method in class com.sleepycat.collections.CurrentTransaction
Returns whether environment is configured for locking.
isLockUncontended(Long) - Method in class com.sleepycat.je.txn.DummyLockManager
 
isLockUncontended(Long) - Method in class com.sleepycat.je.txn.LockManager
 
isLockUncontended(Long) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
isLockUncontendedInternal(Long, int) - Method in class com.sleepycat.je.txn.LockManager
 
isManyType(Class) - Static method in class com.sleepycat.persist.impl.PersistKeyCreator
 
isMaster() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isMaster() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
isMaster() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
isMaster() - Method in enum com.sleepycat.je.rep.ReplicatedEnvironment.State
 
isMatchable() - Method in enum com.sleepycat.je.log.LogEntryType.Replicable
 
isMemOnly() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isMetadataStale(Transaction) - Method in class com.sleepycat.persist.impl.PersistCatalog
Metadata needs refreshing when a Replica with stale metadata is elected master, and then a user write operation is attempted that also requires a metadata update.
isModelClass() - Method in class com.sleepycat.persist.impl.ComplexFormat
 
isModelClass() - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
isModelClass() - Method in class com.sleepycat.persist.impl.Format
Returns whether this class is present in the EntityModel.
isMultiValueParam() - Method in class com.sleepycat.je.config.ConfigParam
 
isMutable() - Method in class com.sleepycat.je.config.ConfigParam
 
isNew() - Method in class com.sleepycat.persist.impl.Format
 
isNodeMaster() - Method in class com.sleepycat.je.rep.stream.MasterStatus
Returns true if it's the master from the node's localized perspective
isNodeType() - Method in class com.sleepycat.je.log.LogEntryType
 
isNoLocking() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isNotInitialized() - Method in class com.sleepycat.je.dbi.CursorImpl
 
isNotSet() - Method in class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
isNotSet() - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
isNotSet() - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
isNotSet() - Method in class com.sleepycat.je.utilint.BooleanStat
 
isNotSet() - Method in class com.sleepycat.je.utilint.FloatStat
 
isNotSet() - Method in class com.sleepycat.je.utilint.IntStat
 
isNotSet() - Method in class com.sleepycat.je.utilint.LongArrayStat
 
isNotSet() - Method in class com.sleepycat.je.utilint.LongStat
 
isNotSet() - Method in class com.sleepycat.je.utilint.Stat
Returns true if this stat is zero or null, as is appropriate for its type.
isNotSet() - Method in class com.sleepycat.je.utilint.StringStat
 
isNull() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
isNull() - Method in class com.sleepycat.je.utilint.VLSN
 
isNull(long) - Static method in class com.sleepycat.je.utilint.VLSN
 
isOldDupType() - Method in class com.sleepycat.je.log.LogEntryType
 
isOldHeaderVersion() - Method in class com.sleepycat.je.log.FileHandle
 
isOnlyAbortable() - Method in class com.sleepycat.je.txn.Txn
 
isOpen() - Method in class com.sleepycat.je.rep.utilint.NamedChannel
 
isOpen() - Method in class com.sleepycat.persist.model.EntityModel
Returns whether the model is associated with an open store.
isOrdered() - Method in class com.sleepycat.collections.StoredContainer
Returns whether keys are ordered in this container.
isOverBudget() - Method in class com.sleepycat.je.evictor.Arbiter
Return true if the memory budget is overspent.
isOwnedWriteLock(Locker) - Method in interface com.sleepycat.je.txn.Lock
Return true if locker is an owner of this Lock and this is a write lock.
isOwnedWriteLock(Locker) - Method in class com.sleepycat.je.txn.LockImpl
Return true if locker is an owner of this Lock and this is a write lock.
isOwnedWriteLock(Locker) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
isOwner() - Method in class com.sleepycat.je.latch.Latch
Return true if the current thread holds this latch.
isOwner() - Method in class com.sleepycat.je.latch.SharedLatch
Return true if this thread is an owner, reader, or write.
isOwner(Long, Locker, LockType) - Method in class com.sleepycat.je.txn.DummyLockManager
 
isOwner(Locker, LockType) - Method in interface com.sleepycat.je.txn.Lock
Return true if locker is an owner of this Lock for lockType, false otherwise.
isOwner(Locker, LockType) - Method in class com.sleepycat.je.txn.LockImpl
Return true if locker is an owner of this Lock for lockType, false otherwise.
isOwner(Long, Locker, LockType) - Method in class com.sleepycat.je.txn.LockManager
Return true if this locker owns this a lock of this type on given node.
isOwner(Long, Locker, LockType) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
isOwner(Locker, LockType) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
isOwnerInternal(Long, Locker, LockType, int) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of isOwner.
isPaused() - Method in class com.sleepycat.je.utilint.DaemonThread
Returns whether the daemon is currently paused/disabled.
isPredefined(Format) - Static method in class com.sleepycat.persist.impl.Format
 
isPreempted() - Method in class com.sleepycat.je.txn.Locker
For unit testing.
isPrepare() - Method in class com.sleepycat.je.log.LNFileReader
 
isPriKeyFieldNullOrZero(Object) - Method in interface com.sleepycat.persist.impl.Accessor
Returns whether the primary key field is null (for a reference type) or zero (for a primitive integer type).
isPriKeyFieldNullOrZero(Object) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
isPriKeyFieldNullOrZero(Object) - Method in class com.sleepycat.persist.impl.RawAccessor
 
isPriKeyFieldNullOrZero(Object) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
isPriKeyNullOrZero(Object, boolean) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
isPriKeyNullOrZero(Object, boolean) - Method in class com.sleepycat.persist.impl.Format
Returns whether the entity's primary key field is null or zero, as defined for primary keys that are assigned from a sequence.
isPrimitive() - Method in class com.sleepycat.persist.impl.Format
 
isPrimitive() - Method in class com.sleepycat.persist.impl.SimpleFormat
 
isPrimitive() - Method in interface com.sleepycat.persist.raw.RawType
Returns whether this type is a Java primitive: char, byte, short, int, long, float or double.
isProvisional(long, long) - Method in enum com.sleepycat.je.log.Provisional
Determines whether a given log entry should be processed during recovery.
isQuorumAck() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
isRawAccess() - Method in class com.sleepycat.persist.impl.AbstractInput
 
isRawAccess() - Method in interface com.sleepycat.persist.impl.Catalog
 
isRawAccess() - Method in interface com.sleepycat.persist.impl.EntityInput
Return whether this input is in raw mode, i.e., whether it is returning raw instances.
isRawAccess() - Method in class com.sleepycat.persist.impl.PersistCatalog
 
isRawAccess() - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
isRawAccess() - Method in class com.sleepycat.persist.impl.RecordInput
 
isRawAccess() - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
isReadCommittedIsolation() - Method in class com.sleepycat.je.txn.BasicLocker
Is never read-committed isolation.
isReadCommittedIsolation() - Method in class com.sleepycat.je.txn.Locker
Returns whether the isolation level of this locker is read-committed.
isReadCommittedIsolation() - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Is always read-committed isolation.
isReadCommittedIsolation() - Method in class com.sleepycat.je.txn.Txn
Is read-committed isolation if so configured.
isReadModifyWrite() - Method in class com.sleepycat.collections.StoredIterator
Returns whether write-locks will be obtained when reading with this cursor.
isReadOnly() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isReadOnly() - Method in class com.sleepycat.persist.impl.PersistCatalog
Returns true if the user opened the store read-only, or we're running in Replica upgrade mode.
isReadUncommitted() - Method in class com.sleepycat.collections.CurrentTransaction
Returns whether the current transaction is a readUncommitted transaction.
isReadUncommittedDefault() - Method in class com.sleepycat.je.txn.Locker
 
isReadUncommittedMode(LockMode) - Method in class com.sleepycat.je.Cursor
Returns whether the given lock mode will cause a read-uncommitted when used with this cursor, taking into account the default cursor configuration.
isRegistered(String) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
 
isRemoteAdditional() - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
isRemoved() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
isRepConverted() - Method in class com.sleepycat.je.dbi.DbTree
 
isRepConverted() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
True if this environment is converted from non-replicated to replicated.
isReplica() - Method in enum com.sleepycat.je.rep.ReplicatedEnvironment.State
 
isReplicable() - Method in enum com.sleepycat.je.log.LogEntryType.Replicable
 
isReplicated(Environment) - Static method in class com.sleepycat.compat.DbCompat
 
isReplicated() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
isReplicated() - Method in class com.sleepycat.je.dbi.DbTree
 
isReplicated() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Return true if this environment is part of a replication group.
isReplicated() - Method in class com.sleepycat.je.rep.impl.RepImpl
Return true if this environment is part of a replication group.
isReplicatedTxn(long) - Static method in class com.sleepycat.je.txn.TxnManager
 
isReplicationDefined() - Method in class com.sleepycat.je.rep.txn.MasterThreadLocker
 
isReplicationDefined() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
isReplicationDefined() - Method in class com.sleepycat.je.rep.txn.ReadonlyTxn
 
isReplicationDefined() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
isReplicationDefined() - Method in class com.sleepycat.je.rep.txn.ReplicaThreadLocker
 
isReplicationDefined() - Method in class com.sleepycat.je.txn.BuddyLocker
Consider this locker replication-defined if its buddy (Txn) is replication-defined.
isReplicationDefined() - Method in class com.sleepycat.je.txn.Locker
Used for debugging checks to ensure that replication-defined lockers are used for accessing replicated databases.
isReplicationPossible() - Method in class com.sleepycat.je.log.LogEntryType
Return true if this type of log entry can be part of the replication stream.
isReplicaUpgradeMode() - Method in class com.sleepycat.persist.EntityStore
 
isReplicaUpgradeMode() - Method in class com.sleepycat.persist.impl.PersistCatalog
For unit testing.
isReplicaUpgradeMode() - Method in class com.sleepycat.persist.impl.Store
For unit testing.
isReservedDbName(String) - Static method in class com.sleepycat.je.dbi.DbTree
Returns true if the name is a reserved JE database name.
isRMWFixEnabled() - Method in class com.sleepycat.je.cleaner.Cleaner
 
isRollbackEnd() - Method in class com.sleepycat.je.log.LNFileReader
 
isRollbackStart() - Method in class com.sleepycat.je.log.LNFileReader
 
isRolledBack() - Method in class com.sleepycat.je.txn.Locker
 
isRolledBack() - Method in class com.sleepycat.je.txn.Txn
 
isRoot() - Method in class com.sleepycat.je.tree.IN
 
isRootResident() - Method in class com.sleepycat.je.tree.Tree
Perform a fast check to see if the root IN is resident.
isRunning() - Method in class com.sleepycat.je.utilint.DaemonThread
Returns whether the onWakeup method is currently executing.
isSameClass(Format) - Method in class com.sleepycat.persist.impl.Format
Returns whether this format has the same class as the given format, irrespective of version changes and renaming.
isSameRM(XAResource) - Method in class com.sleepycat.je.XAEnvironment
 
isSecKeyIncorrectlyOrdered(String) - Method in class com.sleepycat.persist.impl.ComplexFormat
Called when opening an existing secondary database that should have a dup comparator configured.
isSecondary() - Method in class com.sleepycat.collections.DataView
Returns whether this is a view on a secondary database rather than directly on a primary database.
isSecondary() - Method in class com.sleepycat.collections.StoredContainer
Returns whether this container is a view on a secondary database rather than directly on a primary database.
isSerializableIsolation() - Method in class com.sleepycat.je.txn.BasicLocker
Is never serializable isolation.
isSerializableIsolation() - Method in class com.sleepycat.je.txn.Locker
Returns whether the isolation level of this locker is serializable.
isSerializableIsolation() - Method in class com.sleepycat.je.txn.Txn
Is serializable isolation if so configured.
isSharedCache() - Method in class com.sleepycat.je.dbi.MemoryBudget.Totals
 
isShutdown() - Method in class com.sleepycat.je.rep.impl.node.Feeder
 
isShutdown() - Method in class com.sleepycat.je.utilint.StoppableThread
 
isShutdownRequested() - Method in class com.sleepycat.je.utilint.DaemonThread
Returns whether shutdown has been requested.
isSimple() - Method in class com.sleepycat.persist.impl.Format
 
isSimple() - Method in class com.sleepycat.persist.impl.SimpleFormat
 
isSimple() - Method in interface com.sleepycat.persist.raw.RawType
Returns whether this is a simple type: primitive, primitive wrapper, BigInteger, BigDecimal, String or Date.
isSimpleRefType(String) - Static method in class com.sleepycat.persist.model.BytecodeEnhancer
Returns true if the given class is a primitive wrapper, Date or String.
isSimpleType(Class) - Static method in class com.sleepycat.persist.impl.SimpleCatalog
 
isSingleKey() - Method in class com.sleepycat.util.keyrange.KeyRange
Returns whether this is a single-key range.
isStateKnownDeleted(byte) - Static method in class com.sleepycat.je.tree.IN
Returns true if the given state is known deleted.
isStatePendingDeleted(byte) - Static method in class com.sleepycat.je.tree.IN
Returns true if the given state is pending deleted.
issueProposal(QuorumPolicy, Proposer.RetryPredicate) - Method in class com.sleepycat.je.rep.elections.Proposer
Runs an election using the consensus algorithm.
isSuspended() - Method in class com.sleepycat.je.txn.Txn
 
isSyncPoint() - Method in class com.sleepycat.je.log.LogEntryType
Return true if this type of log entry can serve as the synchronization matchpoint for the replication stream.
isSyncPoint(byte) - Static method in class com.sleepycat.je.log.LogEntryType
Return true if this type of log entry can serve as the synchronization matchpoint for the replication stream.
isTargetEntry() - Method in class com.sleepycat.je.log.CheckpointFileReader
 
isTargetEntry() - Method in class com.sleepycat.je.log.DumpFileReader
 
isTargetEntry() - Method in class com.sleepycat.je.log.FileReader
 
isTargetEntry() - Method in class com.sleepycat.je.log.INFileReader
If we're tracking node, database and txn IDs, we want to see all node log entries.
isTargetEntry() - Method in class com.sleepycat.je.log.LNFileReader
 
isTargetEntry() - Method in class com.sleepycat.je.log.ScavengerFileReader
 
isTargetEntry() - Method in class com.sleepycat.je.log.SearchFileReader
 
isTargetEntry() - Method in class com.sleepycat.je.log.UtilizationFileReader
 
isTargetEntry() - Method in class com.sleepycat.je.rep.stream.FeederReader
Return true if this entry is replicated and its VLSN is currentVLSN.
isTargetEntry() - Method in class com.sleepycat.je.rep.stream.FeederSyncupReader
 
isTargetEntry() - Method in class com.sleepycat.je.rep.stream.ReplicaSyncupReader
Return true for ckpt entries, for syncable entries, and if we're in specific vlsn scan mode, any replicated entry.
isTemporary() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
isTemporary(byte) - Static method in class com.sleepycat.je.dbi.DatabaseImpl
 
isTerminated() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.VLSNAwaitLatch
 
isThin() - Method in interface com.sleepycat.je.txn.Lock
 
isThin() - Method in class com.sleepycat.je.txn.LockImpl
 
isThin() - Method in class com.sleepycat.je.txn.ThinLockImpl
 
isTimedOut() - Method in class com.sleepycat.je.txn.BuddyLocker
Returns whether the buddy locker is timed out, since this locker has no independent timeout.
isTimedOut() - Method in class com.sleepycat.je.txn.Locker
 
ISTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
isTransactional() - Method in class com.sleepycat.collections.StoredContainer
Returns whether the databases underlying this container are transactional.
isTransactional() - Method in class com.sleepycat.je.Database
Equivalent to getConfig().getTransactional() but cheaper.
isTransactional() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
isTransactional() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isTransactional() - Method in class com.sleepycat.je.log.LogEntryType
Return true if this log entry has transactional information in it, like a commit or abort record, or a transactional LN.
isTransactional() - Method in enum com.sleepycat.je.log.LogEntryType.Txnal
 
isTransactional() - Method in class com.sleepycat.je.txn.BasicLocker
Is never transactional.
isTransactional() - Method in class com.sleepycat.je.txn.Locker
Returns whether this locker is transactional.
isTransactional() - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Is always transactional because the buddy locker is transactional.
isTransactional() - Method in class com.sleepycat.je.txn.Txn
Is always transactional.
isTransient(long) - Static method in class com.sleepycat.je.utilint.DbLsn
A transient LSN is defined as one with a file number of MAX_FILE_NUM.
isTransientOrNull(long) - Static method in class com.sleepycat.je.utilint.DbLsn
 
isTreeUsageAboveMinimum() - Method in class com.sleepycat.je.dbi.MemoryBudget
Returns whether eviction of INList information is allowed.
isTxnEnd() - Method in class com.sleepycat.je.rep.stream.Protocol.Entry
 
isTxnMode() - Method in class com.sleepycat.collections.CurrentTransaction
Returns whether this is a transactional environment.
isTypeBtree(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
isTypeHash(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
isTypeQueue(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
isTypeRecno(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
ISUB - Static variable in interface com.sleepycat.asm.Opcodes
 
isUnknown() - Method in class com.sleepycat.asm.Attribute
Returns true if this type of attribute is unknown.
isUnknown() - Method in enum com.sleepycat.je.rep.ReplicatedEnvironment.State
 
isUnknownUUID(UUID) - Static method in class com.sleepycat.je.rep.impl.RepGroupImpl
Predicate to help determine whether the UUID is the canonical unknown UUID.
isUpdateAllowed() - Method in class com.sleepycat.persist.BasicIndex
 
isUpdateAllowed() - Method in class com.sleepycat.persist.KeysIndex
 
isUpdateAllowed() - Method in class com.sleepycat.persist.PrimaryIndex
 
isUpdateAllowed() - Method in class com.sleepycat.persist.SecondaryIndex
 
isUserLNType() - Method in class com.sleepycat.je.log.LogEntryType
 
isValid() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
isValid() - Method in class com.sleepycat.je.Environment
Returns whether this Environment is open, valid and can be used.
isValid() - Method in class com.sleepycat.je.Transaction
Returns whether this Transaction is open, which is equivalent to when Transaction.getState() returns Transaction.State.OPEN.
isValid() - Method in class com.sleepycat.je.txn.Locker
Used to determine whether the locker is usable.
isValid() - Method in class com.sleepycat.je.txn.Txn
 
isValidForDelete() - Method in class com.sleepycat.je.tree.BIN
Check if this node fits the qualifications for being part of a deletable subtree.
isValidForDelete() - Method in class com.sleepycat.je.tree.IN
Check if this node fits the qualifications for being part of a deletable subtree.
isValidForDelete() - Method in class com.sleepycat.je.tree.LN
 
isValidForDelete() - Method in class com.sleepycat.je.tree.Node
 
isValidType(byte) - Static method in class com.sleepycat.je.log.LogEntryType
 
isVariableLength() - Method in class com.sleepycat.je.log.LogEntryHeader
May be called after reading MIN_HEADER_SIZE bytes to determine whether more bytes (getVariablePortionSize) should be read.
isWaiter(Long, Locker) - Method in class com.sleepycat.je.txn.DummyLockManager
 
isWaiter(Locker) - Method in interface com.sleepycat.je.txn.Lock
Return true if locker is a waiter on this Lock.
isWaiter(Locker) - Method in class com.sleepycat.je.txn.LockImpl
Return true if locker is a waiter on this Lock.
isWaiter(Long, Locker) - Method in class com.sleepycat.je.txn.LockManager
Return true if this locker is waiting on this lock.
isWaiter(Long, Locker) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
isWaiter(Locker) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
isWaiterInternal(Long, Locker, int) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of isWaiter.
isWideningSupported(Format, Format, boolean) - Static method in class com.sleepycat.persist.impl.WidenerInput
Returns whether widening is supported by this class.
isWritable() - Method in class com.sleepycat.je.Database
Returns true if the Database was opened read/write.
isWritable() - Method in enum com.sleepycat.je.log.FileManager.FileMode
 
isWriteAllowed() - Method in class com.sleepycat.collections.DataCursor
Returns whether write is allowed for this cursor, as specified to the constructor.
isWriteAllowed() - Method in class com.sleepycat.collections.StoredContainer
Returns true if this is a read-write container or false if this is a read-only container.
isWriteConfigType(DbOperationType) - Static method in enum com.sleepycat.je.log.entry.DbOperationType
Return true if this databaes operation type needs to write DatabaseConfig.
isWriteLock() - Method in class com.sleepycat.je.txn.LockType
Returns true if this is a WRITE or RANGE_WRITE lock.
Item - Class in com.sleepycat.asm
A constant pool item.
Item() - Constructor for class com.sleepycat.asm.Item
Constructs an uninitialized Item.
Item(int) - Constructor for class com.sleepycat.asm.Item
Constructs an uninitialized Item for constant pool element at given position.
Item(int, Item) - Constructor for class com.sleepycat.asm.Item
Constructs a copy of the given item.
items - Variable in class com.sleepycat.asm.ClassWriter
The constant pool's hash table data.
iterateDuplicates() - Method in class com.sleepycat.collections.StoredCollection
 
iterateDuplicates() - Method in class com.sleepycat.collections.StoredKeySet
 
iterator() - Method in class com.sleepycat.collections.StoredCollection
Returns an iterator over the elements in this collection.
iterator(boolean) - Method in class com.sleepycat.collections.StoredCollection
Deprecated.
Please use StoredCollection.storedIterator() or StoredCollection.storedIterator(boolean) instead. Because the iterator returned must be closed, the method name iterator is confusing since standard Java iterators do not need to be closed.
iterator(Iterator<E>) - Static method in class com.sleepycat.collections.StoredCollections
Clones an iterator preserving its current position.
iterator() - Method in class com.sleepycat.je.cleaner.PackedOffsets
Returns an iterator over all offsets.
iterator() - Method in class com.sleepycat.je.dbi.INList
Return an iterator over the main 'ins' set.
iterator() - Method in class com.sleepycat.je.rep.util.ldiff.BlockBag
Returns an iterator over the blocks in the bag, in insertion order.
iterator(Database) - Method in class com.sleepycat.je.rep.util.ldiff.LDiff
 
iterator() - Method in class com.sleepycat.je.utilint.TinyHashSet
 
iterator() - Method in class com.sleepycat.persist.BasicCursor
 
iterator(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
iterator() - Method in interface com.sleepycat.persist.EntityCursor
Returns an iterator over the key range, starting with the value following the current position or at the first value if the cursor is uninitialized.
iterator(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Returns an iterator over the key range, starting with the value following the current position or at the first value if the cursor is uninitialized.
iterator() - Method in interface com.sleepycat.persist.ForwardCursor
Returns an iterator over the key range, starting with the value following the current position or at the first value if the cursor is uninitialized.
iterator(LockMode) - Method in interface com.sleepycat.persist.ForwardCursor
Returns an iterator over the key range, starting with the value following the current position or at the first value if the cursor is uninitialized.
ITFMETH_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the INVOKEINTERFACE/INVOKEDYNAMIC instruction.
IUSHR - Static variable in interface com.sleepycat.asm.Opcodes
 
IXOR - Static variable in interface com.sleepycat.asm.Opcodes
 

J

JarMain - Class in com.sleepycat.je.utilint
Used as the main class for the manifest of the je.jar file, and so it is executed when running: java -jar je.jar.
JarMain() - Constructor for class com.sleepycat.je.utilint.JarMain
 
JDBCConnectionConfig - Class in com.sleepycat.je.sync.jdbc
Connection properties for JDBC.
JDBCConnectionConfig() - Constructor for class com.sleepycat.je.sync.jdbc.JDBCConnectionConfig
 
JDBCSyncProcessor - Class in com.sleepycat.je.sync.jdbc
 
JDBCSyncProcessor(Environment, String, JDBCConnectionConfig) - Constructor for class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
Creates a SyncProcessor for synchronizing data between JE and an external data repository via JDBC.
JE_CONSOLE_LEVEL - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
JE_DURABILITY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
JE_FILE_LEVEL - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
JE_LOGGING_DBLOG - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
JE_SUFFIX - Static variable in class com.sleepycat.je.log.FileManager
 
JE_SUFFIXES - Static variable in class com.sleepycat.je.log.FileManager
 
JE_VERSIONS_REJECT - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
JEConnection - Class in com.sleepycat.je.jca.ra
A JEConnection provides access to JE services.
JEConnection(JEManagedConnection) - Constructor for class com.sleepycat.je.jca.ra.JEConnection
 
JEConnectionFactory - Interface in com.sleepycat.je.jca.ra
An application may obtain a JEConnection in this manner:
JEConnectionFactoryImpl - Class in com.sleepycat.je.jca.ra
 
JEConnectionFactoryImpl(ConnectionManager, ManagedConnectionFactory) - Constructor for class com.sleepycat.je.jca.ra.JEConnectionFactoryImpl
 
JEConnectionMetaData - Class in com.sleepycat.je.jca.ra
 
JEConnectionMetaData() - Constructor for class com.sleepycat.je.jca.ra.JEConnectionMetaData
 
JEDiagnostics - Class in com.sleepycat.je.jmx
JEDiagnostics is a debugging mbean for a non replicated JE Environment.
JEDiagnostics(Environment) - Constructor for class com.sleepycat.je.jmx.JEDiagnostics
 
JEDiagnostics() - Constructor for class com.sleepycat.je.jmx.JEDiagnostics
 
JEException - Exception in com.sleepycat.je.jca.ra
 
JEException(String) - Constructor for exception com.sleepycat.je.jca.ra.JEException
 
JEFileFilter - Class in com.sleepycat.je.log
JEFileFilters are used for listing je files.
JEFileFilter(String[]) - Constructor for class com.sleepycat.je.log.JEFileFilter
 
JEFileFilter(String[], long) - Constructor for class com.sleepycat.je.log.JEFileFilter
 
JEFileFilter(String[], long, long) - Constructor for class com.sleepycat.je.log.JEFileFilter
 
JELocalTransaction - Class in com.sleepycat.je.jca.ra
 
JELocalTransaction(XAEnvironment, TransactionConfig, JEManagedConnection) - Constructor for class com.sleepycat.je.jca.ra.JELocalTransaction
 
JEManagedConnection - Class in com.sleepycat.je.jca.ra
 
JEManagedConnection(Subject, JERequestInfo) - Constructor for class com.sleepycat.je.jca.ra.JEManagedConnection
 
JEManagedConnectionFactory - Class in com.sleepycat.je.jca.ra
 
JEManagedConnectionFactory() - Constructor for class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
JEMBean - Class in com.sleepycat.je.jmx
 
JEMBean(Environment) - Constructor for class com.sleepycat.je.jmx.JEMBean
 
JEMBean() - Constructor for class com.sleepycat.je.jmx.JEMBean
 
JEMBeanHelper - Class in com.sleepycat.je.jmx
Deprecated.
As of JE 4, JEMBeanHelper is deprecated in favor of the concrete MBeans available by default with a JE environment. These MBeans can be registered and enabled by the environment by setting the following JVM property: JEMonitor: This MBean provides general stats monitoring and access to basic environment level operations. JEMBeanHelper is a utility class for the MBean implementation which wants to add management of a JE environment to its capabilities. MBean implementations can contain a JEMBeanHelper instance to get MBean metadata for JE and to set attributes, get attributes, and invoke operations.

com.sleepycat.je.jmx.JEMonitor and the example program jmx.JEApplicationMBean are two MBean implementations which provide support different application use cases. See those classes for examples of how to use JEMBeanHelper.

JEMBeanHelper(File, boolean) - Constructor for class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Instantiate a helper, specifying environment home and open capabilities.
JEMonitor - Class in com.sleepycat.je.jmx
JEMonitor is a JMX MBean which makes statistics and basic administrative operations available.
JEMonitor(Environment) - Constructor for class com.sleepycat.je.jmx.JEMonitor
 
JEMonitor() - Constructor for class com.sleepycat.je.jmx.JEMonitor
 
jeName - Variable in class com.sleepycat.je.jmx.JEMBean
 
JERequestInfo - Class in com.sleepycat.je.jca.ra
 
JERequestInfo(File, EnvironmentConfig, TransactionConfig) - Constructor for class com.sleepycat.je.jca.ra.JERequestInfo
 
JEStats - Class in com.sleepycat.je.jmx.plugin
 
JEStats(MBeanServerConnection) - Constructor for class com.sleepycat.je.jmx.plugin.JEStats
 
JEStatsPlugin - Class in com.sleepycat.je.jmx.plugin
 
JEStatsPlugin() - Constructor for class com.sleepycat.je.jmx.plugin.JEStatsPlugin
 
JEVersion - Class in com.sleepycat.je
Berkeley DB Java Edition version information.
JEVersion(String) - Constructor for class com.sleepycat.je.JEVersion
 
join(DataView[], Object[], JoinConfig) - Method in class com.sleepycat.collections.DataView
Returns a cursor for this view that reads only records having the specified index key values.
join(DataCursor[], JoinConfig) - Method in class com.sleepycat.collections.DataView
Returns a cursor for this view that reads only records having the index key values at the specified cursors.
join(StoredContainer[], Object[], JoinConfig) - Method in class com.sleepycat.collections.StoredCollection
Returns an iterator representing an equality join of the indices and index key values specified.
JOIN - Static variable in class com.sleepycat.compat.DbCompat
 
join(Cursor[], JoinConfig) - Method in class com.sleepycat.je.Database
Creates a specialized join cursor for use in performing equality or natural joins on secondary indices.
join(Cursor[], JoinConfig) - Method in class com.sleepycat.je.SecondaryDatabase
This operation is not allowed on a secondary database.
JOIN_GROUP_REQ - Variable in class com.sleepycat.je.rep.monitor.Protocol
 
JoinConfig - Class in com.sleepycat.je
The configuration properties of a JoinCursor.
JoinConfig() - Constructor for class com.sleepycat.je.JoinConfig
Creates an instance with the system's default settings.
JoinConfigBeanInfo - Class in com.sleepycat.je
 
JoinConfigBeanInfo() - Constructor for class com.sleepycat.je.JoinConfigBeanInfo
 
JoinCursor - Class in com.sleepycat.je
A specialized join cursor for use in performing equality or natural joins on secondary indices.
JoinCursor(Locker, Database, Cursor[], JoinConfig) - Constructor for class com.sleepycat.je.JoinCursor
Creates a join cursor without parameter checking.
joinGroup(ReplicaConsistencyPolicy, QuorumPolicy) - Method in class com.sleepycat.je.rep.impl.node.RepNode
JoinGroup ensures that a RepNode is actively participating in a replication group.
joinGroup(ReplicaConsistencyPolicy, QuorumPolicy) - Method in class com.sleepycat.je.rep.impl.RepImpl
Wait for this node to join a replication group and return whether it is a MASTER or REPLICA.
JoinGroupEvent - Class in com.sleepycat.je.rep.monitor
The event generated when a node joins the group.
JoinGroupEvent(String, String, long) - Constructor for class com.sleepycat.je.rep.monitor.JoinGroupEvent
 
JoinGroupTimeouts - Class in com.sleepycat.je.rep.impl.node
Encapsulates the handling of timeouts: ENV_SETUP_TIMEOUT and ENV_UNKNOWN_STATE_TIMEOUT, used when a replicated environment handle is opened and a node joins the group.
JoinGroupTimeouts(DbConfigManager) - Constructor for class com.sleepycat.je.rep.impl.node.JoinGroupTimeouts
 
JPASyncProcessor - Class in com.sleepycat.je.sync.jdbc
 
JPASyncProcessor(String) - Constructor for class com.sleepycat.je.sync.jdbc.JPASyncProcessor
 
JSR - Static variable in class com.sleepycat.asm.Label
Indicates if this basic block ends with a JSR instruction.
JSR - Static variable in interface com.sleepycat.asm.Opcodes
 
JVMSystemUtils - Class in com.sleepycat.je.utilint
 
JVMSystemUtils() - Constructor for class com.sleepycat.je.utilint.JVMSystemUtils
 

K

keepSearching - Variable in class com.sleepycat.je.tree.SearchResult
 
key - Variable in class com.sleepycat.asm.ClassWriter
A reusable key used to look for items in the ClassWriter.items hash table.
key - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
key - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
Key - Class in com.sleepycat.je.tree
Key represents a JE B-Tree Key.
Key(byte[]) - Constructor for class com.sleepycat.je.tree.Key
Construct a new key from a byte array.
key - Variable in class com.sleepycat.persist.BasicCursor
 
Key.DumpType - Class in com.sleepycat.je.tree
 
key2 - Variable in class com.sleepycat.asm.ClassWriter
A reusable key used to look for items in the ClassWriter.items hash table.
key3 - Variable in class com.sleepycat.asm.ClassWriter
A reusable key used to look for items in the ClassWriter.items hash table.
key4 - Variable in class com.sleepycat.asm.ClassWriter
A reusable key used to look for items in the ClassWriter.items hash table.
KEY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
keyAdapter - Variable in class com.sleepycat.persist.BasicIndex
 
keyAssigner - Variable in class com.sleepycat.collections.DataView
 
keyAssigner - Variable in class com.sleepycat.persist.impl.PersistEntityBinding
 
keyBinding - Variable in class com.sleepycat.collections.DataView
 
keyBinding - Variable in class com.sleepycat.persist.BasicIndex
 
keyClass - Variable in class com.sleepycat.persist.BasicIndex
 
keyClassName(String) - Static method in class com.sleepycat.persist.impl.SimpleCatalog
 
KeyField - Annotation Type in com.sleepycat.persist.model
Indicates the sorting position of a key field in a composite key class when the Comparable interface is not implemented.
keyFormat - Variable in class com.sleepycat.persist.impl.PersistKeyBinding
 
KeyLocation - Class in com.sleepycat.persist.impl
Holder for the input and format of a key.
KeyLocation(RecordInput, Format) - Constructor for class com.sleepycat.persist.impl.KeyLocation
 
KeyRange - Class in com.sleepycat.util.keyrange
Encapsulates a key range for use with a RangeCursor.
KeyRange(Comparator<byte[]>) - Constructor for class com.sleepycat.util.keyrange.KeyRange
Creates an unconstrained key range.
KeyRangeException - Exception in com.sleepycat.util.keyrange
An exception thrown when a key is out of range.
KeyRangeException(String) - Constructor for exception com.sleepycat.util.keyrange.KeyRangeException
Creates a key range exception.
keyRangesAllowed - Variable in class com.sleepycat.collections.DataView
 
keys() - Method in class com.sleepycat.persist.BasicIndex
 
keys(Transaction, CursorConfig) - Method in class com.sleepycat.persist.BasicIndex
 
keys(K, boolean, K, boolean) - Method in class com.sleepycat.persist.BasicIndex
 
keys(Transaction, K, boolean, K, boolean, CursorConfig) - Method in class com.sleepycat.persist.BasicIndex
 
keys() - Method in interface com.sleepycat.persist.EntityIndex
Opens a cursor for traversing all keys in this index.
keys(Transaction, CursorConfig) - Method in interface com.sleepycat.persist.EntityIndex
Opens a cursor for traversing all keys in this index.
keys(K, boolean, K, boolean) - Method in interface com.sleepycat.persist.EntityIndex
Opens a cursor for traversing keys in a key range.
keys(Transaction, K, boolean, K, boolean, CursorConfig) - Method in interface com.sleepycat.persist.EntityIndex
Opens a cursor for traversing keys in a key range.
keys() - Method in class com.sleepycat.persist.EntityJoin
Opens a cursor that returns the primary keys of entities qualifying for the join.
keys(Transaction, CursorConfig) - Method in class com.sleepycat.persist.EntityJoin
Opens a cursor that returns the primary keys of entities qualifying for the join.
keys() - Method in class com.sleepycat.persist.SubIndex
 
keys(Transaction, CursorConfig) - Method in class com.sleepycat.persist.SubIndex
 
keys(PK, boolean, PK, boolean) - Method in class com.sleepycat.persist.SubIndex
 
keys(Transaction, PK, boolean, PK, boolean, CursorConfig) - Method in class com.sleepycat.persist.SubIndex
 
KeySelector<K> - Interface in com.sleepycat.persist
This is package-private to hide it until we implemented unsorted access.
keySet() - Method in class com.sleepycat.collections.StoredMap
Returns a set view of the keys contained in this map.
keySet() - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
keySetView() - Method in class com.sleepycat.collections.DataView
Return a new key-set view derived from this view by setting the entity and value binding to null.
KeysIndex<SK,PK> - Class in com.sleepycat.persist
The EntityIndex returned by SecondaryIndex.keysIndex().
KeysIndex(Database, Class<SK>, EntryBinding, Class<PK>, EntryBinding) - Constructor for class com.sleepycat.persist.KeysIndex
 
keysIndex() - Method in class com.sleepycat.persist.SecondaryIndex
Returns a read-only keys index that maps secondary key to primary key.
keysRenumbered - Variable in class com.sleepycat.collections.DataView
 
KeyValueAdapter<V> - Class in com.sleepycat.persist
A ValueAdapter where the "value" is the key (the primary key in a primary index or the secondary key in a secondary index).
KeyValueAdapter(Class<V>, EntryBinding) - Constructor for class com.sleepycat.persist.KeyValueAdapter
 
KIND - Static variable in class com.sleepycat.asm.Frame
Mask to get the kind of a frame type.

L

L2D - Static variable in interface com.sleepycat.asm.Opcodes
 
L2F - Static variable in interface com.sleepycat.asm.Opcodes
 
L2I - Static variable in interface com.sleepycat.asm.Opcodes
 
Label - Class in com.sleepycat.asm
A label represents a position in the bytecode of a method.
Label() - Constructor for class com.sleepycat.asm.Label
Constructs a new label.
LABEL_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of instructions with a 2 bytes bytecode offset label.
LABELW_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of instructions with a 4 bytes bytecode offset label.
LADD - Static variable in interface com.sleepycat.asm.Opcodes
 
lagAwait(TimeConsistencyPolicy) - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
 
LALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
LAND - Static variable in interface com.sleepycat.asm.Opcodes
 
last() - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns the last (highest) element currently in this sorted set.
last() - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns the last (highest) element currently in this sorted set.
last() - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns the last (highest) element currently in this sorted set.
last() - Method in class com.sleepycat.persist.BasicCursor
 
last(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
last() - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the last value and returns it, or returns null if the cursor range is empty.
last(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the last value and returns it, or returns null if the cursor range is empty.
lastField - Variable in class com.sleepycat.asm.ClassWriter
The fields of this class.
lastFileNumberTouched - Variable in class com.sleepycat.je.log.FileManager
 
LastFileReader - Class in com.sleepycat.je.log
LastFileReader traverses the last log file, doing checksums and looking for the end of the log.
LastFileReader(EnvironmentImpl, int) - Constructor for class com.sleepycat.je.log.LastFileReader
This file reader is always positioned at the last file.
LastFileReader(EnvironmentImpl, int, Long) - Constructor for class com.sleepycat.je.log.LastFileReader
Ctor which allows passing in the file number we want to read to the end of.
lastFileTouchedOffset - Variable in class com.sleepycat.je.log.FileManager
 
lastIndexOf(Object) - Method in class com.sleepycat.collections.StoredList
Returns the index in this list of the last occurrence of the specified element, or -1 if this list does not contain this element.
lastKey() - Method in class com.sleepycat.collections.StoredSortedMap
Returns the last (highest) element currently in this sorted map.
lastLoggedLsn - Variable in class com.sleepycat.je.txn.Txn
 
lastMethod - Variable in class com.sleepycat.asm.ClassWriter
The methods of this class.
lastModifiedTime - Variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
LASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
lastTxnEnd - Variable in exception com.sleepycat.je.rep.impl.node.Replica.HardRecoveryElectionException
 
lastUsedLsn - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
lastVLSN - Variable in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
Latch - Class in com.sleepycat.je.latch
 
Latch(String) - Constructor for class com.sleepycat.je.latch.Latch
 
latch() - Method in class com.sleepycat.je.log.FileHandle
 
latch - Variable in class com.sleepycat.je.tree.IN
 
latch(CacheMode) - Method in class com.sleepycat.je.tree.IN
Latch this node exclusive, optionally setting the generation.
latch() - Method in class com.sleepycat.je.tree.IN
Latch this node exclusive and set the generation.
LATCH_CONTENTION - Static variable in class com.sleepycat.je.latch.LatchStatDefinition
 
LATCH_NO_WAITERS - Static variable in class com.sleepycat.je.latch.LatchStatDefinition
 
LATCH_NOWAIT_SUCCESS - Static variable in class com.sleepycat.je.latch.LatchStatDefinition
 
LATCH_NOWAIT_UNSUCCESS - Static variable in class com.sleepycat.je.latch.LatchStatDefinition
 
LATCH_RELEASES - Static variable in class com.sleepycat.je.latch.LatchStatDefinition
 
LATCH_SELF_OWNED - Static variable in class com.sleepycat.je.latch.LatchStatDefinition
 
latchBIN() - Method in class com.sleepycat.je.dbi.CursorImpl
 
latchCount() - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
Used for unit tests only
latchesHeldToString() - Static method in class com.sleepycat.je.latch.LatchSupport
 
latchesHeldToString() - Method in class com.sleepycat.je.latch.LatchTable
 
latchForWrite() - Method in class com.sleepycat.je.log.LogBuffer
When modifying the buffer, acquire the readLatch.
latchNoWait() - Method in class com.sleepycat.je.log.FileHandle
 
latchNoWait(CacheMode) - Method in class com.sleepycat.je.tree.IN
Latch this node if it is not latched by another thread, optionally setting the generation if the latch succeeds.
latchNoWait() - Method in class com.sleepycat.je.tree.IN
Latch this node if it is not latched by another thread, and set the generation if the latch succeeds.
latchRootLatchExclusive() - Method in class com.sleepycat.je.tree.Tree
 
latchShared(CacheMode) - Method in class com.sleepycat.je.tree.IN
Latch this node shared, optionally setting the generation.
latchShared() - Method in class com.sleepycat.je.tree.IN
Latch this node shared and set the generation.
latchShared() - Method in class com.sleepycat.je.tree.Node
 
latchShared(CacheMode) - Method in class com.sleepycat.je.tree.Node
 
LatchStatDefinition - Class in com.sleepycat.je.latch
Per-stat Metadata for JE latch statistics.
LatchStatDefinition() - Constructor for class com.sleepycat.je.latch.LatchStatDefinition
 
LatchSupport - Class in com.sleepycat.je.latch
Class used to hold the debugging latchTable.
LatchSupport() - Constructor for class com.sleepycat.je.latch.LatchSupport
 
latchTable - Static variable in class com.sleepycat.je.latch.LatchSupport
 
LatchTable - Class in com.sleepycat.je.latch
Table of latches by thread for debugging.
LatchTable() - Constructor for class com.sleepycat.je.latch.LatchTable
 
Latency - Class in com.sleepycat.utilint
A struct holding the min, max, avg, 95th, and 99th percentile measurements for the collection of values held in a LatencyStat.
Latency(int, int, int, float, int, int, int, int) - Constructor for class com.sleepycat.utilint.Latency
 
LatencyStat - Class in com.sleepycat.utilint
A stat that keeps track of latency in milliseconds and presents average, min, max, 95th and 99th percentile values.
LatencyStat(long) - Constructor for class com.sleepycat.utilint.LatencyStat
 
lazyCompress(IN) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Do lazy compression at opportune moments.
lazyCompress(IN) - Method in class com.sleepycat.je.incomp.INCompressor
Lazily compress prior to logging a full version of a BIN; the caller is responsible for ensuring that a full version is likely to be logged next.
lazyMigrateLNs(BIN, boolean) - Method in class com.sleepycat.je.cleaner.Cleaner
This method should be called just before logging a BIN.
lazyMigration - Variable in class com.sleepycat.je.cleaner.Cleaner
 
LBF_GROUP_DESC - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
LBF_GROUP_NAME - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
LBFP_BUFFER_BYTES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
LBFP_LOG_BUFFERS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
LBFP_MISS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
LBFP_NOT_RESIDENT - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
LCMP - Static variable in interface com.sleepycat.asm.Opcodes
 
LCONST_0 - Static variable in interface com.sleepycat.asm.Opcodes
 
LCONST_1 - Static variable in interface com.sleepycat.asm.Opcodes
 
LDC - Static variable in interface com.sleepycat.asm.Opcodes
 
LDC_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the LDC instruction.
LDCW_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the LDC_W and LDC2_W instructions.
LDiff - Class in com.sleepycat.je.rep.util.ldiff
LDiff provides a mechanism for efficiently comparing two quiescent databases, typically residing on different machines connected by a network.
LDiff(LDiffConfig) - Constructor for class com.sleepycat.je.rep.util.ldiff.LDiff
Configure a new object with which to compare two databases.
LDiff.MismatchException - Exception in com.sleepycat.je.rep.util.ldiff
The exception that is thrown when a database diff detects differences.
LDiff.MismatchException(String) - Constructor for exception com.sleepycat.je.rep.util.ldiff.LDiff.MismatchException
 
LDiffConfig - Class in com.sleepycat.je.rep.util.ldiff
 
LDiffConfig() - Constructor for class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
LDiffConfigBeanInfo - Class in com.sleepycat.je.rep.util.ldiff
 
LDiffConfigBeanInfo() - Constructor for class com.sleepycat.je.rep.util.ldiff.LDiffConfigBeanInfo
 
LDiffRecordRequestException - Exception in com.sleepycat.je.rep.util.ldiff
Thrown when LDiff requesting records on remote database fails.
LDiffRecordRequestException(String) - Constructor for exception com.sleepycat.je.rep.util.ldiff.LDiffRecordRequestException
For internal use only.
LDiffService - Class in com.sleepycat.je.rep.util.ldiff
Implementation of the LDiff service that process requests from the LDiff client.
LDiffService(ServiceDispatcher, RepImpl) - Constructor for class com.sleepycat.je.rep.util.ldiff.LDiffService
 
LDiffService.LDiffServiceRunnable - Class in com.sleepycat.je.rep.util.ldiff
 
LDiffService.LDiffServiceRunnable(SocketChannel) - Constructor for class com.sleepycat.je.rep.util.ldiff.LDiffService.LDiffServiceRunnable
 
LDiffUtil - Class in com.sleepycat.je.rep.util.ldiff
 
LDiffUtil() - Constructor for class com.sleepycat.je.rep.util.ldiff.LDiffUtil
 
LDIV - Static variable in interface com.sleepycat.asm.Opcodes
 
Learner - Class in com.sleepycat.je.rep.elections
The Learner agent.
Learner(Protocol, ServiceDispatcher) - Constructor for class com.sleepycat.je.rep.elections.Learner
Creates an instance of a Learner which will listen for and propagate messages to local Listeners.
Learner(Protocol, RepNode) - Constructor for class com.sleepycat.je.rep.elections.Learner
 
Learner.Listener - Interface in com.sleepycat.je.rep.elections
 
leaseDuration - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
leaseRenewalCount - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
leases - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
leaseTimer - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
LEAVE_GROUP_REQ - Variable in class com.sleepycat.je.rep.monitor.Protocol
 
LeaveGroupEvent - Class in com.sleepycat.je.rep.monitor
The event generated when a node leaves the group.
LeaveGroupEvent(String, String, LeaveGroupEvent.LeaveReason, long, long) - Constructor for class com.sleepycat.je.rep.monitor.LeaveGroupEvent
 
LeaveGroupEvent.LeaveReason - Enum in com.sleepycat.je.rep.monitor
The reason for why the node leaves the group.
LEFT - Static variable in class com.sleepycat.je.tree.Tree.SearchType
 
len - Variable in class com.sleepycat.util.FastInputStream
 
length - Variable in class com.sleepycat.asm.ByteVector
Actual number of bytes in this vector.
length() - Method in class com.sleepycat.je.tree.INKeyRep.Default
 
length() - Method in class com.sleepycat.je.tree.INKeyRep
 
length() - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
less - Variable in class com.sleepycat.je.tree.CountEstimator.KeyRatios
 
LEVEL_MASK - Static variable in class com.sleepycat.je.tree.IN
 
LevelRecorder - Class in com.sleepycat.je.recovery
LevelRecorder is used to determine when an extra read-IN pass is needed during recovery.
LevelRecorder() - Constructor for class com.sleepycat.je.recovery.LevelRecorder
 
line - Variable in class com.sleepycat.asm.Label
The line number corresponding to this label, if known.
listFileNames(String[]) - Method in class com.sleepycat.je.log.FileManager
Find JE files.
listFileNames(long, long) - Method in class com.sleepycat.je.log.FileManager
Find .jdb files which are >= the minimimum file number and <= the maximum file number.
listFiles(File, String[], boolean) - Static method in class com.sleepycat.je.log.FileManager
Find JE files, flavor for unit test support.
listIterator() - Method in class com.sleepycat.collections.StoredList
Returns a list iterator of the elements in this list (in proper sequence).
listIterator(int) - Method in class com.sleepycat.collections.StoredList
Returns a list iterator of the elements in this list (in proper sequence), starting at the specified position in this list.
listJDBFiles() - Method in class com.sleepycat.je.log.FileManager
 
listJDBFilesInternalMultiDir(JEFileFilter) - Method in class com.sleepycat.je.log.FileManager
 
listJDBFilesInternalSingleDir(JEFileFilter) - Method in class com.sleepycat.je.log.FileManager
 
LLOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
LMUL - Static variable in interface com.sleepycat.asm.Opcodes
 
LN - Class in com.sleepycat.je.tree
An LN represents a Leaf Node in the JE tree.
LN() - Constructor for class com.sleepycat.je.tree.LN
Create an empty LN, to be filled in from the log.
LN(byte[]) - Constructor for class com.sleepycat.je.tree.LN
 
LN(DatabaseEntry) - Constructor for class com.sleepycat.je.tree.LN
 
LN(SizeofMarker, DatabaseEntry) - Constructor for class com.sleepycat.je.tree.LN
For Sizeof.
ln - Variable in class com.sleepycat.je.txn.UndoReader
 
LN.LNWriteFailureException - Exception in com.sleepycat.je.tree
 
LN.LNWriteFailureException(Locker, Exception) - Constructor for exception com.sleepycat.je.tree.LN.LNWriteFailureException
 
LN_FETCH - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
LN_FETCH_MISS - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
LN_INFO_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
LN_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
LNEG - Static variable in interface com.sleepycat.asm.Opcodes
 
LNFileReader - Class in com.sleepycat.je.log
LNFileReader scans log files for LNs.
LNFileReader(EnvironmentImpl, int, long, boolean, long, long, Long, long) - Constructor for class com.sleepycat.je.log.LNFileReader
Create this reader to start at a given LSN.
LNInfo - Class in com.sleepycat.je.cleaner
The information necessary to lookup an LN.
LNInfo(LN, DatabaseId, byte[]) - Constructor for class com.sleepycat.je.cleaner.LNInfo
 
lnKey - Variable in class com.sleepycat.je.tree.TreeLocation
 
LNLogEntry - Class in com.sleepycat.je.log.entry
LNLogEntry embodies all LN log entries.
LNLogEntry(Class<? extends LN>) - Constructor for class com.sleepycat.je.log.entry.LNLogEntry
 
LNLogEntry(LogEntryType, LN, DatabaseId, byte[], long, boolean, Txn) - Constructor for class com.sleepycat.je.log.entry.LNLogEntry
 
LNLogEntry.DupStatus - Enum in com.sleepycat.je.log.entry
 
lnSizeCorrectionFactor - Variable in class com.sleepycat.je.cleaner.Cleaner
 
load() - Method in class com.sleepycat.je.util.DbLoad
 
loadEndOfLogStat() - Method in class com.sleepycat.je.log.LogManager
 
loadEndOfLogStat() - Method in class com.sleepycat.je.log.SyncedLogManager
 
loadEndOfLogStatInternal() - Method in class com.sleepycat.je.log.LogManager
 
loadEnvImplStats(StatsConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.cleaner.Cleaner
Load stats.
loadStats() - Method in class com.sleepycat.je.cleaner.FileSelector
Loads file selection stats.
loadStats(StatsConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Retrieve and return stat information.
loadStats() - Method in class com.sleepycat.je.dbi.INList
All stats from the INList are instantaneous -- never need to be cleared.
loadStats() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.evictor.Arbiter
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.evictor.Evictor
Load stats.
loadStats(StatsConfig) - Method in class com.sleepycat.je.evictor.PrivateSelector
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.evictor.SharedSelector
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.evictor.TargetSelector
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.incomp.INCompressor
Return stats
loadStats(StatsConfig) - Method in class com.sleepycat.je.log.FileManager
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.log.FSyncManager
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.log.LogBufferPool
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.log.LogManager
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.recovery.Checkpointer
Load stats.
loadStats(StatsConfig, BtreeStats) - Method in class com.sleepycat.je.tree.Tree
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.txn.LockManager
 
loadStats(StatsConfig) - Method in class com.sleepycat.je.txn.TxnManager
 
LocalCBVLSNTracker - Class in com.sleepycat.je.rep.impl.node
The LocalCBVLSNTracker tracks this node's local CBVLSN.
LocalCBVLSNTracker(RepNode) - Constructor for class com.sleepycat.je.rep.impl.node.LocalCBVLSNTracker
 
LocalCBVLSNUpdater - Class in com.sleepycat.je.rep.impl.node
Supports updating the group database with each node's local CBVLSN when it is in the Master state.
LocalCBVLSNUpdater(NameIdPair, RepNode) - Constructor for class com.sleepycat.je.rep.impl.node.LocalCBVLSNUpdater
 
localToExternal(Object, Class, String, String) - Method in interface com.sleepycat.je.sync.FieldConverter
Converts a local field/property value to a external field/column value, or returns fromValue unchanged if no custom conversion is needed.
LocalUtilizationTracker - Class in com.sleepycat.je.cleaner
Accumulates changes to the utilization profile locally in a single thread.
LocalUtilizationTracker(EnvironmentImpl) - Constructor for class com.sleepycat.je.cleaner.LocalUtilizationTracker
 
Lock - Interface in com.sleepycat.je.txn
A Lock embodies the lock state of an LSN.
lock(LockType, Locker, boolean, boolean, MemoryBudget, int) - Method in interface com.sleepycat.je.txn.Lock
Attempts to acquire the lock and returns the LockGrantType.
lock(long, LockType, boolean, DatabaseImpl) - Method in class com.sleepycat.je.txn.Locker
Request a blocking or non-blocking lock of the given type on the given LSN.
lock(LockType, Locker, boolean, boolean, MemoryBudget, int) - Method in class com.sleepycat.je.txn.LockImpl
Attempts to acquire the lock and returns the LockGrantType.
lock(long, Locker, LockType, long, boolean, boolean, DatabaseImpl) - Method in class com.sleepycat.je.txn.LockManager
Attempt to acquire a lock of type on lsn.
lock(LockType, Locker, boolean, boolean, MemoryBudget, int) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
LOCK_N_LOCK_TABLES - Static variable in class com.sleepycat.je.EnvironmentConfig
Number of Lock Tables.
LOCK_OLD_LOCK_EXCEPTIONS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOCK_OLD_LOCK_EXCEPTIONS - Static variable in class com.sleepycat.je.EnvironmentConfig
Whether to throw old-style lock exceptions for compatibility with older JE releases.
LOCK_OWNERS - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
LOCK_READ_LOCKS - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
LOCK_REQUESTS - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
LOCK_SUBSYSTEM - Static variable in class com.sleepycat.compat.DbCompat
 
LOCK_TIMEOUT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOCK_TIMEOUT - Static variable in class com.sleepycat.je.EnvironmentConfig
The LockTimeout property.
LOCK_TOTAL - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
LOCK_WAITERS - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
LOCK_WAITS - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
LOCK_WRITE_LOCKS - Static variable in class com.sleepycat.je.txn.LockStatDefinition
 
lockAfterLsnChange(DatabaseImpl, long, long, Locker) - Static method in class com.sleepycat.je.dbi.CursorImpl
After logging a deferred-write LN during eviction/checkpoint or a migrated LN during cleaning, for every existing lock on the old LSN held by another locker, we must lock the new LSN on behalf of that locker.
lockAfterLsnChange(long, long, DatabaseImpl) - Method in class com.sleepycat.je.txn.Locker
Called when an LN is logged by an operation that will not hold the lock such as eviction/checkpoint deferred-write logging or cleaner LN migration.
lockAfterLsnChange(long, long, DatabaseImpl) - Method in class com.sleepycat.je.txn.ThreadLocker
Set the allowMultithreadedAccess mode during execution of this method because a ThreadLocker is not normally allowed to perform locking from more than one thread.
LockAttemptResult - Class in com.sleepycat.je.txn
This is just a struct to hold a multi-value return.
LockAttemptResult(Lock, LockGrantType, boolean) - Constructor for class com.sleepycat.je.txn.LockAttemptResult
 
LockConflict - Class in com.sleepycat.je.txn
LockConflict is a type safe enumeration of lock conflict types.
LockConflictException - Exception in com.sleepycat.je
The common base class for all exceptions that result from record lock conflicts during read and write operations.
LockConflictException(String) - Constructor for exception com.sleepycat.je.LockConflictException
For internal use only.
LockConflictException(Locker, String) - Constructor for exception com.sleepycat.je.LockConflictException
For internal use only.
LockConflictException(Locker, String, Throwable) - Constructor for exception com.sleepycat.je.LockConflictException
For internal use only.
LockConflictException(String, OperationFailureException) - Constructor for exception com.sleepycat.je.LockConflictException
For internal use only.
lockCurrent(LockType) - Method in class com.sleepycat.je.dbi.CursorImpl
 
lockEnvironment(boolean, boolean) - Method in class com.sleepycat.je.log.FileManager
Lock the environment.
lockEof(LockType) - Method in class com.sleepycat.je.dbi.CursorImpl
Locks the logical EOF node for the databaseImpl.
Locker - Class in com.sleepycat.je.txn
Locker instances are JE's route to locking and transactional support.
Locker(EnvironmentImpl, boolean, boolean, long) - Constructor for class com.sleepycat.je.txn.Locker
Create a locker id.
Locker() - Constructor for class com.sleepycat.je.txn.Locker
For reading from the log.
locker - Variable in class com.sleepycat.je.txn.LockInfo
 
LockerFactory - Class in com.sleepycat.je.txn
Factory of static methods for creating Locker objects.
LockerFactory() - Constructor for class com.sleepycat.je.txn.LockerFactory
 
lockGrant - Variable in class com.sleepycat.je.txn.LockAttemptResult
 
LockGrantType - Enum in com.sleepycat.je.txn
LockGrantType is an enumeration of the possible results of a lock attempt.
LockImpl - Class in com.sleepycat.je.txn
A Lock embodies the lock state of a LSN.
LockImpl() - Constructor for class com.sleepycat.je.txn.LockImpl
Create a Lock.
LockImpl(LockInfo) - Constructor for class com.sleepycat.je.txn.LockImpl
 
LOCKIMPL_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
LockInfo - Class in com.sleepycat.je.txn
LockInfo is a class that embodies information about a lock instance.
LockInfo(Locker, LockType) - Constructor for class com.sleepycat.je.txn.LockInfo
Construct a new LockInfo.
LockInfo(LockInfo) - Constructor for class com.sleepycat.je.txn.LockInfo
Clone from given LockInfo.
LOCKINFO_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
locking - Variable in class com.sleepycat.persist.BasicIndex
 
lockingRequired() - Method in class com.sleepycat.je.txn.BasicLocker
 
lockingRequired() - Method in class com.sleepycat.je.txn.Locker
Returns true if locking is required for this Locker.
lockingRequired() - Method in class com.sleepycat.je.txn.ReadCommittedLocker
ReadCommittedLockers always require locking.
lockingRequired() - Method in class com.sleepycat.je.txn.Txn
 
lockInternal(long, LockType, boolean, boolean, DatabaseImpl) - Method in class com.sleepycat.je.rep.txn.ReadonlyTxn
Provides a wrapper to screen for write locks.
lockInternal(long, LockType, boolean, boolean, DatabaseImpl) - Method in class com.sleepycat.je.rep.txn.ReplicaThreadLocker
This overridden method prevents writes on a replica.
lockInternal(long, LockType, boolean, boolean, DatabaseImpl) - Method in class com.sleepycat.je.txn.BasicLocker
 
lockInternal(long, LockType, boolean, boolean, DatabaseImpl) - Method in class com.sleepycat.je.txn.Locker
Abstract method to a blocking or non-blocking lock of the given type on the given LSN.
lockInternal(long, LockType, boolean, boolean, DatabaseImpl) - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Forwards write locks to the buddy locker (the transaction locker).
lockInternal(long, LockType, boolean, boolean, DatabaseImpl) - Method in class com.sleepycat.je.txn.Txn
Gets a lock on this LSN and, if it is a write lock, saves an abort LSN.
lockLN(LockType) - Method in class com.sleepycat.je.dbi.CursorImpl
Does not allow uncontended locks.
lockLN(LockType, boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
Locks the LN at the cursor position.
lockManager - Variable in class com.sleepycat.je.txn.Locker
 
LockManager - Class in com.sleepycat.je.txn
LockManager manages locks.
LockManager(EnvironmentImpl) - Constructor for class com.sleepycat.je.txn.LockManager
 
LockMode - Enum in com.sleepycat.je
Record lock modes for read operations.
lockNextKeyForInsert(DatabaseEntry) - Method in class com.sleepycat.je.dbi.CursorImpl
Search for the next key following the given key, and acquire a range insert lock on it.
LockNotAvailableException - Exception in com.sleepycat.je
Thrown when a non-blocking operation fails to get a lock.
LockNotAvailableException(Locker, String) - Constructor for exception com.sleepycat.je.LockNotAvailableException
For internal use only.
LockNotGrantedException - Exception in com.sleepycat.je
Deprecated.
LockNotGrantedException(Locker, String) - Constructor for exception com.sleepycat.je.LockNotGrantedException
Deprecated.
For internal use only.
lockOnce() - Method in class com.sleepycat.je.rep.txn.MasterTxn
Determines whether we should lock the block-latch lock.
LockPreemptedException - Exception in com.sleepycat.je.rep
Thrown when a lock has been "stolen", or preempted, from a transaction in a replicated environment.
LockPreemptedException(Locker, Throwable) - Constructor for exception com.sleepycat.je.rep.LockPreemptedException
For internal use only.
LockResult - Class in com.sleepycat.je.txn
This class is a container to encapsulate a LockGrantType and a WriteLockInfo so that they can both be returned from writeLock.
LockResult(LockGrantType, WriteLockInfo) - Constructor for class com.sleepycat.je.txn.LockResult
 
lockStat(StatsConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Retrieve lock statistics
lockStat(StatsConfig) - Method in class com.sleepycat.je.txn.LockManager
Statistics
lockStat(StatsConfig) - Method in class com.sleepycat.je.txn.TxnManager
Collect lock related stats.
LockStatDefinition - Class in com.sleepycat.je.txn
Per-stat Metadata for JE lock statistics.
LockStatDefinition() - Constructor for class com.sleepycat.je.txn.LockStatDefinition
 
LockStats - Class in com.sleepycat.je
Deprecated.
as of 4.0.10, replaced by Environment.getStats(StatsConfig).

LockStats(StatGroup, StatGroup, StatGroup) - Constructor for class com.sleepycat.je.LockStats
Deprecated.
 
lockTableLatches - Variable in class com.sleepycat.je.txn.LockManager
 
lockTimeout - Variable in class com.sleepycat.je.cleaner.Cleaner
 
LockTimeoutException - Exception in com.sleepycat.je
Thrown when multiple threads are competing for a lock and the lock timeout interval is exceeded for the current thread.
LockTimeoutException(Locker, String) - Constructor for exception com.sleepycat.je.LockTimeoutException
For internal use only.
lockType - Variable in class com.sleepycat.je.txn.LockInfo
 
LockType - Class in com.sleepycat.je.txn
LockType is a type safe enumeration of all lock types.
LockUpgrade - Class in com.sleepycat.je.txn
LockUpgrade is a type safe enumeration of lock upgrade types.
log(LogEntry, ReplicationContext) - Method in class com.sleepycat.je.log.LogManager
Write a log entry.
log(LogEntry, boolean, boolean, long, DatabaseImpl, ReplicationContext) - Method in class com.sleepycat.je.log.LogManager
Write a log entry.
log(LogEntry, Provisional, boolean, long, DatabaseImpl, ReplicationContext) - Method in class com.sleepycat.je.log.LogManager
Write a log entry.
log(LogItem, LogContext) - Method in class com.sleepycat.je.log.LogManager
Convenience method for logging a single entry.
log(LogManager) - Method in class com.sleepycat.je.tree.IN
Log this IN and clear the dirty flag.
log(LogManager, boolean, boolean, boolean, boolean, IN) - Method in class com.sleepycat.je.tree.IN
Log this node with all available options.
log(LogManager, boolean, boolean, Provisional, boolean, IN) - Method in class com.sleepycat.je.tree.IN
 
log(EnvironmentImpl, DatabaseImpl, byte[], long, boolean, ReplicationContext) - Method in class com.sleepycat.je.tree.LN
Convenience logging method.
log(EnvironmentImpl, DatabaseImpl, byte[], long, Locker, WriteLockInfo, ReplicationContext) - Method in class com.sleepycat.je.tree.LN
Convenience logging method.
LOG_BIN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_BIN_DELTA - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_BUFFER_MAX_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_BUFFER_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
The maximum starting size of a JE log buffer.
LOG_CHECKSUM_READ - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_CHECKSUM_READ - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, perform a checksum check when reading entries from log.
LOG_CHUNKED_NIO - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_CHUNKED_NIO - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
NIO is no longer used by JE and this parameter has no effect.
LOG_CKPT_END - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_CKPT_START - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DBIN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DBTREE - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DEFERREDWRITE_TEMP - Static variable in class com.sleepycat.je.config.EnvironmentParams
Deprecated.
As of 3.3, no longer used Optimize cleaner operation for temporary deferred write DBs.
LOG_DEL_DUPLN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DEL_DUPLN_TRANSACTIONAL - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DEL_LN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DEL_LN_TRANSACTIONAL - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DIN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DIRECT_NIO - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_DIRECT_NIO - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
NIO is no longer used by JE and this parameter has no effect.
LOG_DUP_BIN_DELTA - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DUPCOUNTLN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_DUPCOUNTLN_TRANSACTIONAL - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_FAULT_READ_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_FAULT_READ_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
The buffer size for faulting in objects from disk, in bytes.
LOG_FILE_CACHE_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_FILE_CACHE_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
The size of the file handle cache.
LOG_FILE_HEADER - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_FILE_MAX - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_FILE_MAX - Static variable in class com.sleepycat.je.EnvironmentConfig
The maximum size of each individual JE log file, in bytes.
LOG_FILESUMMARYLN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_FLUSH_TASK_INTERVAL - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
LOG_FLUSH_TASK_INTERVAL - Static variable in class com.sleepycat.je.rep.ReplicationMutableConfig
The interval that JE HA will do a log buffer flush.
LOG_FSYNC_TIMEOUT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_FSYNC_TIMEOUT - Static variable in class com.sleepycat.je.EnvironmentConfig
The timeout limit for group file sync, in microseconds.
LOG_IN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_IN_DELETE_INFO - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_IN_DUPDELETE_INFO - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_INS_LN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_INS_LN_TRANSACTIONAL - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_ITERATOR_MAX_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_ITERATOR_MAX_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
The maximum read buffer size for log iterators, which are used when scanning the log during activities like log cleaning and environment open, in bytes.
LOG_ITERATOR_READ_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_ITERATOR_READ_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
The read buffer size for log iterators, which are used when scanning the log during activities like log cleaning and environment open, in bytes.
LOG_MAPLN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_MAPLN_TRANSACTIONAL - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_MATCHPOINT - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_MEM_ONLY - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, operates in an in-memory test mode without flushing the log to disk.
LOG_MEM_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_MEM_SIZE_MIN - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_MEM_SIZE_MIN_STRING - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_MEMORY_ONLY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_N_DATA_DIRECTORIES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_N_DATA_DIRECTORIES - Static variable in class com.sleepycat.je.EnvironmentConfig
The JE environment can be spread across multiple subdirectories.
LOG_NAMELN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_NAMELN_TRANSACTIONAL - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_NUM_BUFFERS - Static variable in class com.sleepycat.je.EnvironmentConfig
The number of JE log buffers.
LOG_OLD_LN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_OLD_LN_TRANSACTIONAL - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_ROLLBACK_END - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_ROLLBACK_START - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_SIZE - Static variable in class com.sleepycat.je.utilint.VLSN
 
LOG_TOTAL_BUFFER_BYTES - Static variable in class com.sleepycat.je.EnvironmentConfig
The total memory taken by log buffers, in bytes.
LOG_TRACE - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_TXN_ABORT - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_TXN_COMMIT - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_TXN_PREPARE - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_UPD_LN - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_UPD_LN_TRANSACTIONAL - Static variable in class com.sleepycat.je.log.LogEntryType
 
LOG_USE_NIO - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_USE_NIO - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
NIO is no longer used by JE and this parameter has no effect.
LOG_USE_ODSYNC - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_USE_ODSYNC - Static variable in class com.sleepycat.je.EnvironmentConfig
If true (default is false) O_DSYNC is used to open JE log files.
LOG_USE_WRITE_QUEUE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_USE_WRITE_QUEUE - Static variable in class com.sleepycat.je.EnvironmentConfig
If true (default is true) the Write Queue is used for file I/O operations which are blocked by concurrent I/O operations.
LOG_VERIFY_CHECKSUMS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_VERIFY_CHECKSUMS - Static variable in class com.sleepycat.je.EnvironmentConfig
If true, perform a checksum verification just before and after writing to the log.
LOG_VERSION - Static variable in class com.sleepycat.je.log.LogEntryType
Version of the file header, which identifies the version of all entries in that file.
LOG_WRITE_QUEUE_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
LOG_WRITE_QUEUE_SIZE - Static variable in class com.sleepycat.je.EnvironmentConfig
The size of the Write Queue.
LogBuffer - Class in com.sleepycat.je.log
LogBuffers hold outgoing, newly written log entries.
LogBuffer(int, EnvironmentImpl) - Constructor for class com.sleepycat.je.log.LogBuffer
 
LogBuffer(ByteBuffer, long) - Constructor for class com.sleepycat.je.log.LogBuffer
 
LogBufferPool - Class in com.sleepycat.je.log
LogBufferPool keeps a set of log buffers.
LogBufferPool(FileManager, EnvironmentImpl) - Constructor for class com.sleepycat.je.log.LogBufferPool
 
logBufferPool - Variable in class com.sleepycat.je.log.LogManager
 
LogChangeReader - Class in com.sleepycat.je.sync.impl
 
LogChangeReader(Environment, String, SyncProcessor, boolean, long) - Constructor for class com.sleepycat.je.sync.impl.LogChangeReader
 
LogChangeReader.DbInfo - Class in com.sleepycat.je.sync.impl
 
LogChangeReader.DbInfo(String, boolean) - Constructor for class com.sleepycat.je.sync.impl.LogChangeReader.DbInfo
 
LogChangeReader.JEChange - Class in com.sleepycat.je.sync.impl
 
LogChangeReader.JEChange(ChangeReader.ChangeType, DatabaseEntry, DatabaseEntry, String) - Constructor for class com.sleepycat.je.sync.impl.LogChangeReader.JEChange
 
LogChangeReader.JEChangeTxn - Class in com.sleepycat.je.sync.impl
 
LogChangeReader.JEChangeTxn(long, long) - Constructor for class com.sleepycat.je.sync.impl.LogChangeReader.JEChangeTxn
 
LogChangeReader.LogChangeIterator - Class in com.sleepycat.je.sync.impl
 
LogChangeReader.LogChangeIterator() - Constructor for class com.sleepycat.je.sync.impl.LogChangeReader.LogChangeIterator
 
LogChangeSet - Class in com.sleepycat.je.sync.impl
 
LogChangeSet() - Constructor for class com.sleepycat.je.sync.impl.LogChangeSet
 
LogChangeSet(long, long) - Constructor for class com.sleepycat.je.sync.impl.LogChangeSet
 
LogChangeSet.LogChangeSetBinding - Class in com.sleepycat.je.sync.impl
 
LogChangeSet.LogChangeSetBinding() - Constructor for class com.sleepycat.je.sync.impl.LogChangeSet.LogChangeSetBinding
 
LogContext - Class in com.sleepycat.je.log
Context parameters that apply to all logged items when multiple items are logged in one log operation.
LogContext() - Constructor for class com.sleepycat.je.log.LogContext
 
logDirtyChildren() - Method in class com.sleepycat.je.tree.BIN
 
logDirtyChildren() - Method in class com.sleepycat.je.tree.IN
When splits and checkpoints intermingle in a deferred write databases, a checkpoint target may appear which has a valid target but a null LSN.
LogEntry - Interface in com.sleepycat.je.log.entry
A Log entry allows you to read, write and dump a database log entry.
logEntry - Variable in class com.sleepycat.je.txn.UndoReader
 
LogEntryHeader - Class in com.sleepycat.je.log
A LogEntryHeader embodies the header information at the beginning of each log entry file.
LogEntryHeader(ByteBuffer, int) - Constructor for class com.sleepycat.je.log.LogEntryHeader
For reading a log entry.
LogEntryHeader(LogEntry, Provisional, ReplicationContext) - Constructor for class com.sleepycat.je.log.LogEntryHeader
For writing a log header.
LogEntryHeader(byte, int, int, VLSN) - Constructor for class com.sleepycat.je.log.LogEntryHeader
For reading a replication message.
LogEntryType - Class in com.sleepycat.je.log
LogEntryType is an enumeration of all log entry types.
LogEntryType(byte) - Constructor for class com.sleepycat.je.log.LogEntryType
For base class support.
LogEntryType.Marshall - Enum in com.sleepycat.je.log
 
LogEntryType.NodeType - Enum in com.sleepycat.je.log
 
LogEntryType.Replicable - Enum in com.sleepycat.je.log
 
LogEntryType.Txnal - Enum in com.sleepycat.je.log
 
LogFileFeeder - Class in com.sleepycat.je.rep.impl.networkRestore
The LogFileFeeder supplies log files to a client.
LogFileFeeder(FeederManager, SocketChannel) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.LogFileFeeder
 
logFine(String, Node, long, boolean, boolean, boolean) - Method in class com.sleepycat.je.cleaner.Cleaner
Send trace messages to the java.util.logger.
LogFlusher - Class in com.sleepycat.je.rep.impl.node
We decide to move the default durability for replication to NO_SYNC, which requires flushing the write buffer periodically to make sure those updates are durable on the disk.
LogFlusher(RepNode, Timer) - Constructor for class com.sleepycat.je.rep.impl.node.LogFlusher
 
LogFlusher.LogFlushTask - Class in com.sleepycat.je.rep.impl.node
 
LogFlusher.LogFlushTask(RepNode) - Constructor for class com.sleepycat.je.rep.impl.node.LogFlusher.LogFlushTask
 
logForceFlip(LogEntry) - Method in class com.sleepycat.je.log.LogManager
Log this single object and force a flip of the log files.
logForceFlush(LogEntry, boolean, ReplicationContext) - Method in class com.sleepycat.je.log.LogManager
Log this single object and force a write of the log files.
Loggable - Interface in com.sleepycat.je.log
A class that implements Loggable knows how to read and write itself into a ByteBuffer in a format suitable for the JE log or JE replication messages.
logger - Variable in class com.sleepycat.je.Database
 
logger - Variable in class com.sleepycat.je.log.FileReader
 
logger - Variable in class com.sleepycat.je.rep.elections.ElectionAgentThread
 
logger - Variable in class com.sleepycat.je.rep.elections.Proposer
 
logger - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
logger - Variable in class com.sleepycat.je.rep.impl.node.RepNode
 
logger - Variable in class com.sleepycat.je.rep.impl.TextProtocol
 
logger - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
logger - Variable in class com.sleepycat.je.utilint.DaemonThread
 
LoggerUtils - Class in com.sleepycat.je.utilint
Logging Architecture =========================== JE uses the java.util.logging package.
LoggerUtils() - Constructor for class com.sleepycat.je.utilint.LoggerUtils
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
Not used.
logicalEquals(Loggable) - Method in class com.sleepycat.je.cleaner.DbFileSummary
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.cleaner.FileSummary
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.cleaner.PackedOffsets
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.dbi.DatabaseId
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.dbi.DbTree
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
 
logicalEquals(Loggable) - Method in enum com.sleepycat.je.log.entry.DbOperationType
 
logicalEquals(LogEntry) - Method in class com.sleepycat.je.log.entry.INLogEntry
 
logicalEquals(LogEntry) - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
logicalEquals(LogEntry) - Method in interface com.sleepycat.je.log.entry.LogEntry
 
logicalEquals(LogEntry) - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
 
logicalEquals(LogEntry) - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.log.FileHeader
 
logicalEquals(Loggable) - Method in interface com.sleepycat.je.log.Loggable
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.log.Trace
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.recovery.CheckpointStart
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.BINDelta
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.ChildReference
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.DeltaInfo
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.FileSummaryLN
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.IN
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.LN
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.MapLN
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.NameLN
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.tree.Tree
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.txn.RollbackEnd
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.txn.RollbackStart
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.txn.Txn
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.txn.TxnAbort
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.txn.TxnCommit
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.txn.TxnPrepare
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.utilint.Matchpoint
 
logicalEquals(Loggable) - Method in class com.sleepycat.je.utilint.VLSN
 
logicalEqualsIgnoreVersion(LogEntryHeader) - Method in class com.sleepycat.je.log.LogEntryHeader
 
LogItem - Class in com.sleepycat.je.log
Item parameters that apply to a single logged item.
LogItem() - Constructor for class com.sleepycat.je.log.LogItem
 
LogItemCache - Class in com.sleepycat.je.rep.vlsn
A no-wait cache used to retain the most recent VLSNs.
LogItemCache(int, StatGroup) - Constructor for class com.sleepycat.je.rep.vlsn.LogItemCache
Creates a log item size of the specified size.
logLazily(LogEntry, ReplicationContext) - Method in class com.sleepycat.je.log.LogManager
Write a log entry lazily.
LogManager - Class in com.sleepycat.je.log
The LogManager supports reading and writing to the JE log.
LogManager(EnvironmentImpl, boolean) - Constructor for class com.sleepycat.je.log.LogManager
There is a single log manager per database environment.
logMapTreeRoot() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Logs the map tree root and saves the LSN.
logMapTreeRoot(long) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Logs the map tree root, but only if its current LSN is before the ifBeforeLsn parameter or ifBeforeLsn is NULL_LSN.
logMessage(String) - Method in class com.sleepycat.je.rep.impl.GroupService.GroupServiceRunnable
 
logMessage(String) - Method in class com.sleepycat.je.rep.impl.NodeStateService.NodeStateServiceRunnable
 
logMessage(String) - Method in class com.sleepycat.je.rep.monitor.MonitorService.MonitorServiceRunnable
 
logMessage(String) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingRunnable
 
LOGMGR_END_OF_LOG - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
LOGMGR_REPEAT_FAULT_READS - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
LOGMGR_TEMP_BUFFER_WRITES - Static variable in class com.sleepycat.je.log.LogStatDefinition
 
logMsg(Logger, EnvironmentImpl, Level, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Log a message using this logger.
logMsg(Logger, EnvironmentImpl, Formatter, Level, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Log a message using this logger.
logMsg(Logger, Formatter, Level, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Log a message with this logger.
LogOverwriteException - Exception in com.sleepycat.je.rep
Thrown when one or more log files are modified (overwritten) as the result of a replication operation.
LogOverwriteException(String) - Constructor for exception com.sleepycat.je.rep.LogOverwriteException
For internal use only.
logSize(byte[][]) - Static method in class com.sleepycat.je.dbi.TriggerUtils
Determines the size in bytes used to represent the trigger in the log, that is, the size of the output generated by TriggerUtils.writeTriggers(ByteBuffer, byte[][])
LogSource - Interface in com.sleepycat.je.log
A class that implements LogSource can return portions of the log.
LogStatDefinition - Class in com.sleepycat.je.log
Per-stat Metadata for JE FileManager, FSyncManager, LogManager and LogBufferPool statistics.
LogStatDefinition() - Constructor for class com.sleepycat.je.log.LogStatDefinition
 
logStats() - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
 
LogUtils - Class in com.sleepycat.je.log
This class holds convenience methods for marshalling internal JE data to and from the log.
LogUtils() - Constructor for class com.sleepycat.je.log.LogUtils
 
LogUtils.XidImpl - Class in com.sleepycat.je.log
 
LogUtils.XidImpl(int, byte[], byte[]) - Constructor for class com.sleepycat.je.log.LogUtils.XidImpl
 
LogVerificationException - Exception in com.sleepycat.je.util
Thrown during log verification if a checksum cannot be verified or a log entry is determined to be invalid by examining its contents.
LogVerificationException(String) - Constructor for exception com.sleepycat.je.util.LogVerificationException
 
LogVerificationException(String, Throwable) - Constructor for exception com.sleepycat.je.util.LogVerificationException
 
LogVerificationInputStream - Class in com.sleepycat.je.util
Verifies the checksums in an InputStream for a log file in a JE Environment.
LogVerificationInputStream(Environment, InputStream, String) - Constructor for class com.sleepycat.je.util.LogVerificationInputStream
Creates a verification input stream.
LogVerificationInputStream(EnvironmentImpl, InputStream, String, long) - Constructor for class com.sleepycat.je.util.LogVerificationInputStream
Internal constructor.
LOGWRITE_EXCEPTION_TESTING - Static variable in class com.sleepycat.je.log.FileManager
 
LogWriteException - Exception in com.sleepycat.je
Thrown when an IOException or other failure occurs when writing to the JE log.
LogWriteException(EnvironmentImpl, String) - Constructor for exception com.sleepycat.je.LogWriteException
For internal use only.
LogWriteException(EnvironmentImpl, Throwable) - Constructor for exception com.sleepycat.je.LogWriteException
For internal use only.
LogWriteException(EnvironmentImpl, String, Throwable) - Constructor for exception com.sleepycat.je.LogWriteException
For internal use only.
logWriteLatch - Variable in class com.sleepycat.je.log.LogManager
 
LONG - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_Long constant pool items.
LONG - Static variable in class com.sleepycat.asm.Frame
The LONG type.
LONG - Static variable in interface com.sleepycat.asm.Opcodes
 
LONG - Static variable in class com.sleepycat.asm.Type
The sort of the long type.
LONG_BYTES - Static variable in class com.sleepycat.je.log.LogUtils
 
LONG_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
LONG_TYPE - Static variable in class com.sleepycat.asm.Type
The long type.
LongArrayStat - Class in com.sleepycat.je.utilint
A Long array JE stat.
LongArrayStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.LongArrayStat
 
LongArrayStat(StatGroup, StatDefinition, long[]) - Constructor for class com.sleepycat.je.utilint.LongArrayStat
 
LongBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a Long primitive wrapper or a long primitive.
LongBinding() - Constructor for class com.sleepycat.bind.tuple.LongBinding
 
LongConfigParam - Class in com.sleepycat.je.config
A JE configuration parameter with an integer value.
LongConfigParam(String, Long, Long, Long, boolean, boolean) - Constructor for class com.sleepycat.je.config.LongConfigParam
 
LongMaxStat - Class in com.sleepycat.je.utilint
A long stat which maintains a maximum value.
LongMaxStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.LongMaxStat
 
LongMaxStat(StatGroup, StatDefinition, long) - Constructor for class com.sleepycat.je.utilint.LongMaxStat
 
LongMaxZeroStat - Class in com.sleepycat.je.rep.utilint
For stats where the min value in the range is zero, so that sums, averages, etc.
LongMaxZeroStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.rep.utilint.LongMaxZeroStat
 
LongMinStat - Class in com.sleepycat.je.utilint
A long stat which maintains a minimum value.
LongMinStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.LongMinStat
 
LongMinStat(StatGroup, StatDefinition, long) - Constructor for class com.sleepycat.je.utilint.LongMinStat
 
LongMinZeroStat - Class in com.sleepycat.je.rep.utilint
For stats where the min value in the range is zero, so that sums, averages, etc.
LongMinZeroStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.rep.utilint.LongMinZeroStat
 
LongStat - Class in com.sleepycat.je.utilint
A long JE stat.
LongStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.LongStat
 
LongStat(StatGroup, StatDefinition, long) - Constructor for class com.sleepycat.je.utilint.LongStat
 
longToEntry(long, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.LongBinding
Converts a simple long value into an entry buffer.
longToEntry(long, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.PackedLongBinding
Converts a simple Long value into an entry buffer, using PackedLong format.
longToEntry(long, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.SortedPackedLongBinding
Converts a simple Long value into an entry buffer, using SortedPackedLong format.
longToLsn(Long) - Static method in class com.sleepycat.je.utilint.DbLsn
 
longVal - Variable in class com.sleepycat.asm.Item
Value of this item, for a long item.
LOOK_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the LOOKUPSWITCH instruction.
lookAheadCacheSize - Variable in class com.sleepycat.je.cleaner.Cleaner
 
lookupLock(Long) - Method in class com.sleepycat.je.txn.DummyLockManager
 
lookupLock(Long) - Method in class com.sleepycat.je.txn.LockManager
 
lookupLock(Long) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
lookupLockInternal(Long, int) - Method in class com.sleepycat.je.txn.LockManager
 
LOOKUPSWITCH - Static variable in interface com.sleepycat.asm.Opcodes
 
LOR - Static variable in interface com.sleepycat.asm.Opcodes
 
LREM - Static variable in interface com.sleepycat.asm.Opcodes
 
LRETURN - Static variable in interface com.sleepycat.asm.Opcodes
 
LSHL - Static variable in interface com.sleepycat.asm.Opcodes
 
LSHR - Static variable in interface com.sleepycat.asm.Opcodes
 
lsn - Variable in class com.sleepycat.je.rep.stream.MatchpointSearchResults.PassedTxnInfo
 
lsn - Variable in class com.sleepycat.je.tree.TrackingInfo
 
LSNAccumulator - Class in com.sleepycat.je.dbi
 
LSNAccumulator(SortedLSNTreeWalker) - Constructor for class com.sleepycat.je.dbi.LSNAccumulator
 
LSNStat - Class in com.sleepycat.je.utilint
A long JE stat.
LSNStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.LSNStat
 
LSNStat(StatGroup, StatDefinition, long) - Constructor for class com.sleepycat.je.utilint.LSNStat
 
LSTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
LSUB - Static variable in interface com.sleepycat.asm.Opcodes
 
LUSHR - Static variable in interface com.sleepycat.asm.Opcodes
 
LXOR - Static variable in interface com.sleepycat.asm.Opcodes
 

M

main(String[]) - Static method in class com.sleepycat.je.rep.util.DbEnableReplication
Usage:
main(String...) - Static method in class com.sleepycat.je.rep.util.DbGroupAdmin
Usage:
main(String[]) - Static method in class com.sleepycat.je.rep.util.DbPing
Usage:
main(String[]) - Static method in class com.sleepycat.je.rep.util.DbResetRepGroup
Usage:
main(String[]) - Static method in class com.sleepycat.je.rep.util.ldiff.LDiff
The main used by the LDiff utility.
main(String[]) - Static method in class com.sleepycat.je.rep.utilint.DbDumpGroup
 
main(String[]) - Static method in class com.sleepycat.je.rep.utilint.DbFeederPrintLog
 
main(String[]) - Static method in class com.sleepycat.je.rep.utilint.DbNullNode
 
main(String[]) - Static method in class com.sleepycat.je.rep.utilint.DbRepRunAction
 
main(String[]) - Static method in class com.sleepycat.je.rep.utilint.DbStreamVerify
 
main(String[]) - Static method in class com.sleepycat.je.rep.utilint.DbSync
 
main(String[]) - Static method in class com.sleepycat.je.util.DbCacheSize
Runs DbCacheSize as a command line utility.
main(String[]) - Static method in class com.sleepycat.je.util.DbDump
The main used by the DbDump utility.
main(String[]) - Static method in class com.sleepycat.je.util.DbLoad
The main used by the DbLoad utility.
main(String[]) - Static method in class com.sleepycat.je.util.DbPrintLog
The main used by the DbPrintLog utility.
main(String[]) - Static method in class com.sleepycat.je.util.DbRunAction
 
main(String[]) - Static method in class com.sleepycat.je.util.DbSpace
 
main(String[]) - Static method in class com.sleepycat.je.util.DbStat
 
main(String[]) - Static method in class com.sleepycat.je.util.DbTruncateLog
Usage:
main(String[]) - Static method in class com.sleepycat.je.util.DbVerify
The main used by the DbVerify utility.
main(String[]) - Static method in class com.sleepycat.je.util.DbVerifyLog
 
main(String[]) - Static method in class com.sleepycat.je.utilint.JarMain
 
main(String[]) - Static method in class com.sleepycat.persist.model.ClassEnhancer
Enhances classes in the directories specified.
MAIN_LEVEL - Static variable in class com.sleepycat.je.tree.IN
 
makeChecksum() - Static method in class com.sleepycat.je.utilint.Adler32
 
makeConsistent() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Used to ensure that the ReplicationGroup value is consistent after it has been fetched via a readUncommitted access to the rep group database.
makeCursor(DatabaseImpl, Locker, CursorConfig) - Static method in class com.sleepycat.je.DbInternal
Create a Cursor for internal use from a DatabaseImpl.
makeDateFormat() - Static method in class com.sleepycat.je.utilint.TracerFormatter
 
makeDeleted() - Method in class com.sleepycat.je.tree.FileSummaryLN
Clear out the obsoleteOffsets to save memory when the LN is deleted.
makeDeleted() - Method in class com.sleepycat.je.tree.LN
 
makeDeleted() - Method in class com.sleepycat.je.tree.MapLN
 
makeDeleted() - Method in class com.sleepycat.je.tree.NameLN
 
makeDeletedLN() - Static method in class com.sleepycat.je.tree.FileSummaryLN
Creates a deleted FileSummaryLN.
makeEnvironment() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
makeEnvironmentImpl(File, EnvironmentConfig, boolean, RepConfigProxy) - Method in class com.sleepycat.je.Environment
 
makeExceptionEvent(Exception, String) - Static method in class com.sleepycat.je.DbInternal
 
makeFeederDeathEvent(String) - Static method in class com.sleepycat.je.rep.impl.node.MasterTransfer.VLSNProgress
 
makeFetchErrorMsg(String, IN, long, byte) - Static method in class com.sleepycat.je.tree.IN
 
makeFullKey(long, int) - Static method in class com.sleepycat.je.tree.FileSummaryLN
Returns the full two-part key for a given file number and unique sequence.
makeInvisible(long, List<Long>) - Method in class com.sleepycat.je.log.FileManager
Mark the specified log entries as invisible and obsolete.
makeInvisible(byte) - Static method in class com.sleepycat.je.log.LogEntryHeader
Set the invisible bit in the given log entry flags.
makeInvisible(EnvironmentImpl, List<Long>) - Static method in class com.sleepycat.je.recovery.RollbackTracker
 
makeIteratorData(BaseIterator, DataCursor) - Method in class com.sleepycat.collections.StoredCollection
 
makeIteratorData(BaseIterator, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.collections.StoredCollection
 
makeIteratorData(BaseIterator, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.collections.StoredEntrySet
 
makeIteratorData(BaseIterator, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.collections.StoredKeySet
 
makeIteratorData(BaseIterator, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.collections.StoredList
 
makeIteratorData(BaseIterator, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.collections.StoredValueSet
 
makeJavaErrorWrapper() - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
makeKey(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.collections.DataView
Converts a key entry to a key object.
makeKey(DatabaseEntry) - Static method in class com.sleepycat.je.tree.Key
 
makeLN(EnvironmentImpl, byte[]) - Static method in class com.sleepycat.je.tree.LN
Create a new LN from a byte array.
makeLN(EnvironmentImpl, DatabaseEntry) - Static method in class com.sleepycat.je.tree.LN
Create a new LN from a DatabaseEntry.
makeLsn(long, long) - Static method in class com.sleepycat.je.utilint.DbLsn
 
makeLsn(long, int) - Static method in class com.sleepycat.je.utilint.DbLsn
This flavor of makeLsn is used when the file offset has been stored in 32 bits, as is done in the VLSNBucket.
makeNestedPeriod(RollbackEnd, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
A new RollbackEnd has been seen.
makeNestedPeriod(RollbackStart, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
A new RollbackStart has been seen.
makeNewInstance(TupleInput) - Static method in class com.sleepycat.je.rep.vlsn.GhostBucket
Ideally, this would be a constructor, but we have to read several items off the tuple input first before calling super();
makePartialKey(long) - Static method in class com.sleepycat.je.tree.FileSummaryLN
Returns the first 4 bytes of the key for the given file number.
makePrefixKey(byte[], int, int) - Static method in class com.sleepycat.je.dbi.DupKeyData
Returns a two-part key entry with the given key portion, no data, and the special PREFIX_ONLY value for the key length.
makePriDbName(String, String) - Static method in class com.sleepycat.persist.impl.Store
 
makeReplicatedEnvironmentStats(RepImpl, StatsConfig) - Static method in class com.sleepycat.je.rep.RepInternal
 
makeReplicationConfig() - Method in class com.sleepycat.je.rep.impl.RepConfigManager
Create a new ReplicationConfig for use in creating Replicator handles.
makeReplicationConfig(Properties, boolean) - Static method in class com.sleepycat.je.rep.RepInternal
 
makeRootChildReference(Node, byte[], long) - Method in class com.sleepycat.je.tree.Tree
 
makeSecDbName(String, String, String) - Static method in class com.sleepycat.persist.impl.Store
 
makeSelector() - Method in class com.sleepycat.je.evictor.Evictor
 
makeSelector() - Method in class com.sleepycat.je.evictor.PrivateEvictor
 
makeSelector() - Method in class com.sleepycat.je.evictor.SharedEvictor
 
makeSpace(int) - Method in class com.sleepycat.util.FastOutputStream
Ensure that at least the given number of bytes are available in the internal buffer.
makeTimeoutMsg(boolean, Locker, long, LockType, LockGrantType, Lock, long, long, long, DatabaseImpl) - Method in class com.sleepycat.je.txn.DummyLockManager
 
makeTimeoutMsg(boolean, Locker, long, LockType, LockGrantType, Lock, long, long, long, DatabaseImpl) - Method in class com.sleepycat.je.txn.LockManager
Create a informative lock or txn timeout message.
makeTimeoutMsg(boolean, Locker, long, LockType, LockGrantType, Lock, long, long, long, DatabaseImpl) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
makeTimeoutMsgInternal(boolean, Locker, long, LockType, LockGrantType, Lock, long, long, long, DatabaseImpl) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of creating an lock or txn timeout message.
makeTransientLsn(long) - Static method in class com.sleepycat.je.utilint.DbLsn
For transient LSNs we use the MAX_FILE_NUM and the ascending sequence of offsets.
makeUtilityEnvironment(File, boolean) - Static method in class com.sleepycat.je.utilint.CmdUtil
Create an environment suitable for utilities.
makeValue(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.collections.DataView
Converts a key-value entry pair to a value object.
makeWindow(int) - Method in class com.sleepycat.je.log.FileReader
May be overridden by other FileReaders.
makeWindow(int) - Method in class com.sleepycat.je.rep.stream.FeederReader
Use a ReadWindow which can read from LogBuffers as well as the physical file.
MANA_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the MULTIANEWARRAY instruction.
map() - Method in interface com.sleepycat.persist.EntityIndex
Returns a standard Java map based on this entity index.
map() - Method in class com.sleepycat.persist.KeysIndex
 
map() - Method in class com.sleepycat.persist.PrimaryIndex
 
map() - Method in class com.sleepycat.persist.SecondaryIndex
 
map() - Method in class com.sleepycat.persist.SubIndex
 
MapEntryParameter<K,V> - Class in com.sleepycat.collections
A simple Map.Entry implementation that can be used as in input parameter.
MapEntryParameter(K, V) - Constructor for class com.sleepycat.collections.MapEntryParameter
Creates a map entry with a given key and value.
MapLN - Class in com.sleepycat.je.tree
A MapLN represents a Leaf Node in the JE Db Mapping Tree.
MapLN(DatabaseImpl) - Constructor for class com.sleepycat.je.tree.MapLN
Create a new MapLn to hold a new databaseImpl.
MapLN() - Constructor for class com.sleepycat.je.tree.MapLN
Create an empty MapLN, to be filled in from the log.
MAPLN_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
MapProxy<K,V> - Class in com.sleepycat.persist.impl
Proxy for a Map.
MapProxy() - Constructor for class com.sleepycat.persist.impl.MapProxy
 
MapProxy.HashMapProxy<K,V> - Class in com.sleepycat.persist.impl
 
MapProxy.HashMapProxy() - Constructor for class com.sleepycat.persist.impl.MapProxy.HashMapProxy
 
MapProxy.LinkedHashMapProxy<K,V> - Class in com.sleepycat.persist.impl
 
MapProxy.LinkedHashMapProxy() - Constructor for class com.sleepycat.persist.impl.MapProxy.LinkedHashMapProxy
 
MapProxy.TreeMapProxy<K,V> - Class in com.sleepycat.persist.impl
 
MapProxy.TreeMapProxy() - Constructor for class com.sleepycat.persist.impl.MapProxy.TreeMapProxy
 
mark - Variable in class com.sleepycat.util.FastInputStream
 
mark(int) - Method in class com.sleepycat.util.FastInputStream
 
markDeleteAtTxnEnd(DatabaseImpl, boolean) - Method in class com.sleepycat.je.txn.BasicLocker
 
markDeleteAtTxnEnd(DatabaseImpl, boolean) - Method in class com.sleepycat.je.txn.Locker
Database operations like remove and truncate leave behind residual DatabaseImpls that must be purged at transaction commit or abort.
markDeleteAtTxnEnd(DatabaseImpl, boolean) - Method in class com.sleepycat.je.txn.Txn
 
markFinish(T, long) - Method in class com.sleepycat.utilint.StatsTracker
Track the end of an operation.
markFinish(T, long, int) - Method in class com.sleepycat.utilint.StatsTracker
Track the end of an operation.
markStart() - Method in class com.sleepycat.utilint.StatsTracker
Track the start of a operation.
markSupported() - Method in class com.sleepycat.util.FastInputStream
 
marshalEntry(TupleOutput) - Method in interface com.sleepycat.bind.tuple.MarshalledTupleEntry
Construct the key or data tuple entry from the key or data object.
MarshalledTupleEntry - Interface in com.sleepycat.bind.tuple
A marshalling interface implemented by key, data or entity classes that are represented as tuples.
MarshalledTupleKeyEntity - Interface in com.sleepycat.bind.tuple
A marshalling interface implemented by entity classes that represent keys as tuples.
marshallOutsideLatch() - Method in enum com.sleepycat.je.log.LogEntryType.Marshall
 
marshallOutsideLatch() - Method in class com.sleepycat.je.log.LogEntryType
Return true if this log entry should be marshalled into a buffer outside the log write latch.
marshalPrimaryKey(TupleOutput) - Method in interface com.sleepycat.bind.tuple.MarshalledTupleKeyEntity
Extracts the entity's primary key and writes it to the key output.
marshalSecondaryKey(String, TupleOutput) - Method in interface com.sleepycat.bind.tuple.MarshalledTupleKeyEntity
Extracts the entity's secondary key and writes it to the key output.
MASK_32BIT - Static variable in class com.sleepycat.je.rep.util.ldiff.LDiffUtil
 
MASTER - Static variable in class com.sleepycat.je.log.ReplicationContext
 
MASTER_CHANGE_CHECK_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.node.FeederManager
 
MASTER_QUERY - Variable in class com.sleepycat.je.rep.elections.Protocol
 
MASTER_QUERY_RESPONSE - Variable in class com.sleepycat.je.rep.elections.Protocol
 
MasterChangeListener - Class in com.sleepycat.je.rep.stream
The Listener registered with Elections to learn about new Masters
MasterChangeListener(RepNode) - Constructor for class com.sleepycat.je.rep.stream.MasterChangeListener
 
MasterFeederSource - Class in com.sleepycat.je.rep.stream
Implementation of a master node acting as a FeederSource.
MasterFeederSource(EnvironmentImpl, VLSNIndex, NameIdPair) - Constructor for class com.sleepycat.je.rep.stream.MasterFeederSource
 
masterNameIdPair - Variable in exception com.sleepycat.je.rep.impl.node.Replica.HardRecoveryElectionException
 
MasterReplicaTransitionException - Exception in com.sleepycat.je.rep
MasterReplicaTransitionException is thrown in JE replication systems when this environment is a master and must transition to replica state.
MasterReplicaTransitionException(EnvironmentImpl, Exception) - Constructor for exception com.sleepycat.je.rep.MasterReplicaTransitionException
 
MasterReplicaTransitionException(String, MasterReplicaTransitionException) - Constructor for exception com.sleepycat.je.rep.MasterReplicaTransitionException
 
MasterStateException - Exception in com.sleepycat.je.rep
This exception indicates that the application attempted an operation that is not permitted when it is in the Replicator.State.Master state.
MasterStateException(StateChangeEvent) - Constructor for exception com.sleepycat.je.rep.MasterStateException
For internal use only.
MasterStateException(String) - Constructor for exception com.sleepycat.je.rep.MasterStateException
For internal use only.
MasterStatus - Class in com.sleepycat.je.rep.stream
Class used by a node to track changes in Master Status.
MasterStatus(NameIdPair) - Constructor for class com.sleepycat.je.rep.stream.MasterStatus
 
MasterStatus.MasterSyncException - Exception in com.sleepycat.je.rep.stream
 
MasterStatus.MasterSyncException() - Constructor for exception com.sleepycat.je.rep.stream.MasterStatus.MasterSyncException
 
MasterSuggestionGenerator - Class in com.sleepycat.je.rep.stream
A Basic suggestion generator.
MasterSuggestionGenerator(RepNode) - Constructor for class com.sleepycat.je.rep.stream.MasterSuggestionGenerator
 
MasterThreadLocker - Class in com.sleepycat.je.rep.txn
A MasterThreadLocker is used with a user initiated non-transactional operation on a Master.
MasterThreadLocker(RepImpl) - Constructor for class com.sleepycat.je.rep.txn.MasterThreadLocker
 
MasterTransfer - Class in com.sleepycat.je.rep.impl.node
A Master Transfer operation.
MasterTransfer(Set<String>, long, RepNode) - Constructor for class com.sleepycat.je.rep.impl.node.MasterTransfer
 
MasterTransfer.VLSNProgress - Class in com.sleepycat.je.rep.impl.node
An event of interest in the pursuit of our goal of completing the Master Transfer.
MasterTransfer.VLSNProgress(VLSN, String) - Constructor for class com.sleepycat.je.rep.impl.node.MasterTransfer.VLSNProgress
 
MasterTransferFailureException - Exception in com.sleepycat.je.rep
Thrown by ReplicatedEnvironment.transferMaster(java.util.Set<java.lang.String>, int, java.util.concurrent.TimeUnit) if a Master Transfer operation cannot be completed within the allotted time.
MasterTransferFailureException(String) - Constructor for exception com.sleepycat.je.rep.MasterTransferFailureException
For internal use only.
masterTransitionCleanup() - Method in class com.sleepycat.je.rep.impl.node.Replica
Invoked when this node transitions to the master state.
MasterTxn - Class in com.sleepycat.je.rep.txn
A MasterTxn represents a user initiated Txn executed on the Master node.
MasterTxn(EnvironmentImpl, TransactionConfig, NameIdPair) - Constructor for class com.sleepycat.je.rep.txn.MasterTxn
 
MasterTxn.MasterTxnFactory - Interface in com.sleepycat.je.rep.txn
 
masterTxnEndTime - Variable in class com.sleepycat.je.rep.impl.node.Replay.TxnInfo
 
MasterValue - Class in com.sleepycat.je.rep.elections
Class represents the identity of a Master as a subclass of a StringValue that can be used during the election protocol.
MasterValue(String, int, NameIdPair) - Constructor for class com.sleepycat.je.rep.elections.MasterValue
 
MasterValue(String) - Constructor for class com.sleepycat.je.rep.elections.MasterValue
 
match(InputWireRecord) - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
Used at syncup, when comparing records received from the feeder against local records.
match(OutputWireRecord) - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
For unit tests.
match(BinaryProtocol.Message) - Method in class com.sleepycat.je.rep.stream.Protocol.AlternateMatchpoint
 
match(BinaryProtocol.Message) - Method in class com.sleepycat.je.rep.stream.Protocol.Entry
 
match(BinaryProtocol.Message) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.Message
 
matchManagedConnections(Set, Subject, ConnectionRequestInfo) - Method in class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
Matchpoint - Class in com.sleepycat.je.utilint
This class writes out a log entry that can be used for replication syncup.
Matchpoint(int) - Constructor for class com.sleepycat.je.utilint.Matchpoint
 
Matchpoint() - Constructor for class com.sleepycat.je.utilint.Matchpoint
For constructing from the log.
MatchpointSearchResults - Class in com.sleepycat.je.rep.stream
Holds information seen by the ReplicaSyncupReader when scanning a replica's log for a matchpoint.
MatchpointSearchResults(EnvironmentImpl) - Constructor for class com.sleepycat.je.rep.stream.MatchpointSearchResults
 
MatchpointSearchResults.PassedTxnInfo - Class in com.sleepycat.je.rep.stream
 
MatchpointSearchResults.PassedTxnInfo(Timestamp, long, VLSN, long) - Constructor for class com.sleepycat.je.rep.stream.MatchpointSearchResults.PassedTxnInfo
 
matchpointVLSN - Variable in exception com.sleepycat.je.rep.impl.node.Replica.HardRecoveryElectionException
 
MAX_CLOCK_DELTA - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
MAX_CLOCK_DELTA - Static variable in class com.sleepycat.je.rep.ReplicationConfig
Sets the maximum acceptable clock skew between this Replica and its Feeder, which is the node that is the source of its replication stream.
MAX_COMMIT_PROCESSING_NANOS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
MAX_DUMP_BYTES - Static variable in class com.sleepycat.je.DatabaseEntry
 
MAX_ENTRIES - Static variable in class com.sleepycat.je.tree.INTargetRep.Sparse
 
MAX_FIELD_NUM - Static variable in interface com.sleepycat.persist.impl.Accessor
A large field value to use instead of Integer.MAX_VALUE, to work around Java JIT compiler bug when doing an (X <= Integer.MAX_VALUE) as would be done in readXxxKeyFields methods.
MAX_FILE_OFFSET - Static variable in class com.sleepycat.je.utilint.DbLsn
 
MAX_HEADER_SIZE - Static variable in class com.sleepycat.je.log.LogEntryHeader
 
MAX_INDEX - Static variable in class com.sleepycat.je.tree.INTargetRep.Sparse
 
MAX_KEY_SIZE_KEYVALS_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
MAX_KEYS - Static variable in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
MAX_LENGTH - Static variable in class com.sleepycat.util.PackedInteger
The maximum number of bytes needed to store an int value (5).
MAX_LEVEL - Static variable in class com.sleepycat.je.tree.IN
 
MAX_LONG_LENGTH - Static variable in class com.sleepycat.util.PackedInteger
The maximum number of bytes needed to store a long value (9).
MAX_MEMORY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
MAX_MEMORY - Static variable in class com.sleepycat.je.EnvironmentConfig
The CacheSize property.
MAX_MEMORY_PERCENT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
MAX_MEMORY_PERCENT - Static variable in class com.sleepycat.je.EnvironmentConfig
The CachePercent property.
MAX_MESSAGE_SIZE - Static variable in class com.sleepycat.je.rep.impl.RepParams
The maximum message size which will be accepted by a node (to prevent DOS attacks).
MAX_MESSAGE_SIZE - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The maximum message size which will be accepted by a node (to prevent DOS attacks).
maxBatchFiles - Variable in class com.sleepycat.je.cleaner.Cleaner
 
maxBytes - Variable in class com.sleepycat.je.log.StatsFileReader.EntryInfo
 
maxFileNumber - Variable in class com.sleepycat.je.log.JEFileFilter
 
maxFlushLevelHook - Static variable in class com.sleepycat.je.recovery.Checkpointer
For unit testing only.
maxINsPerBatch - Variable in class com.sleepycat.je.evictor.TargetSelector.SetupInfo
 
maxLNSize - Variable in class com.sleepycat.je.cleaner.FileSummary
 
maxMemory - Variable in class com.sleepycat.je.dbi.MemoryBudget.Totals
 
MAY_EVICT_LNS - Static variable in class com.sleepycat.je.tree.IN
 
MAY_EVICT_NODE - Static variable in class com.sleepycat.je.tree.IN
 
MAY_NOT_EVICT - Static variable in class com.sleepycat.je.tree.IN
 
maybeForceYield() - Static method in class com.sleepycat.je.dbi.EnvironmentImpl
For stress testing.
mayCreateDeletedLN() - Method in enum com.sleepycat.je.dbi.DbType
Returns true if createDeletedLN may be called.
mayCreateUpdatedLN() - Method in enum com.sleepycat.je.dbi.DbType
Returns true if createUpdatedLN may be called.
mayNotWrite() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
When a EnvironmentFailureException occurs or the environment is closed, further writing can cause log corruption.
MB_ADMIN_BYTES - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
MB_DATA_BYTES - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
MB_GROUP_DESC - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
MB_GROUP_NAME - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
MB_LOCK_BYTES - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
MB_SHARED_CACHE_TOTAL_BYTES - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
MB_TOTAL_BYTES - Static variable in class com.sleepycat.je.dbi.DbiStatDefinition
 
mBeanCount - Variable in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
mBeanNamePrefix - Static variable in class com.sleepycat.je.jmx.plugin.JEStatsPlugin
 
mBeanNamePrefix - Variable in class com.sleepycat.je.jmx.plugin.Stats
 
mBeanNamePrefix - Static variable in class com.sleepycat.je.rep.jmx.plugin.RepJEStatsPlugin
 
md - Static variable in class com.sleepycat.je.rep.util.ldiff.LDiffUtil
 
measure(PrintStream) - Method in class com.sleepycat.je.util.DbCacheSize
For testing, insert the specified data set and initialize the measuredBtreeSize and measuredBtreeSizeWithData fields.
MemberChangeEvent - Class in com.sleepycat.je.rep.monitor
MemberChangeEvent is the base class for all member status changed events.
MemberChangeEvent(String, String) - Constructor for class com.sleepycat.je.rep.monitor.MemberChangeEvent
 
MemberNotFoundException - Exception in com.sleepycat.je.rep
Thrown when an operation requires a replication group member and that member is not present in the replication group.
MemberNotFoundException(String) - Constructor for exception com.sleepycat.je.rep.MemberNotFoundException
For internal use only.
MEMBERSHIP_INFO - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
MEMBERSHIP_INFO_OK - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
MEMBERSHIP_INFO_REJECT - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
MEMBERSHIP_RETRIES - Static variable in class com.sleepycat.je.rep.stream.ReplicaFeederHandshake
 
MEMBERSHIP_RETRY_SLEEP_MS - Static variable in class com.sleepycat.je.rep.stream.ReplicaFeederHandshake
 
MEMORY_SUBSYSTEM - Static variable in class com.sleepycat.compat.DbCompat
 
MemoryBudget - Class in com.sleepycat.je.dbi
MemoryBudget calculates the available memory for JE and how to apportion it between cache and log buffers.
MemoryBudget(EnvironmentImpl, EnvironmentImpl, DbConfigManager) - Constructor for class com.sleepycat.je.dbi.MemoryBudget
 
MemoryBudget.Totals - Class in com.sleepycat.je.dbi
Common base class for shared and private totals.
memRecalcBegin() - Method in class com.sleepycat.je.dbi.INList
We are starting the iteration of the INList.
memRecalcEnd(boolean) - Method in class com.sleepycat.je.dbi.INList
The reset operation is over.
memRecalcIterate(IN) - Method in class com.sleepycat.je.dbi.INList
An IN was encountered during the iteration through the entire INList.
memRecalcUpdate(IN, long) - Method in class com.sleepycat.je.dbi.INList
The size of an IN is changing.
merge(ClassWriter, Frame, int) - Method in class com.sleepycat.asm.Frame
Merges the input frame of the given basic block with the input and output frames of this basic block.
merge(OffsetList) - Method in class com.sleepycat.je.cleaner.OffsetList
Merges the given list and returns whether a segment was freed.
merge(VLSNRecoveryTracker) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
merge(VLSNRange) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
The "other" range is going to be appended to this range.
merge(VLSN, VLSNRecoveryTracker) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
Attempt to replace the mappings in this vlsnIndex for deleteStart->lastVLSN with those from the recovery mapper.
MESSAGE_HEADER_SIZE - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
MESSAGE_READ_RATE - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
MESSAGE_WRITE_RATE - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
messageCount() - Method in class com.sleepycat.je.rep.impl.TextProtocol
 
messageCount() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
messageDigest - Variable in class com.sleepycat.je.rep.impl.networkRestore.LogFileFeeder
 
messageDigest - Variable in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackup
 
messageExchange() - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
Run a message exchange.
messageNocheckSuffix - Variable in class com.sleepycat.je.rep.impl.TextProtocol
 
messagePrefixNocheck - Variable in class com.sleepycat.je.rep.impl.TextProtocol.Message
 
messageTransferMs() - Method in class com.sleepycat.je.rep.txn.MasterTxn
Returns the amount of time it took to copy the commit record from the log buffer to the rep stream.
METH - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_Methodref constant pool items.
METHOD - Static variable in class com.sleepycat.asm.Type
The sort of method types.
MethodVisitor - Class in com.sleepycat.asm
A visitor to visit a Java method.
MethodVisitor(int) - Constructor for class com.sleepycat.asm.MethodVisitor
Constructs a new MethodVisitor.
MethodVisitor(int, MethodVisitor) - Constructor for class com.sleepycat.asm.MethodVisitor
Constructs a new MethodVisitor.
MethodWriter - Class in com.sleepycat.asm
A MethodVisitor that generates methods in bytecode form.
MethodWriter(ClassWriter, int, String, String, String, String[], boolean, boolean) - Constructor for class com.sleepycat.asm.MethodWriter
Constructs a new MethodWriter.
migrateFromBeta(Map<String, Format>) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
migrateFromBeta(Map<String, Format>) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
migrateFromBeta(Map<String, Format>) - Method in class com.sleepycat.persist.impl.FieldInfo
 
migrateFromBeta(Map<String, Format>) - Method in class com.sleepycat.persist.impl.Format
Special handling for JE 3.0.12 beta formats.
millisToDuration(int, TimeUnit) - Static method in class com.sleepycat.je.utilint.PropUtil
Converts the given duration value in milliseconds to the given unit.
MIN_COMMIT_PROCESSING_NANOS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
MIN_HEADER_SIZE - Static variable in class com.sleepycat.je.log.LogEntryHeader
Persistent fields.
MIN_LEVEL - Static variable in class com.sleepycat.je.tree.IN
 
MIN_LOG_BUFFER_SIZE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
MIN_LOG_SIZE - Static variable in class com.sleepycat.je.log.entry.LNLogEntry
Used for computing the minimum log space used by an LNLogEntry.
MIN_MAX_MEMORY_SIZE - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
MIN_MAX_MEMORY_SIZE_STRING - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
MIN_TREE_MEMORY - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
minAckNodes(int) - Method in enum com.sleepycat.je.Durability.ReplicaAckPolicy
Returns the minimum number of replication nodes required to implement the ReplicaAckPolicy for a given group size.
minAckNodes(Durability.ReplicaAckPolicy) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the minimum number of replication nodes required to implement the ReplicaAckPolicy for a given group size.
minAckNodes(Durability) - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
minAge - Variable in class com.sleepycat.je.cleaner.Cleaner
 
minBytes - Variable in class com.sleepycat.je.log.StatsFileReader.EntryInfo
 
minFileNumber - Variable in class com.sleepycat.je.log.JEFileFilter
 
minFileUtilization - Variable in class com.sleepycat.je.cleaner.Cleaner
 
minUtilization - Variable in class com.sleepycat.je.cleaner.Cleaner
 
MismatchedRegion - Class in com.sleepycat.je.rep.util.ldiff
 
MismatchedRegion() - Constructor for class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
mix - Variable in class com.sleepycat.je.rep.util.ldiff.Record
 
MobileConnectionConfig - Class in com.sleepycat.je.sync.mobile
Connection properties for Mobile Server.
MobileConnectionConfig() - Constructor for class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
MobileDataSet - Class in com.sleepycat.je.sync.mobile
 
MobileDataSet(String, SyncProcessor, Collection<SyncDatabase>) - Constructor for class com.sleepycat.je.sync.mobile.MobileDataSet
 
MobileSyncProcessor - Class in com.sleepycat.je.sync.mobile
Manages one or more synchronized data sets for Oracle Mobile Server and processes sync operations.
MobileSyncProcessor(Environment, String, MobileConnectionConfig) - Constructor for class com.sleepycat.je.sync.mobile.MobileSyncProcessor
Creates a SyncProcessor for Oracle Mobile Server.
ModelInternal - Class in com.sleepycat.persist.model
 
ModelInternal() - Constructor for class com.sleepycat.persist.model.ModelInternal
 
modify(byte[]) - Method in class com.sleepycat.je.tree.LN
 
modifyDbRoot(DatabaseImpl) - Method in class com.sleepycat.je.dbi.DbTree
Write the MapLN to disk.
modifyDbRoot(DatabaseImpl, long, boolean) - Method in class com.sleepycat.je.dbi.DbTree
Write a MapLN to the log in order to: - propagate a root change - save per-db utilization information - save database config information.
Monitor - Class in com.sleepycat.je.rep.monitor
Provides a lightweight mechanism to track the current master node and the members of the replication group.
Monitor(ReplicationConfig) - Constructor for class com.sleepycat.je.rep.monitor.Monitor
Deprecated.
As of JE 5, replaced by Monitor.Monitor(MonitorConfig)
Monitor(MonitorConfig) - Constructor for class com.sleepycat.je.rep.monitor.Monitor
Creates a monitor instance.
MONITOR_OPEN_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
MONITOR_READ_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
MonitorChangeEvent - Class in com.sleepycat.je.rep.monitor
MonitorChangeEvent is the base class for all Monitor events.
MonitorChangeEvent(String) - Constructor for class com.sleepycat.je.rep.monitor.MonitorChangeEvent
 
MonitorChangeListener - Interface in com.sleepycat.je.rep.monitor
Applications can register for Monitor event notification through Monitor.startListener(com.sleepycat.je.rep.monitor.MonitorChangeListener).
MonitorConfig - Class in com.sleepycat.je.rep.monitor
Specifies the attributes used by a replication Monitor.
MonitorConfig() - Constructor for class com.sleepycat.je.rep.monitor.MonitorConfig
An instance created using the default constructor is initialized with the default settings.
MonitorConfig(ReplicationConfig) - Constructor for class com.sleepycat.je.rep.monitor.MonitorConfig
 
MonitorConfigBeanInfo - Class in com.sleepycat.je.rep.monitor
 
MonitorConfigBeanInfo() - Constructor for class com.sleepycat.je.rep.monitor.MonitorConfigBeanInfo
 
MONITORENTER - Static variable in interface com.sleepycat.asm.Opcodes
 
MonitorEventManager - Class in com.sleepycat.je.rep.impl.node
The class for firing MonitorChangeEvents.
MonitorEventManager(RepNode) - Constructor for class com.sleepycat.je.rep.impl.node.MonitorEventManager
 
MONITOREXIT - Static variable in interface com.sleepycat.asm.Opcodes
 
MonitorService - Class in com.sleepycat.je.rep.monitor
 
MonitorService(Monitor, ServiceDispatcher) - Constructor for class com.sleepycat.je.rep.monitor.MonitorService
 
MonitorService.MonitorServiceRunnable - Class in com.sleepycat.je.rep.monitor
 
MonitorService.MonitorServiceRunnable(SocketChannel, Protocol) - Constructor for class com.sleepycat.je.rep.monitor.MonitorService.MonitorServiceRunnable
 
moveToIndex(int) - Method in class com.sleepycat.collections.BaseIterator
 
moveToIndex(int) - Method in class com.sleepycat.collections.BlockIterator
 
moveToIndex(int) - Method in class com.sleepycat.collections.StoredIterator
 
moveWriteToReadLock(long, Lock) - Method in class com.sleepycat.je.txn.BasicLocker
A lock is being demoted.
moveWriteToReadLock(long, Lock) - Method in class com.sleepycat.je.txn.Locker
A lock is being demoted.
moveWriteToReadLock(long, Lock) - Method in class com.sleepycat.je.txn.Txn
A lock is being demoted.
MTYPE - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_MethodType constant pool items.
MULTIANEWARRAY - Static variable in interface com.sleepycat.asm.Opcodes
 
multiLog(LogItem[], LogContext) - Method in class com.sleepycat.je.log.LogManager
 
multiValueParamName(String) - Static method in class com.sleepycat.je.config.ConfigParam
 
mustGenerateVLSN() - Method in class com.sleepycat.je.log.ReplicationContext
 
Mutation - Class in com.sleepycat.persist.evolve
The base class for all mutations.
Mutation(String, int, String) - Constructor for class com.sleepycat.persist.evolve.Mutation
 
Mutations - Class in com.sleepycat.persist.evolve
A collection of mutations for configuring class evolution.
Mutations() - Constructor for class com.sleepycat.persist.evolve.Mutations
Creates an empty set of mutations.
mv - Variable in class com.sleepycat.asm.MethodVisitor
The method visitor to which this visitor must delegate method calls.
mvParamIndex(String) - Static method in class com.sleepycat.je.config.ConfigParam
 
MyRangeCursor - Class in com.sleepycat.collections
 
MyRangeCursor(KeyRange, CursorConfig, DataView, boolean) - Constructor for class com.sleepycat.collections.MyRangeCursor
 

N

N_ABORTS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_BAD_WRITES - Static variable in class com.sleepycat.je.log.FileManager
 
N_BUCKETS_CREATED - Static variable in class com.sleepycat.je.rep.vlsn.VLSNIndexStatDefinition
 
N_BYTES_READ - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
N_BYTES_WRITTEN - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
N_COMMIT_ACKS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_COMMIT_NO_SYNCS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_COMMIT_SYNCS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_COMMIT_WRITE_NO_SYNCS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_COMMITS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_ELAPSED_TXN_TIME - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_FEEDERS_CREATED - Static variable in class com.sleepycat.je.rep.impl.node.FeederManagerStatDefinition
 
N_FEEDERS_SHUTDOWN - Static variable in class com.sleepycat.je.rep.impl.node.FeederManagerStatDefinition
 
N_HEAD_BUCKETS_DELETED - Static variable in class com.sleepycat.je.rep.vlsn.VLSNIndexStatDefinition
 
N_HITS - Static variable in class com.sleepycat.je.rep.vlsn.VLSNIndexStatDefinition
 
N_LAG_CONSISTENCY_WAIT_MS - Static variable in class com.sleepycat.je.rep.impl.node.ReplicaStatDefinition
 
N_LAG_CONSISTENCY_WAITS - Static variable in class com.sleepycat.je.rep.impl.node.ReplicaStatDefinition
 
N_LNS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_LOCK_TABLES - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
N_MAX_REPLICA_LAG - Static variable in class com.sleepycat.je.rep.impl.node.FeederManagerStatDefinition
 
N_MAX_REPLICA_LAG_NAME - Static variable in class com.sleepycat.je.rep.impl.node.FeederManagerStatDefinition
 
N_MESSAGE_QUEUE_OVERFLOWS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_MESSAGES_READ - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
N_MESSAGES_WRITTEN - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
N_MISSES - Static variable in class com.sleepycat.je.rep.vlsn.VLSNIndexStatDefinition
 
N_NAME_LNS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
N_NO_WAITS - Static variable in class com.sleepycat.je.rep.utilint.SizeAwaitMapStatDefinition
 
N_READ_NANOS - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
N_REAL_WAITS - Static variable in class com.sleepycat.je.rep.utilint.SizeAwaitMapStatDefinition
 
N_TAIL_BUCKETS_DELETED - Static variable in class com.sleepycat.je.rep.vlsn.VLSNIndexStatDefinition
 
N_VLSN_CONSISTENCY_WAIT_MS - Static variable in class com.sleepycat.je.rep.impl.node.ReplicaStatDefinition
 
N_VLSN_CONSISTENCY_WAITS - Static variable in class com.sleepycat.je.rep.impl.node.ReplicaStatDefinition
 
N_WAIT_TIME - Static variable in class com.sleepycat.je.rep.utilint.SizeAwaitMapStatDefinition
 
N_WRITE_NANOS - Static variable in class com.sleepycat.je.rep.utilint.BinaryProtocolStatDefinition
 
name - Variable in class com.sleepycat.asm.Handle
The name of the field or method designated by this handle.
name - Variable in class com.sleepycat.je.config.ConfigParam
 
NAME - Static variable in class com.sleepycat.je.rep.CommitPointConsistencyPolicy
The name:"CommitPointConsistencyPolicy" associated with this policy.
NAME - Static variable in class com.sleepycat.je.rep.impl.PointConsistencyPolicy
The name:"PointConsistencyPolicy" associated with this policy.
NAME - Static variable in class com.sleepycat.je.rep.NoConsistencyRequiredPolicy
The name:"NoConsistencyRequiredPolicy" associated with this policy.
NAME - Static variable in class com.sleepycat.je.rep.TimeConsistencyPolicy
The name:"TimeConsistencyPolicy" associated with this policy.
NAME - Static variable in class com.sleepycat.je.rep.util.ldiff.LDiffService
 
name - Variable in class com.sleepycat.je.sync.impl.LogChangeReader.DbInfo
 
name - Variable in class com.sleepycat.je.utilint.DaemonThread
 
NAME_DB_ID - Static variable in class com.sleepycat.je.dbi.DbTree
 
NAME_SEPARATOR - Static variable in class com.sleepycat.persist.impl.Store
 
NAME_TYPE - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_NameAndType constant pool items.
NamedChannel - Class in com.sleepycat.je.rep.utilint
Packages a SocketChannel and a NameIdPair together so that logging messages can show the node name instead of the channel toString();
NamedChannel(SocketChannel, NameIdPair) - Constructor for class com.sleepycat.je.rep.utilint.NamedChannel
 
NamedChannel(SocketChannel) - Constructor for class com.sleepycat.je.rep.utilint.NamedChannel
 
NamedChannelWithTimeout - Class in com.sleepycat.je.rep.utilint
NamedChannelWithTimeout permits association of timeouts with a SocketChannel.
NamedChannelWithTimeout(RepNode, SocketChannel, int) - Constructor for class com.sleepycat.je.rep.utilint.NamedChannelWithTimeout
 
nameIdPair - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
NameIdPair - Class in com.sleepycat.je.rep.impl.node
The public name and internal id pair used to uniquely identify a node within a replication group.
NameIdPair(String, int) - Constructor for class com.sleepycat.je.rep.impl.node.NameIdPair
 
NameIdPair(String) - Constructor for class com.sleepycat.je.rep.impl.node.NameIdPair
Constructor for a pair where the node ID is as yet unknown.
nameIdPair - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
NameLN - Class in com.sleepycat.je.tree
A NameLN represents a Leaf Node in the name->database id mapping tree.
NameLN(DatabaseId) - Constructor for class com.sleepycat.je.tree.NameLN
In the ideal world, we'd have a base LN class so that this NameLN doesn't have a superfluous data field, but we want to optimize the LN class for size and speed right now.
NameLN() - Constructor for class com.sleepycat.je.tree.NameLN
Create an empty NameLN, to be filled in from the log.
NameLNLogEntry - Class in com.sleepycat.je.log.entry
NameLNLogEntry contains all the regular LNLogEntry fields and additional information about the database operation which instigated the logging of this NameLN.
NameLNLogEntry() - Constructor for class com.sleepycat.je.log.entry.NameLNLogEntry
Constructor to read an entry.
NameLNLogEntry(LogEntryType, NameLN, DatabaseId, byte[], long, boolean, Txn, ReplicationContext) - Constructor for class com.sleepycat.je.log.entry.NameLNLogEntry
Constructor to write this entry.
nBINDeltasCleaned - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nBINDeltasDead - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nBINDeltasMigrated - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nBINDeltasObsolete - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nBytesRead - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
nBytesReadFromWriteQueue - Variable in class com.sleepycat.je.log.FileManager
 
nBytesWritten - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
nBytesWrittenFromWriteQueue - Variable in class com.sleepycat.je.log.FileManager
 
nCleanerDeletions - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nCleanerProbeRuns - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nCleanerRuns - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nClusterLNsProcessed - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nCursors() - Method in class com.sleepycat.je.tree.BIN
 
nDeadlockRetries - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nDeadlockRetries() - Method in class com.sleepycat.je.cleaner.FileProcessor
Return the number of retries when a deadlock exception occurs.
nDeadlockRetries() - Method in class com.sleepycat.je.incomp.INCompressor
Return the number of retries when a deadlock exception occurs.
nDeadlockRetries() - Method in class com.sleepycat.je.recovery.Checkpointer
Return the number of retries when a deadlock exception occurs.
nDeadlockRetries() - Method in class com.sleepycat.je.utilint.DaemonThread
Returns the number of retries to perform when Deadlock Exceptions occur.
nDeltaINFlush - Variable in class com.sleepycat.je.recovery.Checkpointer.FlushStats
 
nDeltaINFlushThisRun - Variable in class com.sleepycat.je.recovery.Checkpointer.FlushStats
 
needCriticalEviction() - Method in class com.sleepycat.je.evictor.Arbiter
Do a check on whether synchronous eviction is needed.
needRepConvert - Variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
needRepConvert() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
needsRollback() - Method in class com.sleepycat.je.recovery.RollbackTracker.Scanner
 
needsSplitting() - Method in class com.sleepycat.je.tree.IN
Return true if this node needs splitting.
NEG_DB_ID_START - Static variable in class com.sleepycat.je.dbi.DbTree
 
nEntriesRead - Variable in class com.sleepycat.je.cleaner.Cleaner
 
NESTED_TRANSACTIONS - Static variable in class com.sleepycat.compat.DbCompat
 
NetworkBackup - Class in com.sleepycat.je.rep.impl.networkRestore
This class implements a hot network backup that permits it to obtain a consistent set of log files from any running environment that provides a LogFileFeeder service.
NetworkBackup(InetSocketAddress, int, File, NameIdPair, boolean, int, VLSN, RepImpl, FileManager) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.NetworkBackup
Creates a configured backup instance which when executed will backup the files to the environment directory.
NetworkBackup(InetSocketAddress, File, NameIdPair, boolean, FileManager) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.NetworkBackup
Convenience overloading.
NetworkBackup.DigestException - Exception in com.sleepycat.je.rep.impl.networkRestore
Exception indicating that the digest sent by the server did not match the digest computed by the client, that is, the log file was corrupted during transit.
NetworkBackup.DigestException() - Constructor for exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.DigestException
 
NetworkBackup.InsufficientVLSNRangeException - Exception in com.sleepycat.je.rep.impl.networkRestore
Exception indicating that the server vlsn range did not cover the VLSN of interest.
NetworkBackup.InsufficientVLSNRangeException(VLSN, VLSN, VLSN) - Constructor for exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.InsufficientVLSNRangeException
 
NetworkBackup.LoadThresholdExceededException - Exception in com.sleepycat.je.rep.impl.networkRestore
 
NetworkBackup.LoadThresholdExceededException(int, int) - Constructor for exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.LoadThresholdExceededException
 
NetworkBackupStatDefinition - Class in com.sleepycat.je.rep.impl.networkRestore
Per-stat Metadata for each NetworkBackup statistics.
NetworkBackupStatDefinition() - Constructor for class com.sleepycat.je.rep.impl.networkRestore.NetworkBackupStatDefinition
 
NetworkRestore - Class in com.sleepycat.je.rep
Obtains log files for a Replica from other members of the replication group.
NetworkRestore() - Constructor for class com.sleepycat.je.rep.NetworkRestore
Creates an instance of NetworkRestore suitable for restoring the logs at this node.
NetworkRestoreConfig - Class in com.sleepycat.je.rep
NetworkRestoreConfig defines the configuration parameters used to configure a NetworkRestore operation.
NetworkRestoreConfig() - Constructor for class com.sleepycat.je.rep.NetworkRestoreConfig
 
NetworkRestoreConfigBeanInfo - Class in com.sleepycat.je.rep
 
NetworkRestoreConfigBeanInfo() - Constructor for class com.sleepycat.je.rep.NetworkRestoreConfigBeanInfo
 
NEW - Static variable in interface com.sleepycat.asm.Opcodes
 
NEW_JE_EXCEPTIONS - Static variable in class com.sleepycat.compat.DbCompat
 
NEWARRAY - Static variable in interface com.sleepycat.asm.Opcodes
 
newArray(int) - Method in interface com.sleepycat.persist.impl.Accessor
Creates a new one dimensional array of the given length, having the target class as its component type.
newArray(int) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
newArray(int) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
newArray(int) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
newArray(int) - Method in class com.sleepycat.persist.impl.EnumFormat
 
newArray(int) - Method in class com.sleepycat.persist.impl.Format
Creates an array of the format's class of the given length, as if Array.newInstance(getType(), len) were called.
newArray(int) - Method in class com.sleepycat.persist.impl.NonPersistentFormat
 
newArray(int) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
newArray(int) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
newArray(int) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
newArray(int) - Method in class com.sleepycat.persist.impl.RawAccessor
 
newArray(int) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigDec
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigInt
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDate
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
newArray(int) - Method in class com.sleepycat.persist.impl.SimpleFormat.FString
 
newClass(String) - Method in class com.sleepycat.asm.ClassWriter
Adds a class reference to the constant pool of the class being build.
newClassItem(String) - Method in class com.sleepycat.asm.ClassWriter
Adds a class reference to the constant pool of the class being build.
newConst(Object) - Method in class com.sleepycat.asm.ClassWriter
Adds a number or string constant to the constant pool of the class being build.
newConstItem(Object) - Method in class com.sleepycat.asm.ClassWriter
Adds a number or string constant to the constant pool of the class being build.
newDb - Variable in class com.sleepycat.je.dbi.DbTree.TruncateDbResult
 
newDbcInstance(Transaction, CursorConfig) - Method in class com.sleepycat.je.Database
Is overridden by SecondaryDatabase.
newDbcInstance(Transaction, CursorConfig) - Method in class com.sleepycat.je.SecondaryDatabase
Overrides Database method.
newDouble(double) - Method in class com.sleepycat.asm.ClassWriter
Adds a double to the constant pool of the class being build.
newEvent() - Static method in class com.sleepycat.persist.evolve.EvolveInternal
Internal access method that should not be used by applications.
newField(String, String, String) - Method in class com.sleepycat.asm.ClassWriter
Adds a field reference to the constant pool of the class being build.
newFieldItem(String, String, String) - Method in class com.sleepycat.asm.ClassWriter
Adds a field reference to the constant pool of the class being build.
newFloat(float) - Method in class com.sleepycat.asm.ClassWriter
Adds a float to the constant pool of the class being build.
newHandle(int, String, String, String) - Method in class com.sleepycat.asm.ClassWriter
Adds a handle to the constant pool of the class being build.
newHandleItem(int, String, String, String) - Method in class com.sleepycat.asm.ClassWriter
Adds a handle to the constant pool of the class being build.
newInstance() - Method in interface com.sleepycat.persist.impl.Accessor
Creates a new instance of the target class using its default constructor.
newInstance(int) - Method in class com.sleepycat.persist.impl.CollectionProxy.ArrayListProxy
 
newInstance(int) - Method in class com.sleepycat.persist.impl.CollectionProxy.HashSetProxy
 
newInstance(int) - Method in class com.sleepycat.persist.impl.CollectionProxy.LinkedListProxy
 
newInstance(int) - Method in class com.sleepycat.persist.impl.CollectionProxy
 
newInstance(int) - Method in class com.sleepycat.persist.impl.CollectionProxy.TreeSetProxy
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ConverterReader
 
newInstance() - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.EnumFormat
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.Format
Creates a new instance of the target class using its default constructor.
newInstance(int) - Method in class com.sleepycat.persist.impl.MapProxy.HashMapProxy
 
newInstance(int) - Method in class com.sleepycat.persist.impl.MapProxy.LinkedHashMapProxy
 
newInstance(int) - Method in class com.sleepycat.persist.impl.MapProxy
 
newInstance(int) - Method in class com.sleepycat.persist.impl.MapProxy.TreeMapProxy
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.NonPersistentFormat
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
newInstance() - Method in class com.sleepycat.persist.impl.RawAccessor
 
newInstance(EntityInput, boolean) - Method in interface com.sleepycat.persist.impl.Reader
 
newInstance() - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigDec
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigInt
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDate
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
newInstance(EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FString
 
newInstanceOfType() - Method in class com.sleepycat.je.log.entry.BaseEntry
 
newInstanceOfType(Constructor<?>) - Static method in class com.sleepycat.je.log.entry.BaseEntry
 
newInteger(int) - Method in class com.sleepycat.asm.ClassWriter
Adds an integer to the constant pool of the class being build.
newInvokeDynamic(String, String, Handle, Object...) - Method in class com.sleepycat.asm.ClassWriter
Adds an invokedynamic reference to the constant pool of the class being build.
newInvokeDynamicItem(String, String, Handle, Object...) - Method in class com.sleepycat.asm.ClassWriter
Adds an invokedynamic reference to the constant pool of the class being build.
newLNInstance(EnvironmentImpl) - Method in class com.sleepycat.je.log.entry.LNLogEntry
newLNInstance usually returns exactly the type of LN of the type that was contained in in the log.
newLockNotAvailableException(Locker, String) - Method in class com.sleepycat.je.txn.LockManager
This method should always be called instead of explicitly creating LockNotAvailableException, to ensure that je.lock.oldLockExceptions is enforced.
newLong(long) - Method in class com.sleepycat.asm.ClassWriter
Adds a long to the constant pool of the class being build.
newLsn - Variable in class com.sleepycat.je.log.LogItem
LSN of the new log entry.
newMap(Database, Class<K>, Class<V>, boolean) - Method in class com.sleepycat.collections.TupleSerialFactory
Creates a map from a previously opened Database object.
NewMasterEvent - Class in com.sleepycat.je.rep.monitor
The event generated upon detecting a new Master.
NewMasterEvent(MasterValue) - Constructor for class com.sleepycat.je.rep.monitor.NewMasterEvent
 
newMethod(String, String, String, boolean) - Method in class com.sleepycat.asm.ClassWriter
Adds a method reference to the constant pool of the class being build.
newMethodItem(String, String, String, boolean) - Method in class com.sleepycat.asm.ClassWriter
Adds a method reference to the constant pool of the class being build.
newMethodType(String) - Method in class com.sleepycat.asm.ClassWriter
Adds a method type reference to the constant pool of the class being build.
newMethodTypeItem(String) - Method in class com.sleepycat.asm.ClassWriter
Adds a method type reference to the constant pool of the class being build.
newNameType(String, String) - Method in class com.sleepycat.asm.ClassWriter
Adds a name and type to the constant pool of the class being build.
newNameTypeItem(String, String) - Method in class com.sleepycat.asm.ClassWriter
Adds a name and type to the constant pool of the class being build.
newNonTxnLocker() - Method in class com.sleepycat.je.txn.BasicLocker
Throws EnvironmentFailureException unconditionally.
newNonTxnLocker() - Method in class com.sleepycat.je.txn.Locker
Creates a fresh non-transactional locker, while retaining any transactional locks held by this locker.
newNonTxnLocker() - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Returns a new ReadCommittedLocker that shares locks with this locker by virtue of both lockers only holding READ locks.
newNonTxnLocker() - Method in class com.sleepycat.je.txn.ThreadLocker
Returns a new non-transactional locker that shares locks with this locker by virtue of being a ThreadLocker for the same thread.
newNonTxnLocker() - Method in class com.sleepycat.je.txn.Txn
Returns 'this', since this locker holds no non-transactional locks.
newOutput() - Static method in class com.sleepycat.bind.tuple.TupleBase
Deprecated.
newOutput(byte[]) - Static method in class com.sleepycat.bind.tuple.TupleBase
Deprecated.
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
newPrimitiveArray(int, EntityInput) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
newSortedMap(Database, Class<K>, Class<V>, boolean) - Method in class com.sleepycat.collections.TupleSerialFactory
Creates a sorted map from a previously opened Database object.
newSwingWorker() - Method in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
newThread(Runnable) - Method in class com.sleepycat.je.utilint.StoppableThreadFactory
 
newUTF8(String) - Method in class com.sleepycat.asm.ClassWriter
Adds an UTF8 string to the constant pool of the class being build.
next - Variable in class com.sleepycat.asm.AnnotationWriter
Next annotation writer.
next - Variable in class com.sleepycat.asm.Attribute
The next attribute in this attribute list.
next - Variable in class com.sleepycat.asm.Edge
The next edge in the list of successors of the originating basic block.
next - Variable in class com.sleepycat.asm.Handler
Next exception handler block info.
next - Variable in class com.sleepycat.asm.Item
Link to another constant pool item, used for collision lists in the constant pool's hash table.
next - Variable in class com.sleepycat.asm.Label
The next basic block in the basic block stack.
next() - Method in class com.sleepycat.collections.BlockIterator
 
next() - Method in class com.sleepycat.collections.StoredIterator
Returns the next element in the iteration.
next(SortedMap<Long, FileSummary>) - Method in class com.sleepycat.je.cleaner.FilesToMigrate
Returns the next file file to be migrated.
next() - Method in class com.sleepycat.je.cleaner.OffsetList.Segment
Returns the next segment or null if this is the tail segment.
next() - Method in class com.sleepycat.je.cleaner.PackedOffsets.Iterator
 
next() - Method in class com.sleepycat.je.rep.utilint.FreePortLocator
Returns the next free port.
next() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.LogChangeIterator
 
next() - Method in class com.sleepycat.je.utilint.TinyHashSet.SingleElementIterator
 
next() - Method in class com.sleepycat.persist.BasicCursor
 
next(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
next() - Method in class com.sleepycat.persist.BasicIterator
 
next() - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the next value and returns it, or returns null if there are no more values in the cursor range.
next(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the next value and returns it, or returns null if there are no more values in the cursor range.
next() - Method in interface com.sleepycat.persist.ForwardCursor
Moves the cursor to the next value and returns it, or returns null if there are no more values in the cursor range.
next(LockMode) - Method in interface com.sleepycat.persist.ForwardCursor
Moves the cursor to the next value and returns it, or returns null if there are no more values in the cursor range.
nextAvailableLsn - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
nextDup() - Method in class com.sleepycat.persist.BasicCursor
 
nextDup(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
nextDup() - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the next value with the same key (duplicate) and returns it, or returns null if no more values are present for the key at the current position.
nextDup(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the next value with the same key (duplicate) and returns it, or returns null if no more values are present for the key at the current position.
nextDup(LockMode) - Method in class com.sleepycat.persist.SubIndexCursor
 
nextEntryOffset - Variable in class com.sleepycat.je.log.FileReader
 
nextIndex() - Method in class com.sleepycat.collections.BlockIterator
 
nextIndex() - Method in class com.sleepycat.collections.StoredIterator
Returns the index of the element that would be returned by a subsequent call to next.
nextNoDup() - Method in class com.sleepycat.persist.BasicCursor
 
nextNoDup(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
nextNoDup() - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the next value with a different key and returns it, or returns null if there are no more unique keys in the cursor range.
nextNoDup(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the next value with a different key and returns it, or returns null if there are no more unique keys in the cursor range.
nextNoDup(LockMode) - Method in class com.sleepycat.persist.SubIndexCursor
 
nextPayloadToken() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Message
Returns the next token in the payload.
nextProposal() - Method in class com.sleepycat.je.rep.elections.Proposer
Creates the next unique Proposal to be used
nextProposal() - Method in class com.sleepycat.je.rep.elections.RankingProposer
Returns a proposal number.
nextProposal() - Method in class com.sleepycat.je.rep.elections.TimebasedProposalGenerator
Returns the next Proposal greater than all previous proposals returned on this machine.
nextWindow() - Method in class com.sleepycat.je.rep.util.ldiff.Window
Advance the window to the next block of records and update the rolling checksum.
nFileOpens - Variable in class com.sleepycat.je.log.FileManager
 
nFSyncTime - Variable in class com.sleepycat.je.log.FileManager
 
nFullBINFlush - Variable in class com.sleepycat.je.recovery.Checkpointer.FlushStats
 
nFullBINFlushThisRun - Variable in class com.sleepycat.je.recovery.Checkpointer.FlushStats
 
nFullINFlush - Variable in class com.sleepycat.je.recovery.Checkpointer.FlushStats
 
nFullINFlushThisRun - Variable in class com.sleepycat.je.recovery.Checkpointer.FlushStats
 
nINsCleaned - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nINsDead - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nINsMigrated - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nINsObsolete - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nLNQueueHits - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nLNsCleaned - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nLNsDead - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nLNsLocked - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nLNsMarked - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nLNsMigrated - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nLNsObsolete - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nLockTables - Variable in class com.sleepycat.je.txn.LockManager
 
nLogFSyncs - Variable in class com.sleepycat.je.log.FileManager
 
nMarkedLNsProcessed - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nMessagesRead - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
nMessagesWritten - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
NO_CONSISTENCY - Static variable in class com.sleepycat.je.rep.NoConsistencyRequiredPolicy
Convenience instance.
NO_ENV - Static variable in class com.sleepycat.je.utilint.LoggerUtils
 
NO_FSYNC_NEEDED - Static variable in class com.sleepycat.je.log.FSyncManager.FSyncGroup
 
NO_OVERWRITE - Static variable in class com.sleepycat.je.dbi.Operation
 
NO_REPLICATE - Static variable in class com.sleepycat.je.log.DbOpReplicationContext
 
NO_REPLICATE - Static variable in class com.sleepycat.je.log.ReplicationContext
 
NO_RETURN_ENTRY - Static variable in class com.sleepycat.persist.BasicIndex
 
NOARG_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of instructions without any argument.
NOCHECK - Static variable in class com.sleepycat.je.rep.impl.node.NameIdPair
 
NOCHECK_NODE_ID - Static variable in class com.sleepycat.je.rep.impl.node.NameIdPair
 
NoConsistencyRequiredPolicy - Class in com.sleepycat.je.rep
A consistency policy that lets a transaction on a replica using this policy proceed regardless of the state of the Replica relative to the Master.
NoConsistencyRequiredPolicy() - Constructor for class com.sleepycat.je.rep.NoConsistencyRequiredPolicy
Create a NoConsistencyRequiredPolicy.
node - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureNode
 
Node - Class in com.sleepycat.je.tree
A Node contains all the common base information for any JE B-Tree node.
Node() - Constructor for class com.sleepycat.je.tree.Node
Only for subclasses.
NODE_DUP_TREE_MAX_ENTRIES - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
this property no longer has any effect; DatabaseConfig.setNodeMaxEntries(int) should be used instead.
NODE_HOST_PORT - Static variable in class com.sleepycat.je.rep.impl.RepParams
Names the host (or interface) and port associated with the node in the replication group, e.g.
NODE_HOST_PORT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
Names the hostname and port associated with this node in the replication group, e.g.
NODE_MAX - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
NODE_MAX_DUPTREE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
NODE_MAX_ENTRIES - Static variable in class com.sleepycat.je.EnvironmentConfig
The maximum number of entries in an internal btree node.
NODE_NAME - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
NODE_NAME - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The node name uniquely identifies this node within the replication group.
NODE_NOT_EMPTY - Static variable in exception com.sleepycat.je.tree.NodeNotEmptyException
 
NODE_PRIORITY - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
NODE_PRIORITY - Static variable in class com.sleepycat.je.rep.ReplicationMutableConfig
The election priority associated with this node.
NODE_STATE_REQ - Variable in class com.sleepycat.je.rep.impl.NodeStateProtocol
 
NODE_STATE_RESP - Variable in class com.sleepycat.je.rep.impl.NodeStateProtocol
 
NODE_TYPE - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
NODE_TYPE - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The type of this node.
nodeDb - Variable in class com.sleepycat.je.log.LogContext
Database of the node(s), or null if entry is not a node.
nodeId - Variable in class com.sleepycat.je.recovery.Checkpointer.CheckpointReference
 
nodeId - Variable in class com.sleepycat.je.tree.TrackingInfo
 
NodeNotEmptyException - Exception in com.sleepycat.je.tree
Error to indicate that a bottom level BIN is not empty during a delete subtree operation.
NodeNotEmptyException() - Constructor for exception com.sleepycat.je.tree.NodeNotEmptyException
 
NodeSequence - Class in com.sleepycat.je.dbi
NodeSequence encapsulates the generation and maintenance of a sequence for generating node IDs and transient LSNs.
NodeSequence(EnvironmentImpl) - Constructor for class com.sleepycat.je.dbi.NodeSequence
 
NodeState - Class in com.sleepycat.je.rep.impl.node
NodeState encapsulates the current replicator state, and the ability to wait for state transition and fire state change notifications.
NodeState(NameIdPair, RepImpl) - Constructor for class com.sleepycat.je.rep.impl.node.NodeState
 
NodeState - Class in com.sleepycat.je.rep
The current state of a replication node and the application this node is running in.
NodeState(String, String, ReplicatedEnvironment.State, String, JEVersion, long, long, long, int, int, byte[], double) - Constructor for class com.sleepycat.je.rep.NodeState
 
NodeStateProtocol - Class in com.sleepycat.je.rep.impl
Defines the protocol used in support of node state querying.
NodeStateProtocol(String, NameIdPair, RepImpl) - Constructor for class com.sleepycat.je.rep.impl.NodeStateProtocol
 
NodeStateProtocol.NodeStateRequest - Class in com.sleepycat.je.rep.impl
 
NodeStateProtocol.NodeStateRequest(String) - Constructor for class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateRequest
 
NodeStateProtocol.NodeStateRequest(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateRequest
 
NodeStateProtocol.NodeStateResponse - Class in com.sleepycat.je.rep.impl
 
NodeStateProtocol.NodeStateResponse(String, String, long, ReplicatedEnvironment.State) - Constructor for class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
NodeStateProtocol.NodeStateResponse(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
NodeStateService - Class in com.sleepycat.je.rep.impl
The service registered by a RepNode to answer the state request from another node.
NodeStateService(ServiceDispatcher, RepNode) - Constructor for class com.sleepycat.je.rep.impl.NodeStateService
 
NodeStateService.NodeStateServiceRunnable - Class in com.sleepycat.je.rep.impl
 
NodeStateService.NodeStateServiceRunnable(SocketChannel, NodeStateProtocol) - Constructor for class com.sleepycat.je.rep.impl.NodeStateService.NodeStateServiceRunnable
 
NodeType - Enum in com.sleepycat.je.rep
The different types of nodes that can be in a replication group.
nonBlockingLock(long, LockType, boolean, DatabaseImpl) - Method in class com.sleepycat.je.txn.Locker
Request a non-blocking lock of the given type on the given LSN.
NONE - Static variable in class com.sleepycat.je.tree.INTargetRep
 
NONE - Static variable in class com.sleepycat.je.txn.LockType
NONE is used for requesting a dirty read and does not appear in the conflict or upgrade matrices.
NonPersistentFormat - Class in com.sleepycat.persist.impl
Format for a non-persistent class that is only used for declared field types and arrays.
NonPersistentFormat(Catalog, Class) - Constructor for class com.sleepycat.persist.impl.NonPersistentFormat
 
nonTxnOperationEnd() - Method in class com.sleepycat.je.txn.BasicLocker
Release locks and close the cursor at the end of the operation.
nonTxnOperationEnd() - Method in class com.sleepycat.je.txn.Locker
Releases locks and closes the locker at the end of a non-transactional cursor operation.
nonTxnOperationEnd() - Method in class com.sleepycat.je.txn.Txn
Created transactions do nothing at the end of the operation.
NOP - Static variable in interface com.sleepycat.asm.Opcodes
 
nOpenFiles - Variable in class com.sleepycat.je.log.FileManager
 
NORMAL - Static variable in class com.sleepycat.asm.Edge
Denotes a normal control flow graph edge.
NORMAL - Static variable in class com.sleepycat.je.tree.Tree.SearchType
 
normalizeLevel(IN, int) - Static method in class com.sleepycat.je.evictor.TargetSelector
Normalize the tree level of the given IN.
notAllowedException() - Static method in class com.sleepycat.je.SecondaryDatabase
 
noteINListChange(int) - Method in class com.sleepycat.je.evictor.Evictor
Called whenever INs are added to, or removed from, the INList.
noteINListChange(int) - Method in class com.sleepycat.je.evictor.PrivateSelector
Do nothing.
noteINListChange(int) - Method in class com.sleepycat.je.evictor.SharedSelector
After 1/INIT_SIZE_THRESHOLD of all INs have been changed, reinitialize the sizes.
noteINListChange(int) - Method in class com.sleepycat.je.evictor.TargetSelector
Called whenever INs are added to, or removed from, the INList.
noteLatch(Object) - Method in class com.sleepycat.je.latch.LatchTable
Only call under the assert system.
noteMemoryExceeded() - Method in interface com.sleepycat.je.dbi.SortedLSNTreeWalker.TreeNodeProcessor
 
notePassedCheckpointEnd() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
If we see a checkpoint end record, see if it is a barrier to rolling back, and advance the file reader position.
notePassedCommits(Timestamp, long, VLSN, long) - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
The reader saw a transaction commit.
notePrepare() - Method in class com.sleepycat.je.txn.TxnManager
Called when XATransaction is prepared.
noteProgress(MasterTransfer.VLSNProgress) - Method in class com.sleepycat.je.rep.impl.node.MasterTransfer
Accepts a Progress event and posts it to our queue for processing by the Master Transfer operation thread.
noteRepChange(INArrayRep<ARRAY_BASE_TYPE, REP_ENUM_TYPE, ELEMENT_TYPE>, IN) - Method in class com.sleepycat.je.tree.INArrayRep
Performs the bookkeeping associated with a representation change.
noteRepGroupDbChange() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
noteReplicaAck(long) - Method in class com.sleepycat.je.rep.stream.FeederTxns
Notes that an acknowledgment was received from a replica.
noteTriggerDb(DatabaseImpl) - Method in class com.sleepycat.je.txn.Txn
Accumulates the set of databases for which transaction commit/abort triggers must be run.
noteWriteHandleClose() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Decrements the write count and returns the updated value.
noteWriteHandleOpen() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Increments the write count and returns the updated value.
notify(Proposer.Proposal, Protocol.Value) - Method in class com.sleepycat.je.rep.elections.Elections.ElectionListener
The Listener protocol announcing election results.
notify(Proposer.Proposal, Protocol.Value) - Method in interface com.sleepycat.je.rep.elections.Learner.Listener
 
notify(NewMasterEvent) - Method in interface com.sleepycat.je.rep.monitor.MonitorChangeListener
The method is invoked whenever there is new master associated with the replication group.
notify(GroupChangeEvent) - Method in interface com.sleepycat.je.rep.monitor.MonitorChangeListener
The method is invoked whenever there is a change in the composition of the replication group.
notify(JoinGroupEvent) - Method in interface com.sleepycat.je.rep.monitor.MonitorChangeListener
The method is invoked whenever a node joins the group, by successfully opening its first ReplicatedEnvironment handle.
notify(LeaveGroupEvent) - Method in interface com.sleepycat.je.rep.monitor.MonitorChangeListener
The method is invoked whenever a node leaves the group by closing its last ReplicatedEnvironment handle.
notify(Proposer.Proposal, Protocol.Value) - Method in class com.sleepycat.je.rep.stream.MasterChangeListener
Implements the Listener protocol.
notifyGroupChange(String, GroupChangeEvent.GroupChangeType) - Method in class com.sleepycat.je.rep.impl.node.MonitorEventManager
Fire a GroupChangeEvent.
notifyGroupChange(GroupChangeEvent) - Method in class com.sleepycat.je.rep.monitor.Monitor
Notify the MonitorChangeListener that a GroupChangeEvent occurred.
notifyJoin(JoinGroupEvent) - Method in class com.sleepycat.je.rep.monitor.Monitor
Notify the MonitorChangeListener that a JoinGroupEvent happens.
notifyJoinGroup() - Method in class com.sleepycat.je.rep.impl.node.MonitorEventManager
Fire a JoinGroupEvent.
notifyLeave(LeaveGroupEvent) - Method in class com.sleepycat.je.rep.monitor.Monitor
Notify the MonitorChangeListener that a LeaveGroupEvent occurred.
notifyLeaveGroup(LeaveGroupEvent.LeaveReason) - Method in class com.sleepycat.je.rep.impl.node.MonitorEventManager
Fire a LeaveGroupEvent and wait for responses.
notifyTriggers(Locker, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Database
Notifies associated triggers when a put() or delete() is performed on the primary.
notInRollbackStartAndEnd(long, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
There should not be any txnal LNs between a rollback start and rollback end log entry.
NotPersistent - Annotation Type in com.sleepycat.persist.model
Overrides the default rules for field persistence and defines a field as being non-persistent even when it is not declared with the transient keyword.
NotTransient - Annotation Type in com.sleepycat.persist.model
Overrides the default rules for field persistence and defines a field as being persistent even when it is declared with the transient keyword.
nOwners(Long) - Method in class com.sleepycat.je.txn.DummyLockManager
 
nOwners() - Method in interface com.sleepycat.je.txn.Lock
 
nOwners() - Method in class com.sleepycat.je.txn.LockImpl
 
nOwners(Long) - Method in class com.sleepycat.je.txn.LockManager
Return the number of owners of this lock.
nOwners(Long) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
nOwners() - Method in class com.sleepycat.je.txn.ThinLockImpl
 
nOwnersInternal(Long, int) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of nWaiters.
nPendingLNsLocked - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nPendingLNsProcessed - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nRandomReadBytes - Variable in class com.sleepycat.je.log.FileManager
 
nRandomReads - Variable in class com.sleepycat.je.log.FileManager
 
nRandomWriteBytes - Variable in class com.sleepycat.je.log.FileManager
 
nRandomWrites - Variable in class com.sleepycat.je.log.FileManager
 
nReadNanos - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
nReadsFromWriteQueue - Variable in class com.sleepycat.je.log.FileManager
 
nRepeatIteratorReads - Variable in class com.sleepycat.je.cleaner.Cleaner
 
nReposition - Variable in class com.sleepycat.je.rep.stream.VLSNReader
 
nScanned - Variable in class com.sleepycat.je.rep.stream.VLSNReader
 
nSequentialReadBytes - Variable in class com.sleepycat.je.log.FileManager
 
nSequentialReads - Variable in class com.sleepycat.je.log.FileManager
 
nSequentialWriteBytes - Variable in class com.sleepycat.je.log.FileManager
 
nSequentialWrites - Variable in class com.sleepycat.je.log.FileManager
 
nToBeCleanedLNsProcessed - Variable in class com.sleepycat.je.cleaner.Cleaner
 
NULL - Static variable in class com.sleepycat.asm.Frame
The NULL type.
NULL - Static variable in interface com.sleepycat.asm.Opcodes
 
NULL - Static variable in class com.sleepycat.je.rep.impl.node.NameIdPair
 
NULL_CHANGE - Static variable in class com.sleepycat.je.rep.impl.RepNodeImpl
 
NULL_LSN - Static variable in class com.sleepycat.je.utilint.DbLsn
 
NULL_NODE_ID - Static variable in class com.sleepycat.je.rep.impl.node.NameIdPair
 
NULL_NODE_ID - Static variable in class com.sleepycat.je.tree.Node
 
NULL_POSITION - Static variable in class com.sleepycat.je.sync.impl.LogChangeSet
 
NULL_STRING_UTF_VALUE - Static variable in class com.sleepycat.bind.tuple.TupleOutput
We represent a null string as a single FF UTF character, which cannot occur in a UTF encoded string.
NULL_TXN_ID - Static variable in class com.sleepycat.je.txn.TxnManager
 
NULL_VLSN - Static variable in class com.sleepycat.je.utilint.VLSN
 
nullifyForeignKey(SecondaryDatabase, DatabaseEntry) - Method in class com.sleepycat.bind.serial.SerialSerialKeyCreator
 
nullifyForeignKey(D) - Method in class com.sleepycat.bind.serial.SerialSerialKeyCreator
Clears the index key in a data object.
nullifyForeignKey(SecondaryDatabase, DatabaseEntry) - Method in class com.sleepycat.bind.serial.TupleSerialKeyCreator
 
nullifyForeignKey(D) - Method in class com.sleepycat.bind.serial.TupleSerialKeyCreator
Clears the index key in the deserialized data entry.
nullifyForeignKey(D) - Method in class com.sleepycat.bind.serial.TupleSerialMarshalledKeyCreator
 
nullifyForeignKey(String) - Method in interface com.sleepycat.bind.tuple.MarshalledTupleKeyEntity
Clears the entity's secondary key fields for the given key name.
nullifyForeignKey(SecondaryDatabase, DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleTupleKeyCreator
 
nullifyForeignKey(TupleInput, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleTupleKeyCreator
Clears the index key in the tuple data entry.
nullifyForeignKey(TupleInput, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleTupleMarshalledKeyCreator
 
nullifyForeignKey(SecondaryDatabase, DatabaseEntry) - Method in interface com.sleepycat.je.ForeignKeyNullifier
Sets the foreign key reference to null in the datum of the primary database.
nullifyForeignKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.je.ForeignMultiKeyNullifier
Sets the foreign key reference to null in the datum of the primary database.
nullifyForeignKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistKeyCreator
 
nullifySecKey(Catalog, Object, String, Object) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
nullifySecKey(Catalog, Object, String, Object) - Method in class com.sleepycat.persist.impl.Format
Nullifies the given key field in the given RawObject -- rawAccess mode is implied.
nullOrEqual(Object, Object) - Static method in class com.sleepycat.persist.model.ClassMetadata
 
NUM_BATCHES_DESC - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
NUM_LOG_BUFFERS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
NUM_LOG_BUFFERS_DEFAULT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
numDBs - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.EnvInfo
 
numNodesScanned - Variable in class com.sleepycat.je.evictor.TargetSelector.ScanInfo
 
numRecords - Variable in class com.sleepycat.je.rep.util.ldiff.Block
 
nWaiters() - Method in class com.sleepycat.je.latch.Latch
Return the number of threads waiting.
nWaiters(Long) - Method in class com.sleepycat.je.txn.DummyLockManager
 
nWaiters() - Method in interface com.sleepycat.je.txn.Lock
 
nWaiters() - Method in class com.sleepycat.je.txn.LockImpl
 
nWaiters(Long) - Method in class com.sleepycat.je.txn.LockManager
Return the number of waiters for this lock.
nWaiters(Long) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
nWaiters() - Method in class com.sleepycat.je.txn.ThinLockImpl
 
nWaitersInternal(Long, int) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of nWaiters.
nWakeupRequests - Variable in class com.sleepycat.je.utilint.DaemonThread
 
nWriteNanos - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
nWriteQueueOverflow - Variable in class com.sleepycat.je.log.FileManager
 
nWriteQueueOverflowFailures - Variable in class com.sleepycat.je.log.FileManager
 
nWritesFromWriteQueue - Variable in class com.sleepycat.je.log.FileManager
 

O

OBFUSCATE - Static variable in class com.sleepycat.je.tree.Key.DumpType
 
OBJECT - Static variable in class com.sleepycat.asm.Frame
Base kind of the base reference types.
OBJECT - Static variable in class com.sleepycat.asm.Type
The sort of object reference types.
OBJECT_ARRAY_ITEM_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
OBJECT_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
ObjectArrayFormat - Class in com.sleepycat.persist.impl
An array of objects having a specified number of dimensions.
ObjectArrayFormat(Catalog, Class) - Constructor for class com.sleepycat.persist.impl.ObjectArrayFormat
 
objectArraySize(int) - Static method in class com.sleepycat.je.dbi.MemoryBudget
 
objectToBytes(Object, String) - Static method in class com.sleepycat.je.dbi.DatabaseImpl
Converts an arbitrary object to a serialized byte array.
objectToData(E, DatabaseEntry) - Method in interface com.sleepycat.bind.EntityBinding
Extracts the data entry from an entity Object.
objectToData(E, DatabaseEntry) - Method in class com.sleepycat.bind.serial.SerialSerialBinding
 
objectToData(E) - Method in class com.sleepycat.bind.serial.SerialSerialBinding
Extracts a data object from an entity object.
objectToData(E, DatabaseEntry) - Method in class com.sleepycat.bind.serial.TupleSerialBinding
 
objectToData(E) - Method in class com.sleepycat.bind.serial.TupleSerialBinding
Extracts a data object from an entity object.
objectToData(E) - Method in class com.sleepycat.bind.serial.TupleSerialMarshalledBinding
 
objectToData(E, DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleTupleBinding
 
objectToData(E, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleTupleBinding
Extracts a key tuple from an entity object.
objectToData(E, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleTupleMarshalledBinding
 
objectToData(Object, DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistEntityBinding
 
objectToEntry(byte[], DatabaseEntry) - Method in class com.sleepycat.bind.ByteArrayBinding
 
objectToEntry(E, DatabaseEntry) - Method in interface com.sleepycat.bind.EntryBinding
Converts an Object into a entry buffer.
objectToEntry(Object, DatabaseEntry) - Method in class com.sleepycat.bind.RecordNumberBinding
 
objectToEntry(E, DatabaseEntry) - Method in class com.sleepycat.bind.serial.SerialBinding
Serialize an object into an entry buffer.
objectToEntry(BigDecimal, TupleOutput) - Method in class com.sleepycat.bind.tuple.BigDecimalBinding
 
objectToEntry(BigInteger, TupleOutput) - Method in class com.sleepycat.bind.tuple.BigIntegerBinding
 
objectToEntry(Boolean, TupleOutput) - Method in class com.sleepycat.bind.tuple.BooleanBinding
 
objectToEntry(Byte, TupleOutput) - Method in class com.sleepycat.bind.tuple.ByteBinding
 
objectToEntry(Character, TupleOutput) - Method in class com.sleepycat.bind.tuple.CharacterBinding
 
objectToEntry(Double, TupleOutput) - Method in class com.sleepycat.bind.tuple.DoubleBinding
 
objectToEntry(Float, TupleOutput) - Method in class com.sleepycat.bind.tuple.FloatBinding
 
objectToEntry(Integer, TupleOutput) - Method in class com.sleepycat.bind.tuple.IntegerBinding
 
objectToEntry(Long, TupleOutput) - Method in class com.sleepycat.bind.tuple.LongBinding
 
objectToEntry(Integer, TupleOutput) - Method in class com.sleepycat.bind.tuple.PackedIntegerBinding
 
objectToEntry(Long, TupleOutput) - Method in class com.sleepycat.bind.tuple.PackedLongBinding
 
objectToEntry(Short, TupleOutput) - Method in class com.sleepycat.bind.tuple.ShortBinding
 
objectToEntry(BigDecimal, TupleOutput) - Method in class com.sleepycat.bind.tuple.SortedBigDecimalBinding
 
objectToEntry(Double, TupleOutput) - Method in class com.sleepycat.bind.tuple.SortedDoubleBinding
 
objectToEntry(Float, TupleOutput) - Method in class com.sleepycat.bind.tuple.SortedFloatBinding
 
objectToEntry(Integer, TupleOutput) - Method in class com.sleepycat.bind.tuple.SortedPackedIntegerBinding
 
objectToEntry(Long, TupleOutput) - Method in class com.sleepycat.bind.tuple.SortedPackedLongBinding
 
objectToEntry(String, TupleOutput) - Method in class com.sleepycat.bind.tuple.StringBinding
 
objectToEntry(E, DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleBinding
 
objectToEntry(E, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleBinding
Converts a key or data object to a tuple entry.
objectToEntry(TupleInput, DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleInputBinding
 
objectToEntry(E, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleMarshalledBinding
 
objectToEntry(RepGroupImpl, TupleOutput) - Method in class com.sleepycat.je.rep.impl.RepGroupDB.GroupBinding
 
objectToEntry(RepNodeImpl, TupleOutput) - Method in class com.sleepycat.je.rep.impl.RepGroupDB.NodeBinding
 
objectToEntry(VLSNRange, TupleOutput) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange.VLSNRangeBinding
 
objectToEntry(LogChangeSet, TupleOutput) - Method in class com.sleepycat.je.sync.impl.LogChangeSet.LogChangeSetBinding
 
objectToEntry(Object, DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistKeyBinding
 
objectToHex(TupleBinding<T>, T) - Static method in class com.sleepycat.je.rep.impl.RepGroupImpl
Serializes an object by converting its TupleBinding byte based representation into the hex characters deonoting the bytes.
objectToKey(E, DatabaseEntry) - Method in interface com.sleepycat.bind.EntityBinding
Extracts the key entry from an entity Object.
objectToKey(E, DatabaseEntry) - Method in class com.sleepycat.bind.serial.SerialSerialBinding
 
objectToKey(E) - Method in class com.sleepycat.bind.serial.SerialSerialBinding
Extracts a key object from an entity object.
objectToKey(E, DatabaseEntry) - Method in class com.sleepycat.bind.serial.TupleSerialBinding
 
objectToKey(E, TupleOutput) - Method in class com.sleepycat.bind.serial.TupleSerialBinding
Extracts a key tuple from an entity object.
objectToKey(E, TupleOutput) - Method in class com.sleepycat.bind.serial.TupleSerialMarshalledBinding
 
objectToKey(E, DatabaseEntry) - Method in class com.sleepycat.bind.tuple.TupleTupleBinding
 
objectToKey(E, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleTupleBinding
Extracts a key tuple from an entity object.
objectToKey(E, TupleOutput) - Method in class com.sleepycat.bind.tuple.TupleTupleMarshalledBinding
 
objectToKey(Object, DatabaseEntry) - Method in class com.sleepycat.persist.impl.PersistEntityBinding
 
objName - Variable in class com.sleepycat.je.jmx.plugin.Stats
 
obsoleteBINDeltaCount - Variable in class com.sleepycat.je.cleaner.INSummary
 
obsoleteBINDeltaSize - Variable in class com.sleepycat.je.cleaner.INSummary
 
obsoleteDupsAllowed - Variable in class com.sleepycat.je.log.LogContext
Whether it is possible that the previous version of this log entry is already marked obsolete.
obsoleteINCount - Variable in class com.sleepycat.je.cleaner.DbFileSummary
 
obsoleteINCount - Variable in class com.sleepycat.je.cleaner.FileSummary
 
obsoleteINCount - Variable in class com.sleepycat.je.cleaner.INSummary
 
obsoleteINSize - Variable in class com.sleepycat.je.cleaner.INSummary
 
obsoleteLNCount - Variable in class com.sleepycat.je.cleaner.DbFileSummary
 
obsoleteLNCount - Variable in class com.sleepycat.je.cleaner.FileSummary
 
obsoleteLNSize - Variable in class com.sleepycat.je.cleaner.DbFileSummary
 
obsoleteLNSize - Variable in class com.sleepycat.je.cleaner.FileSummary
 
obsoleteLNSizeCounted - Variable in class com.sleepycat.je.cleaner.DbFileSummary
 
obsoleteLNSizeCounted - Variable in class com.sleepycat.je.cleaner.FileSummary
 
obsoleteWriteLockInfo - Variable in class com.sleepycat.je.log.LogContext
Set of obsolete LSNs which are counted when logging a commit entry.
off - Variable in class com.sleepycat.util.FastInputStream
 
OffsetList - Class in com.sleepycat.je.cleaner
List of LSN offsets as a linked list of segments.
OffsetList() - Constructor for class com.sleepycat.je.cleaner.OffsetList
 
OffsetList.Segment - Class in com.sleepycat.je.cleaner
One segment of a OffsetList containing at most SEGMENT_CAPACITY values.
OffsetList.Segment() - Constructor for class com.sleepycat.je.cleaner.OffsetList.Segment
 
OK_RESP - Variable in class com.sleepycat.je.rep.impl.TextProtocol
 
oldDB - Variable in class com.sleepycat.je.dbi.DbTree.TruncateDbResult
 
oldLsn - Variable in class com.sleepycat.je.log.LogItem
The previous version of the node to be counted as obsolete, or NULL_LSN if the entry is not a node or has no old LSN.
oldSize - Variable in class com.sleepycat.je.log.LogItem
 
onForeignKeyDelete(Locker, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryDatabase
Called by the ForeignKeyTrigger when a record in the foreign database is deleted.
onSync(Database) - Method in interface com.sleepycat.persist.impl.Store.SyncHook
 
onWakeup() - Method in class com.sleepycat.je.cleaner.FileProcessor
Activates the cleaner.
onWakeup() - Method in class com.sleepycat.je.incomp.INCompressor
 
onWakeup() - Method in class com.sleepycat.je.recovery.Checkpointer
Called whenever the DaemonThread wakes up from a sleep.
onWakeup() - Method in class com.sleepycat.je.utilint.DaemonThread
onWakeup is synchronized to ensure that multiple invocations of the DaemonThread aren't made.
OP_CHECKPOINT - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
OP_CHECKPOINT - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_CLEAN - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
OP_CLEAN - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_DB_NAMES - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
OP_DB_NAMES - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_DB_STAT - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
OP_DB_STAT - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_DUMP_REPSTATS - Static variable in class com.sleepycat.je.rep.jmx.RepJEMonitor
 
OP_DUMP_STATE - Static variable in class com.sleepycat.je.rep.jmx.RepJEMonitor
 
OP_ENV_CONFIG - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_ENV_STAT - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
OP_ENV_STAT - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_EVICT - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
OP_EVICT - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_GET_REP_TIPS - Static variable in class com.sleepycat.je.rep.jmx.RepJEMonitor
 
OP_GET_TIPS - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_RESET_LOGGING - Static variable in class com.sleepycat.je.jmx.JEDiagnostics
 
OP_RESET_LOGGING_LEVEL - Static variable in class com.sleepycat.je.jmx.JEDiagnostics
 
OP_SYNC - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
OP_SYNC - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
OP_TXN_STAT - Static variable in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
 
OP_TXN_STAT - Static variable in class com.sleepycat.je.jmx.JEMonitor
 
Opcodes - Interface in com.sleepycat.asm
Defines the JVM opcodes, access flags and array type codes.
OPEN - Static variable in class com.sleepycat.je.dbi.DbEnvState
 
open() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Not much to do, mark state.
open(File, EnvironmentConfig, Map<String, String>) - Method in class com.sleepycat.je.rep.utilint.DbCacheSizeRepEnv
 
open(Transaction, Environment, boolean) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
open(Transaction, Environment, boolean) - Method in interface com.sleepycat.je.trigger.PersistentTrigger
The trigger method invoked after the open of the first Database writable handle.
open(File, EnvironmentConfig, Map<String, String>) - Method in interface com.sleepycat.je.utilint.DbCacheSizeRepEnv
 
openBlockingChannel(InetSocketAddress, boolean, int, int) - Static method in class com.sleepycat.je.rep.utilint.RepUtils
Create a socket channel with the designated properties
openBlockingChannel(InetSocketAddress, boolean, int) - Static method in class com.sleepycat.je.rep.utilint.RepUtils
An overloading of the above when the receive buffer size is to be defaulted.
openChangeReader(String, boolean, long) - Method in class com.sleepycat.je.sync.SyncProcessor
Called internally by the SyncProcessor during a sync operation to obtain the set of local changes to be transferred to the external system.
openCursor(Database, CursorConfig, boolean, Transaction) - Method in class com.sleepycat.collections.CurrentTransaction
Opens a cursor for a given database, dup'ing an existing CDB cursor if one is open for the current thread.
openCursor(Transaction, CursorConfig) - Method in class com.sleepycat.je.Database
Returns a cursor into the database.
openCursor(DiskOrderedCursorConfig) - Method in class com.sleepycat.je.Database
Create a ForwardCursor to iterate over the records in 'this'.
openCursor(Transaction, CursorConfig) - Method in class com.sleepycat.je.SecondaryDatabase
Obtain a cursor on a database, returning a SecondaryCursor.
openCursorHook(DatabaseImpl) - Method in class com.sleepycat.je.rep.txn.ReplicaThreadLocker
Verifies that consistency requirements are met before allowing the cursor to be opened.
openCursorHook(DatabaseImpl) - Method in class com.sleepycat.je.txn.Locker
Overridden to perform actions in a non-transactional cursor when it is opened, for example, ReplicaThreadLocker performs consistency checks.
openDatabase(Environment, Transaction, String, String, DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
Returns null if the database is not found (and AllowCreate is false) or already exists (and ExclusiveCreate is true).
openDatabase(Transaction, String, DatabaseConfig) - Method in class com.sleepycat.je.Environment
Opens, and optionally creates, a Database.
openDatabase(String, DatabaseConfig) - Method in class com.sleepycat.je.jca.ra.JEConnection
 
openDatabase(String, DatabaseConfig) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
openDb(Environment, String) - Static method in class com.sleepycat.je.rep.util.ldiff.LDiffUtil
 
openedDatabaseHandles - Variable in class com.sleepycat.je.txn.Txn
 
openEnv(String) - Static method in class com.sleepycat.je.rep.util.ldiff.LDiffUtil
 
openEnv(boolean) - Method in class com.sleepycat.je.util.DbDump
 
openEnv() - Method in class com.sleepycat.je.util.DbVerify
 
openExisting() - Method in class com.sleepycat.persist.impl.PersistCatalog
Increments the reference count for a catalog that is already open.
openInternalDatabase(Environment, Transaction, String, DatabaseConfig) - Static method in class com.sleepycat.je.DbInternal
 
openInternalDatabase(Transaction, String, DatabaseConfig) - Method in class com.sleepycat.je.Environment
Opens an internal database for internal JE use.
openReadOnly - Variable in class com.sleepycat.je.util.DbVerify
 
openSecondaryCursor(Transaction, CursorConfig) - Method in class com.sleepycat.je.SecondaryDatabase
openSecondaryDatabase(Environment, Transaction, String, String, Database, SecondaryConfig) - Static method in class com.sleepycat.compat.DbCompat
Returns null if the database is not found (and AllowCreate is false) or already exists (and ExclusiveCreate is true).
openSecondaryDatabase(Transaction, String, Database, SecondaryConfig) - Method in class com.sleepycat.je.Environment
Opens and optionally creates a SecondaryDatabase.
openSecondaryDatabase(String, Database, SecondaryConfig) - Method in class com.sleepycat.je.jca.ra.JEConnection
 
openSecondaryDatabase(String, Database, SecondaryConfig) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
openSequence(Transaction, DatabaseEntry, SequenceConfig) - Method in class com.sleepycat.je.Database
Opens a sequence in the database.
Operation - Class in com.sleepycat.je.dbi
An enumeration of different api call sources for replication, currently for debugging.
Operation() - Constructor for class com.sleepycat.je.dbi.Operation
 
operationEnd(boolean) - Method in class com.sleepycat.je.txn.BasicLocker
Release locks and close the cursor at the end of the operation.
operationEnd() - Method in class com.sleepycat.je.txn.Locker
The equivalent of calling operationEnd(true).
operationEnd(OperationStatus) - Method in class com.sleepycat.je.txn.Locker
A SUCCESS status equals operationOk.
operationEnd(boolean) - Method in class com.sleepycat.je.txn.Locker
Different types of transactions do different things when the operation ends.
operationEnd(boolean) - Method in class com.sleepycat.je.txn.Txn
 
OperationFailureException - Exception in com.sleepycat.je
Indicates that a failure has occurred that impacts the current operation and/or transaction.
OperationFailureException(Locker, boolean, String, Throwable) - Constructor for exception com.sleepycat.je.OperationFailureException
For internal use only.
OperationFailureException(String) - Constructor for exception com.sleepycat.je.OperationFailureException
For internal use only.
OperationFailureException(String, OperationFailureException) - Constructor for exception com.sleepycat.je.OperationFailureException
For internal use only.
operationList - Variable in class com.sleepycat.je.jmx.JEMBean
 
OperationStatus - Enum in com.sleepycat.je
Status values from database operations.
opName - Variable in class com.sleepycat.je.jmx.plugin.Stats
 
OPTIONAL_READ_UNCOMMITTED - Static variable in class com.sleepycat.compat.DbCompat
 
optionalLog(LogManager) - Method in class com.sleepycat.je.tree.IN
Log this IN and clear the dirty flag.
optionalLog(EnvironmentImpl, DatabaseImpl, byte[], byte[], long, Locker, WriteLockInfo, ReplicationContext) - Method in class com.sleepycat.je.tree.LN
Convenience logging method.
optionalLogProvisional(LogManager, IN) - Method in class com.sleepycat.je.tree.IN
Log this node provisionally and clear the dirty flag.
optionalLogProvisional(EnvironmentImpl, DatabaseImpl, byte[], long, ReplicationContext) - Method in class com.sleepycat.je.tree.LN
Convenience logging method.
optionalModifyDbRoot(DatabaseImpl) - Method in class com.sleepycat.je.dbi.DbTree
Check deferred write settings before writing the MapLN.
ordered - Variable in class com.sleepycat.collections.DataView
 
outputDirectory - Variable in class com.sleepycat.je.util.DbDump
 
outputFile - Variable in class com.sleepycat.je.util.DbDump
 
outputStackMax - Variable in class com.sleepycat.asm.Label
Maximum height reached by the output stack, relatively to the top of the input stack.
outputToEntry(TupleOutput, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.TupleBase
Utility method to set the data in a entry buffer to the data in a tuple output object.
OutputWireRecord - Class in com.sleepycat.je.rep.stream
Format for log entries sent across the wire for replication.
OutputWireRecord(EnvironmentImpl, LogEntryHeader, ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.OutputWireRecord
Make a OutputWireRecord from FileReader output for sending out.
OutputWireRecord(EnvironmentImpl, LogItem) - Constructor for class com.sleepycat.je.rep.stream.OutputWireRecord
Creates an OutputWireRecord from a log item.
OutputWireRecord(EnvironmentImpl, InputWireRecord) - Constructor for class com.sleepycat.je.rep.stream.OutputWireRecord
 
outputWireRecord - Variable in class com.sleepycat.je.rep.stream.Protocol.Entry
 
overrideDurability(Durability) - Method in class com.sleepycat.je.TransactionConfig
Used internally to configure Durability, modifying the existing Durability or explicit sync configuration.
owner - Variable in class com.sleepycat.asm.Frame
The label (i.e.
owner - Variable in class com.sleepycat.asm.Handle
The internal name of the field or method designed by this handle.
owner() - Method in class com.sleepycat.je.latch.Latch
Used only for unit tests.
owns(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 

P

pack(long[]) - Method in class com.sleepycat.je.cleaner.PackedOffsets
Packs the given offsets, replacing any offsets stored in this object.
PackedInteger - Class in com.sleepycat.util
Static methods for reading and writing packed integers.
PackedInteger() - Constructor for class com.sleepycat.util.PackedInteger
 
PackedIntegerBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for an unsorted Integer primitive wrapper or an unsorted int primitive, that stores the value in the smallest number of bytes possible.
PackedIntegerBinding() - Constructor for class com.sleepycat.bind.tuple.PackedIntegerBinding
 
PackedLongBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for an unsorted Long primitive wrapper or an unsorted long primitive, that stores the value in the smallest number of bytes possible.
PackedLongBinding() - Constructor for class com.sleepycat.bind.tuple.PackedLongBinding
 
PackedObsoleteInfo - Class in com.sleepycat.je.cleaner
A sequence of obsolete info.
PackedObsoleteInfo() - Constructor for class com.sleepycat.je.cleaner.PackedObsoleteInfo
 
packedObsoleteInfo - Variable in class com.sleepycat.je.log.LogContext
Sequence of packed obsolete info which is counted when logging a non-provisional IN.
PackedOffsets - Class in com.sleepycat.je.cleaner
Stores a sorted list of LSN offsets in a packed short representation.
PackedOffsets() - Constructor for class com.sleepycat.je.cleaner.PackedOffsets
Creates an empty object.
PackedOffsets.Iterator - Class in com.sleepycat.je.cleaner
An iterator over all offsets.
parent - Variable in class com.sleepycat.je.tree.INLogItem
Parent IN of IN to be logged, or null for the root IN.
parent - Variable in class com.sleepycat.je.tree.SearchResult
 
parentIndex - Variable in class com.sleepycat.je.tree.INLogItem
Index of parent slot for IN to be logged.
parse(String) - Static method in class com.sleepycat.je.Durability
Parses the string and returns the durability it represents.
parse(String) - Method in interface com.sleepycat.je.rep.elections.Proposer.ProposalParser
Converts the wire format back into a Proposal
parse(String) - Method in interface com.sleepycat.je.rep.elections.Protocol.ValueParser
Converts the wire format back into a Value
parse(String) - Method in class com.sleepycat.je.rep.impl.TextProtocol
Parses a line into a Request/Response message.
parseArgs(String[]) - Method in class com.sleepycat.je.rep.utilint.DbDumpGroup
Parse the command line parameters.
parseArgs(String[]) - Method in class com.sleepycat.je.util.DbCacheSize
 
parseArgs(String[]) - Method in class com.sleepycat.je.util.DbDump
 
parseArgs(String[]) - Method in class com.sleepycat.je.util.DbStat
 
parseArgs(String[]) - Method in class com.sleepycat.je.util.DbVerify
 
parseDbName(String) - Method in class com.sleepycat.persist.impl.Store
Parses a whole DB name and returns an array of 2 strings where element 0 is the file name (always null for JE, always non-null for DB core) and element 1 is the logical DB name (always non-null for JE, may be null for DB core).
parseDbName(String, DatabaseNamer) - Static method in class com.sleepycat.persist.impl.Store
Allows passing a namer to a static method for testing.
parseDuration(String) - Static method in class com.sleepycat.je.utilint.PropUtil
Parses a String duration property (time + optional unit) and returns the value in millis.
parseRequest(String) - Method in class com.sleepycat.je.rep.impl.TextProtocol
Converts a request line into a requestMessage.
parseResponse(String) - Method in class com.sleepycat.je.rep.impl.TextProtocol
Converts a response line into a ResponseMessage.
partialCheckpointStartLsn - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
participate() - Method in class com.sleepycat.je.rep.elections.Elections
Permits the Election agent to start participating in elections held by the replication group, or initiate elections on behalf of this node.
passivatePrimary() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
PersistCatalog - Class in com.sleepycat.persist.impl
The catalog of class formats for a store, along with its associated model and mutations.
PersistCatalog(Environment, String, String, DatabaseConfig, EntityModel, Mutations, boolean, Store) - Constructor for class com.sleepycat.persist.impl.PersistCatalog
Creates a new catalog, opening the database and reading it from a given catalog database if it already exists.
PersistCatalog(PersistCatalog, String) - Constructor for class com.sleepycat.persist.impl.PersistCatalog
Creates a new catalog when a Replica refresh occurs.
PersistComparator - Class in com.sleepycat.persist.impl
The btree comparator for persistent key classes.
PersistComparator(PersistKeyBinding) - Constructor for class com.sleepycat.persist.impl.PersistComparator
 
Persistent - Annotation Type in com.sleepycat.persist.model
Identifies a persistent class that is not an Entity class or a simple type.
persistentEquals(DatabaseConfig) - Method in class com.sleepycat.je.DatabaseConfig
For unit tests, checks that the database configuration attributes that are saved persistently are equal.
PersistEntityBinding - Class in com.sleepycat.persist.impl
A persistence entity binding for a given entity class.
PersistEntityBinding(PersistCatalog, String, boolean) - Constructor for class com.sleepycat.persist.impl.PersistEntityBinding
Creates a key binding for a given entity class.
PersistentProxy<T> - Interface in com.sleepycat.persist.model
Implemented by a proxy class to represent the persistent state of a (non-persistent) proxied class.
PersistentTrigger - Interface in com.sleepycat.je.trigger
Placeholder to be used when persistent triggers are supported in the future.
PersistKeyAssigner - Class in com.sleepycat.persist.impl
Assigns primary keys from a Sequence.
PersistKeyAssigner(PersistKeyBinding, PersistEntityBinding, Sequence) - Constructor for class com.sleepycat.persist.impl.PersistKeyAssigner
 
PersistKeyBinding - Class in com.sleepycat.persist.impl
A persistence key binding for a given key class.
PersistKeyBinding(Catalog, String, boolean) - Constructor for class com.sleepycat.persist.impl.PersistKeyBinding
Creates a key binding for a given key class.
PersistKeyBinding(Catalog, Class, String[]) - Constructor for class com.sleepycat.persist.impl.PersistKeyBinding
Creates a key binding dynamically for use by PersistComparator.
PersistKeyCreator - Class in com.sleepycat.persist.impl
A persistence secondary key creator/nullifier.
PersistKeyCreator(Catalog, EntityMetadata, String, SecondaryKeyMetadata, boolean) - Constructor for class com.sleepycat.persist.impl.PersistKeyCreator
Creates a key creator/nullifier for a given entity class and key name.
PHASE1_HIGHER_PROPOSAL - Static variable in class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
PHASE1_NO_NON_ZERO_PRIO - Static variable in class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
PHASE1_NO_QUORUM - Static variable in class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
phase1NoNonZeroPrio - Variable in class com.sleepycat.je.rep.elections.Proposer
 
PHASE2_HIGHER_PROPOSAL - Static variable in class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
PHASE2_NO_QUORUM - Static variable in class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
pkey - Variable in class com.sleepycat.persist.BasicCursor
 
PLACEHOLDER - Static variable in class com.sleepycat.je.dbi.Operation
 
PointConsistencyPolicy - Class in com.sleepycat.je.rep.impl
This is used to ensure that the Replica has finished replaying or proceeded past the vlsn specified by the policy.
PointConsistencyPolicy(VLSN) - Constructor for class com.sleepycat.je.rep.impl.PointConsistencyPolicy
 
PointConsistencyPolicy(VLSN, long, TimeUnit) - Constructor for class com.sleepycat.je.rep.impl.PointConsistencyPolicy
 
policyToString(T) - Method in interface com.sleepycat.je.rep.utilint.RepUtils.ConsistencyPolicyFormat
 
poll(long, TimeUnit) - Method in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareBlockingQueue
Deprecated.
pollOrException(long, TimeUnit) - Method in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareBlockingQueue
 
pool - Variable in class com.sleepycat.asm.ClassWriter
The constant pool of this class.
POP - Static variable in interface com.sleepycat.asm.Opcodes
 
pop() - Method in class com.sleepycat.je.txn.TxnChain
Return information about the next item on the transaction chain and remove it from the chain.
POP2 - Static variable in interface com.sleepycat.asm.Opcodes
 
POPULATE_ENFORCES_CONSTRAINTS - Static variable in class com.sleepycat.compat.DbCompat
 
populateCache(StartupTracker.Counter) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Populate the profile for file selection.
port() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
position - Variable in class com.sleepycat.asm.Label
The position of this label in the code, if known.
position(DatabaseEntry, DatabaseEntry, LockMode, boolean) - Method in class com.sleepycat.je.Cursor
Internal version of getFirst/getLast that does no parameter checking.
position(Cursor, DatabaseEntry, DatabaseEntry, LockMode, boolean) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.position().
position(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode, boolean) - Method in class com.sleepycat.je.SecondaryCursor
Calls position() and retrieves primary data.
positionAndCheck(long, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.BackwardScanner
 
positionAndCheck(long, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.Scanner
Return true if this transactional log entry is something that should be rolled back in this rollback period.
positionAndCheck(long, long) - Method in class com.sleepycat.je.recovery.RollbackTracker.UnderConstructionScanner
 
positionBuffer(long) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
positionChildren(long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
positionFirstOrLast(boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
Position the cursor at the first or last record of the databaseImpl.
postCheckpointClose(boolean) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Release any resources from a subclass that need to be released after the closing checkpoint.
postCheckpointClose(boolean) - Method in class com.sleepycat.je.rep.impl.RepImpl
Close any resources that need to be closed after the closing checkpoint.
postFetchInit(DatabaseImpl) - Method in class com.sleepycat.je.log.entry.BaseEntry
 
postFetchInit(DatabaseImpl) - Method in class com.sleepycat.je.log.entry.LNLogEntry
See postFetchInit(boolean).
postFetchInit(boolean) - Method in class com.sleepycat.je.log.entry.LNLogEntry
Converts the key/data for old format LNs in a duplicates DB.
postFetchInit(DatabaseImpl, long) - Method in class com.sleepycat.je.tree.FileSummaryLN
Initialize a node that has been faulted in from the log.
postFetchInit(DatabaseImpl, long) - Method in class com.sleepycat.je.tree.IN
Initialize a node that has been read in from the log.
postFetchInit(DatabaseImpl, long) - Method in class com.sleepycat.je.tree.MapLN
Initialize a node that has been faulted in from the log.
postFetchInit(DatabaseImpl, long) - Method in class com.sleepycat.je.tree.Node
 
postLogAbortHook(MasterTxn) - Method in class com.sleepycat.je.rep.impl.RepImpl
Releases the block latch lock, if held.
postLogAbortHook() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
postLogAbortHook() - Method in class com.sleepycat.je.txn.Txn
 
postLogCommitAbortHook(MasterTxn) - Method in class com.sleepycat.je.rep.impl.RepImpl
Removes any pending acknowledgments that were registered by the preLogCommitHook.
postLogCommitAbortHook() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
postLogCommitAbortHook() - Method in class com.sleepycat.je.txn.Txn
Invoked if the transaction associated with the preLogCommitHook was subsequently aborted, for example due to a lack of disk space.
postLogCommitHook(MasterTxn) - Method in class com.sleepycat.je.rep.impl.RepImpl
It ensures that the feeder obtains the requisite number of acknowledgments required for a successful commit.
postLogCommitHook(LogItem) - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
postLogCommitHook(LogItem) - Method in class com.sleepycat.je.txn.Txn
This hook is invoked after the commit record has been written to the log, but before write locks have been released, so that other application cannot see the changes made by the transaction.
postLogWork(LogEntryHeader, long) - Method in class com.sleepycat.je.log.entry.BaseEntry
Do any processing we need to do after logging, while under the logging latch.
postLogWork(LogEntryHeader, long) - Method in class com.sleepycat.je.log.entry.LNLogEntry
For LN entries, we need to record the latest LSN for that node with the owning transaction, within the protection of the log latch.
postLogWork(LogEntryHeader, long) - Method in interface com.sleepycat.je.log.entry.LogEntry
Do any processing we need to do after logging, while under the logging latch.
postRecoveryConversion() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Called after recovery but before any other initialization.
postRecoveryConversion() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
postRecoveryInit(DatabaseImpl, long) - Method in class com.sleepycat.je.tree.IN
Initialize a node read in during recovery.
postStartLNCount - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
postStartLNTxnCount - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
postStartMapLNCount - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
postStartMapLNTxnCount - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
PRE_HEARTBEAT_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
precedes(long) - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
precedes(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
preCheckpointEndFlush() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Do any work that must be done before the checkpoint end is written, as as part of the checkpoint process.
preCheckpointEndFlush() - Method in class com.sleepycat.je.rep.impl.RepImpl
Flush any information that needs to go out at checkpoint.
preload(long) - Method in class com.sleepycat.je.Database
Deprecated.
As of JE 2.0.83, replaced by Database.preload(PreloadConfig).

preload(long, long) - Method in class com.sleepycat.je.Database
Deprecated.
As of JE 2.0.101, replaced by Database.preload(PreloadConfig).

preload(PreloadConfig) - Method in class com.sleepycat.je.Database
Preloads the cache.
preload(PreloadConfig) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Preload the cache, using up to maxBytes bytes or maxMillsecs msec.
preload(DatabaseImpl[], PreloadConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
preload(Database[], PreloadConfig) - Method in class com.sleepycat.je.Environment
Preloads the cache with multiple databases.
PreloadConfig - Class in com.sleepycat.je
Specifies the attributes of an application invoked preload operation.
PreloadConfig() - Constructor for class com.sleepycat.je.PreloadConfig
Default configuration used if null is passed to Database.preload.
PreloadConfig.Phases - Enum in com.sleepycat.je
Preload progress listeners report this phase value, along with a count of the number if times that the preload has fetched from disk.
PreloadConfigBeanInfo - Class in com.sleepycat.je
 
PreloadConfigBeanInfo() - Constructor for class com.sleepycat.je.PreloadConfigBeanInfo
 
PreloadStats - Class in com.sleepycat.je
PreloadStats(int, int, int, int, int, int, int, PreloadStatus) - Constructor for class com.sleepycat.je.PreloadStats
 
PreloadStats() - Constructor for class com.sleepycat.je.PreloadStats
 
PreloadStatus - Class in com.sleepycat.je
Describes the result of the Database.preload operation.
PreloadStatus(String) - Constructor for class com.sleepycat.je.PreloadStatus
 
preLogAbortHook(MasterTxn) - Method in class com.sleepycat.je.rep.impl.RepImpl
Invoked before aborting a MasterTxn, this happens when the master is going to be a replica because of mastership transfer.
preLogAbortHook() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
preLogAbortHook() - Method in class com.sleepycat.je.txn.Txn
 
preLogCommitHook(MasterTxn) - Method in class com.sleepycat.je.rep.impl.RepImpl
This hook is used primarily to perform the final checks before allowing the commit operation to proceed.
preLogCommitHook() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
preLogCommitHook() - Method in class com.sleepycat.je.txn.Txn
This hook is invoked before the commit of a transaction that made changes to a replicated environment.
preLogWithoutLock(DatabaseImpl) - Method in class com.sleepycat.je.rep.txn.ReadonlyTxn
If logging occurs before locking, we must screen out write locks here.
preLogWithoutLock(DatabaseImpl) - Method in class com.sleepycat.je.rep.txn.ReplicaThreadLocker
If logging occurs before locking, we must screen out write locks here.
preLogWithoutLock(DatabaseImpl) - Method in class com.sleepycat.je.txn.BasicLocker
 
preLogWithoutLock(DatabaseImpl) - Method in class com.sleepycat.je.txn.Locker
In the case where logging occurs before locking, we must ensure that we're prepared to undo if logging succeeds but locking fails.
preLogWithoutLock(DatabaseImpl) - Method in class com.sleepycat.je.txn.Txn
If logging succeeds but locking fails, we need the database for undo.
premain(String, Instrumentation) - Static method in class com.sleepycat.persist.model.ClassEnhancer
Enhances classes as specified by a JVM -javaagent argument.
prepare(Xid) - Method in class com.sleepycat.je.txn.Txn
 
prepare(Xid) - Method in class com.sleepycat.je.XAEnvironment
 
PreparedTxn - Class in com.sleepycat.je.txn
A PreparedTxn is used at recovery for processing a TXN_PREPARE log entry.
prepareForInsert() - Static method in class com.sleepycat.je.dbi.CursorImpl.LockStanding
Creates WriteLockInfo that is appropriate for a newly inserted slot.
prepareForSlotReuse(int) - Method in class com.sleepycat.je.tree.IN
Called prior to changing a slot to contain a different logical node.
prepareForUpdate() - Method in class com.sleepycat.je.dbi.CursorImpl.LockStanding
Creates WriteLockInfo that is appropriate for an update or delete operation, after lockLN has been called.
preRecoveryCheckpointInit(RecoveryInfo) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
preRecoveryCheckpointInit(RecoveryInfo) - Method in class com.sleepycat.je.rep.impl.node.Replay
Actions that must be taken before the recovery checkpoint, whether the environment is read/write or read/only.
preRecoveryCheckpointInit(RecoveryInfo) - Method in class com.sleepycat.je.rep.impl.RepImpl
The VLSNIndex must be created, merged and flushed before the recovery checkpoint.
PRESERVE_RECORD_VERSION - Static variable in class com.sleepycat.je.rep.impl.RepParams
Internal parameter to preserve record version (VLSN).
preShutdown() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
Stop accepting new connections, while the individual services quiesce and shut themselves down.
preStartLNCount - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
preStartLNTxnCount - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
preStartMapLNCount - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
preStartMapLNTxnCount - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
prev - Variable in class com.sleepycat.asm.AnnotationWriter
Previous annotation writer.
prev() - Method in class com.sleepycat.persist.BasicCursor
 
prev(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
prev() - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the previous value and returns it, or returns null if there are no preceding values in the cursor range.
prev(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the previous value and returns it, or returns null if there are no preceding values in the cursor range.
prevDup() - Method in class com.sleepycat.persist.BasicCursor
 
prevDup(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
prevDup() - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the previous value with the same key (duplicate) and returns it, or returns null if no preceding values are present for the key at the current position.
prevDup(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the previous value with the same key (duplicate) and returns it, or returns null if no preceding values are present for the key at the current position.
prevDup(LockMode) - Method in class com.sleepycat.persist.SubIndexCursor
 
previous() - Method in class com.sleepycat.collections.BlockIterator
 
previous() - Method in class com.sleepycat.collections.StoredIterator
Returns the next element in the iteration.
previousIndex() - Method in class com.sleepycat.collections.BlockIterator
 
previousIndex() - Method in class com.sleepycat.collections.StoredIterator
Returns the index of the element that would be returned by a subsequent call to previous.
prevNoDup() - Method in class com.sleepycat.persist.BasicCursor
 
prevNoDup(LockMode) - Method in class com.sleepycat.persist.BasicCursor
 
prevNoDup() - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the preceding value with a different key and returns it, or returns null if there are no preceding unique keys in the cursor range.
prevNoDup(LockMode) - Method in interface com.sleepycat.persist.EntityCursor
Moves the cursor to the preceding value with a different key and returns it, or returns null if there are no preceding unique keys in the cursor range.
prevNoDup(LockMode) - Method in class com.sleepycat.persist.SubIndexCursor
 
PRI_KEY_VISITED_OFFSET - Static variable in class com.sleepycat.persist.impl.RecordInput
 
PrimaryIndex<PK,E> - Class in com.sleepycat.persist
The primary index for an entity class and its primary key.
PrimaryIndex(Database, Class<PK>, EntryBinding<PK>, Class<E>, EntityBinding<E>) - Constructor for class com.sleepycat.persist.PrimaryIndex
Creates a primary index without using an EntityStore.
PrimaryKey - Annotation Type in com.sleepycat.persist.model
Indicates the primary key field of an entity class.
PrimaryKeyAssigner - Interface in com.sleepycat.collections
An interface implemented to assign new primary key values.
primaryKeyBinding - Variable in class com.sleepycat.bind.serial.SerialSerialKeyCreator
 
PrimaryKeyMetadata - Class in com.sleepycat.persist.model
The metadata for a primary key field.
PrimaryKeyMetadata(String, String, String, String) - Constructor for class com.sleepycat.persist.model.PrimaryKeyMetadata
Used by an EntityModel to construct primary key metadata.
PrimaryKeyValueAdapter<V> - Class in com.sleepycat.persist
A ValueAdapter where the "value" is the primary key.
PrimaryKeyValueAdapter(Class<V>, EntryBinding) - Constructor for class com.sleepycat.persist.PrimaryKeyValueAdapter
 
PRIMITIVE_LONG_ARRAY_ITEM_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
PrimitiveArrayFormat - Class in com.sleepycat.persist.impl
An array of primitives having one dimension.
PrimitiveArrayFormat(Catalog, Class) - Constructor for class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
primitiveToWrapper(Class) - Static method in class com.sleepycat.persist.impl.SimpleCatalog
 
print(PrintStream) - Method in class com.sleepycat.je.util.DbSpace
 
PrintFileReader - Class in com.sleepycat.je.log
The PrintFileReader prints out the target log entries.
PrintFileReader(EnvironmentImpl, int, long, long, long, String, String, boolean, boolean, boolean) - Constructor for class com.sleepycat.je.log.PrintFileReader
Create this reader to start at a given LSN.
printHeader(PrintStream, boolean, boolean) - Method in class com.sleepycat.je.util.DbDump
 
printMemorySize() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
printMemorySize() - Method in class com.sleepycat.je.tree.IN
 
printStartupInfo(PrintStream) - Method in class com.sleepycat.je.Environment
Print a detailed report about the costs of different phases of environment startup.
printStartupInfo(PrintStream) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Print a detailed report about the costs of different phases of environment startup.
printUsage(String) - Method in class com.sleepycat.je.util.DbDump
 
printUsage(String) - Method in class com.sleepycat.je.util.DbVerify
 
PrivateEvictor - Class in com.sleepycat.je.evictor
An evictor for a private cache.
PrivateEvictor(EnvironmentImpl) - Constructor for class com.sleepycat.je.evictor.PrivateEvictor
 
PrivateSelector - Class in com.sleepycat.je.evictor
The standard eviction selector that operates on the INList for a single environment.
PrivateSelector(EnvironmentImpl) - Constructor for class com.sleepycat.je.evictor.PrivateSelector
 
probeGroupDb() - Method in class com.sleepycat.je.rep.impl.RepImpl
Open the group db, which should exist already.
process(Protocol.Propose) - Method in class com.sleepycat.je.rep.elections.Acceptor
Responds to a Propose request.
process(Protocol.Accept) - Method in class com.sleepycat.je.rep.elections.Acceptor
Responds to Accept request
process(RepGroupProtocol.GroupRequest) - Method in class com.sleepycat.je.rep.impl.GroupService
Wraps the replication group as currently cached on this node in a Response message and returns it.
process(RepGroupProtocol.EnsureNode) - Method in class com.sleepycat.je.rep.impl.GroupService
Ensures that the Monitor node, as described in the request, is a member of the group.
process(RepGroupProtocol.RemoveMember) - Method in class com.sleepycat.je.rep.impl.GroupService
Removes a current member from the group.
process(RepGroupProtocol.UpdateAddress) - Method in class com.sleepycat.je.rep.impl.GroupService
Update the network address for a dead replica.
process(RepGroupProtocol.TransferMaster) - Method in class com.sleepycat.je.rep.impl.GroupService
Transfer the master role from the current master to one of the specified replicas.
process(NodeStateProtocol.NodeStateRequest) - Method in class com.sleepycat.je.rep.impl.NodeStateService
Process a node state querying request.
process(Object, TextProtocol.RequestMessage) - Method in class com.sleepycat.je.rep.impl.TextProtocol
 
process(Protocol.GroupChange) - Method in class com.sleepycat.je.rep.monitor.MonitorService
Notify the monitor about the group change (add/remove a node) event.
process(Protocol.JoinGroup) - Method in class com.sleepycat.je.rep.monitor.MonitorService
Notify the monitor about a node has joined the group.
process(Protocol.LeaveGroup) - Method in class com.sleepycat.je.rep.monitor.MonitorService
Notify the monitor about a node has left the group.
processAccumulatedLSNs(LSNAccumulator) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
processBIN(BIN, Long, int) - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
processBIN(BIN, Long, int) - Method in interface com.sleepycat.je.tree.TreeWalkerStatsAccumulator
 
processDirtyDeletedLN(long, LN, byte[]) - Method in interface com.sleepycat.je.dbi.SortedLSNTreeWalker.TreeNodeProcessor
 
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.CheckpointFileReader
This reader instantiates the first object of a given log entry
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.CleanerFileReader
Process the header to track the last VLSN and count true utilization.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.FileReader
Each file reader implements this method to process the entry data.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.INFileReader
This reader returns non-provisional INs and IN delete entries.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.LastFileReader
Validate the checksum on each entry, see if we should remember the LSN of this entry.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.LNFileReader
This reader instantiates an LN and key for every LN entry.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.PrintFileReader
This reader prints the log entry item.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.ScavengerFileReader
 
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.SearchFileReader
This reader instantiate the first object of a given log entry.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.StatsFileReader
This reader collects stats about the log entry.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.UtilizationFileReader
 
processEntry(ByteBuffer) - Method in class com.sleepycat.je.log.VLSNDistributionReader
Count the number of vlsns in the file, along with the first and last vlsn.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.rep.stream.FeederSyncupReader
Instantiate a WireRecord to house this log entry.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.rep.stream.ReplicaSyncupReader
ProcessEntry does additional filtering before deciding whether to return an entry as a candidate for matching.
processEntry(ByteBuffer) - Method in class com.sleepycat.je.rep.stream.VLSNReader
Instantiate a WireRecord to house this log entry.
processEntryCallback(LogEntry, LogEntryType) - Method in class com.sleepycat.je.log.ScavengerFileReader
 
processFuture() - Method in class com.sleepycat.je.rep.elections.Utils.WithFutureExceptionHandler
 
processIN(IN, Long, int) - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
processIN(IN, Long, int) - Method in interface com.sleepycat.je.tree.TreeWalkerStatsAccumulator
 
processLSN(long, LogEntryType, Node, byte[]) - Method in interface com.sleepycat.je.dbi.SortedLSNTreeWalker.TreeNodeProcessor
 
ProcessorMetadata<S extends SyncDataSet> - Class in com.sleepycat.je.sync
Used for storing a serialized form of processor-specific metadata, including a collection of SyncDataSet objects and processor connection properties; used only by SyncProcessor implementations.
ProcessorMetadata() - Constructor for class com.sleepycat.je.sync.ProcessorMetadata
 
processorName - Variable in class com.sleepycat.je.sync.SyncProcessor
 
processPending() - Method in class com.sleepycat.je.cleaner.Cleaner
If any LNs are pending, process them.
processResidentChild(long, Node, byte[], LSNAccumulator) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
processResult(Proposer.Proposal, Protocol.Value) - Method in class com.sleepycat.je.rep.elections.Learner
Processes a result message
progress(T, long, long) - Method in interface com.sleepycat.je.ProgressListener
Called by BDB JE to indicate to the user that progress has been made on a potentially long running or asynchronous operation.
progressInterval - Variable in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
ProgressListener<T extends java.lang.Enum<T>> - Interface in com.sleepycat.je
ProgressListener provides feedback to the application that progress is being made on a potentially long running or asynchronous JE operation.
progressStream - Variable in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
PROHIBIT_NESTED_REF_MSG - Static variable in class com.sleepycat.persist.impl.RecordInput
 
PROHIBIT_REF_OBJECT - Static variable in class com.sleepycat.persist.impl.RecordInput
 
PROHIBIT_REF_OFFSET - Static variable in class com.sleepycat.persist.impl.RecordInput
 
PROMISE - Variable in class com.sleepycat.je.rep.elections.Protocol
 
PROMISE_COUNT - Static variable in class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
promote(EnvironmentImpl, EnvironmentFailureReason, String, Throwable) - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
propagatePostCommitException(DatabaseException) - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
propagatePostCommitException(DatabaseException) - Method in class com.sleepycat.je.txn.Txn
Identifies exceptions that may be propagated back to the caller during the postCommit phase of a transaction commit.
propertiesName - Static variable in class com.sleepycat.util.ConfigBeanInfoBase
 
propertyChange(PropertyChangeEvent) - Method in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
proposal - Variable in class com.sleepycat.je.rep.elections.Proposer.WinningProposal
 
proposal - Variable in class com.sleepycat.je.rep.elections.Protocol.Propose
 
PROPOSE - Variable in class com.sleepycat.je.rep.elections.Protocol
 
Proposer - Class in com.sleepycat.je.rep.elections
Plays the role of a Proposer in the consensus algorithm.
Proposer(Elections, NameIdPair) - Constructor for class com.sleepycat.je.rep.elections.Proposer
Initializes a proposer with the set of acceptors identified by the sockets on which they accept proposals.
Proposer.MaxRetriesException - Exception in com.sleepycat.je.rep.elections
Exception thrown when a Proposal issue fails because the retry limit has been exceeded.
Proposer.MaxRetriesException(StatGroup) - Constructor for exception com.sleepycat.je.rep.elections.Proposer.MaxRetriesException
 
Proposer.Proposal - Interface in com.sleepycat.je.rep.elections
The Interface defining a Proposal.
Proposer.ProposalParser - Interface in com.sleepycat.je.rep.elections
 
Proposer.RetryPredicate - Interface in com.sleepycat.je.rep.elections
Interface to determine whether the Proposer should be retry with a new Proposal or abandon the effort.
Proposer.WinningProposal - Class in com.sleepycat.je.rep.elections
Summarizes the results of the election
Proposer.WinningProposal(Proposer.Proposal, Protocol.Value, StatGroup) - Constructor for class com.sleepycat.je.rep.elections.Proposer.WinningProposal
 
ProposerStatDefinition - Class in com.sleepycat.je.rep.elections
Per-stat Metadata for each Proposer statistics.
ProposerStatDefinition() - Constructor for class com.sleepycat.je.rep.elections.ProposerStatDefinition
 
proposerStats - Variable in exception com.sleepycat.je.rep.elections.Proposer.MaxRetriesException
 
proposerStats - Variable in class com.sleepycat.je.rep.elections.Proposer.WinningProposal
 
props - Variable in class com.sleepycat.je.dbi.DbConfigManager
 
props - Variable in class com.sleepycat.je.EnvironmentMutableConfig
 
props - Variable in class com.sleepycat.je.rep.ReplicationMutableConfig
 
PropUtil - Class in com.sleepycat.je.utilint
Convenience methods for handling JE properties.
PropUtil() - Constructor for class com.sleepycat.je.utilint.PropUtil
 
protocol - Variable in class com.sleepycat.je.rep.elections.ElectionAgentThread
 
Protocol - Class in com.sleepycat.je.rep.elections
Defines the request/response messages used in the implementation of elections.
Protocol(Proposer.ProposalParser, Protocol.ValueParser, String, NameIdPair, RepImpl) - Constructor for class com.sleepycat.je.rep.elections.Protocol
Creates an instance of the Protocol.
protocol - Variable in class com.sleepycat.je.rep.impl.GroupService
 
Protocol - Class in com.sleepycat.je.rep.impl.networkRestore
The protocol used to obtain backup files from a LF Feeder.
Protocol(NameIdPair, int, EnvironmentImpl) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
Protocol - Class in com.sleepycat.je.rep.monitor
 
Protocol(String, NameIdPair, RepImpl) - Constructor for class com.sleepycat.je.rep.monitor.Protocol
 
Protocol - Class in com.sleepycat.je.rep.stream
Defines the messages used to set up a feeder-replica replication stream.
Protocol - Class in com.sleepycat.je.rep.util.ldiff
Protocol used by LDiff to request the blocks associated with a database and do the record level analysis.
Protocol(NameIdPair, EnvironmentImpl) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol
 
protocol - Variable in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingRunnable
 
Protocol.Accept - Class in com.sleepycat.je.rep.elections
Accept request issued in Phase 2 of paxos.
Protocol.Accept(Proposer.Proposal, Protocol.Value) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Accept
 
Protocol.Accept(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Accept
 
Protocol.Accepted - Class in com.sleepycat.je.rep.elections
Response to a successful Accept message.
Protocol.Accepted(Proposer.Proposal, Protocol.Value) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Accepted
 
Protocol.Accepted(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Accepted
 
Protocol.Ack - Class in com.sleepycat.je.rep.stream
 
Protocol.Ack(long) - Constructor for class com.sleepycat.je.rep.stream.Protocol.Ack
 
Protocol.Ack(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.Ack
 
Protocol.AlternateMatchpoint - Class in com.sleepycat.je.rep.stream
 
Protocol.AlternateMatchpoint(OutputWireRecord) - Constructor for class com.sleepycat.je.rep.stream.Protocol.AlternateMatchpoint
 
Protocol.AlternateMatchpoint(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.AlternateMatchpoint
 
Protocol.BlockInfo - Class in com.sleepycat.je.rep.util.ldiff
Supplies the properties of an individual block.
Protocol.BlockInfo(Block) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.BlockInfo
 
Protocol.BlockInfo(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.BlockInfo
 
Protocol.BlockListEnd - Class in com.sleepycat.je.rep.util.ldiff
Denotes the end of the list of blocks.
Protocol.BlockListEnd() - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.BlockListEnd
 
Protocol.BlockListEnd(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.BlockListEnd
 
Protocol.BlockListStart - Class in com.sleepycat.je.rep.util.ldiff
Denotes the start of the list of blocks.
Protocol.BlockListStart() - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.BlockListStart
 
Protocol.BlockListStart(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.BlockListStart
 
Protocol.Commit - Class in com.sleepycat.je.rep.stream
 
Protocol.Commit() - Constructor for class com.sleepycat.je.rep.stream.Protocol.Commit
 
Protocol.Commit(boolean, Durability.SyncPolicy, OutputWireRecord) - Constructor for class com.sleepycat.je.rep.stream.Protocol.Commit
 
Protocol.Commit(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.Commit
 
Protocol.DbBlocks - Class in com.sleepycat.je.rep.util.ldiff
Message used to request a list of blocks.
Protocol.DbBlocks(String, int) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.DbBlocks
 
Protocol.DbBlocks(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.DbBlocks
 
Protocol.DbMismatch - Class in com.sleepycat.je.rep.util.ldiff
Issued in response to a database level mismatch either because the database itself does not exist at the node, or because it's properties are different.
Protocol.DbMismatch(String) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.DbMismatch
 
Protocol.DbMismatch(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.DbMismatch
 
Protocol.DiffAreaEnd - Class in com.sleepycat.je.rep.util.ldiff
Message used to present the transfer of a different area on remote database is done.
Protocol.DiffAreaEnd() - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.DiffAreaEnd
 
Protocol.DiffAreaEnd(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.DiffAreaEnd
 
Protocol.DiffAreaStart - Class in com.sleepycat.je.rep.util.ldiff
Message used to present the transfer of a different area on remote database begins.
Protocol.DiffAreaStart() - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.DiffAreaStart
 
Protocol.DiffAreaStart(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.DiffAreaStart
 
Protocol.Done - Class in com.sleepycat.je.rep.impl.networkRestore
Message from client indicating it's done with all the files it needs and that the connection can be terminated.
Protocol.Done() - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.Done
 
Protocol.Done(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.Done
 
Protocol.Done - Class in com.sleepycat.je.rep.util.ldiff
Message used to present the transfer of all the different data is done.
Protocol.Done() - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.Done
 
Protocol.Done(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.Done
 
Protocol.DuplicateNodeReject - Class in com.sleepycat.je.rep.stream
 
Protocol.DuplicateNodeReject(String) - Constructor for class com.sleepycat.je.rep.stream.Protocol.DuplicateNodeReject
 
Protocol.DuplicateNodeReject(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.DuplicateNodeReject
 
Protocol.Entry - Class in com.sleepycat.je.rep.stream
A message containing a log entry in the replication stream.
Protocol.Entry() - Constructor for class com.sleepycat.je.rep.stream.Protocol.Entry
 
Protocol.Entry(OutputWireRecord) - Constructor for class com.sleepycat.je.rep.stream.Protocol.Entry
 
Protocol.Entry(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.Entry
 
Protocol.EntryNotFound - Class in com.sleepycat.je.rep.stream
Response when the EntryRequest asks for a VLSN that is below the VLSN range covered by the Feeder.
Protocol.EntryNotFound() - Constructor for class com.sleepycat.je.rep.stream.Protocol.EntryNotFound
 
Protocol.EntryNotFound(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.EntryNotFound
 
Protocol.EntryRequest - Class in com.sleepycat.je.rep.stream
A replica node asks a feeder for the log entry at this VLSN.
Protocol.EntryRequest(VLSN) - Constructor for class com.sleepycat.je.rep.stream.Protocol.EntryRequest
 
Protocol.EntryRequest(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.EntryRequest
 
Protocol.EnvDiff - Class in com.sleepycat.je.rep.util.ldiff
Message used to present that an Environment is requesting to do a LDiff with another Environment.
Protocol.EnvDiff() - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.EnvDiff
 
Protocol.EnvDiff(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.EnvDiff
 
Protocol.EnvInfo - Class in com.sleepycat.je.rep.util.ldiff
Message used to present how many databases in a compared Environment.
Protocol.EnvInfo(int) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.EnvInfo
 
Protocol.EnvInfo(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.EnvInfo
 
Protocol.Error - Class in com.sleepycat.je.rep.util.ldiff
Message used to present an operation error on remote database.
Protocol.Error(String) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.Error
 
Protocol.Error(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.Error
 
Protocol.FeederInfoReq - Class in com.sleepycat.je.rep.impl.networkRestore
 
Protocol.FeederInfoReq() - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoReq
 
Protocol.FeederInfoReq(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoReq
 
Protocol.FeederInfoResp - Class in com.sleepycat.je.rep.impl.networkRestore
 
Protocol.FeederInfoResp(int, VLSN, VLSN) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoResp
 
Protocol.FeederInfoResp(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoResp
 
Protocol.FeederJEVersions - Class in com.sleepycat.je.rep.stream
 
Protocol.FeederJEVersions(JEVersion, int) - Constructor for class com.sleepycat.je.rep.stream.Protocol.FeederJEVersions
 
Protocol.FeederJEVersions(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.FeederJEVersions
 
Protocol.FeederProtocolVersion - Class in com.sleepycat.je.rep.stream
The feeder sends the replica its proposed version.
Protocol.FeederProtocolVersion(int) - Constructor for class com.sleepycat.je.rep.stream.Protocol.FeederProtocolVersion
 
Protocol.FeederProtocolVersion(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.FeederProtocolVersion
 
Protocol.FileEnd - Class in com.sleepycat.je.rep.impl.networkRestore
The message ending the response triple: FileStart FileEnd
Protocol.FileEnd(String, long, long, byte[]) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileEnd
 
Protocol.FileEnd(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileEnd
 
Protocol.FileInfoReq - Class in com.sleepycat.je.rep.impl.networkRestore
Requests information about a specific log file.
Protocol.FileInfoReq(String, boolean) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoReq
 
Protocol.FileInfoReq(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoReq
 
Protocol.FileInfoResp - Class in com.sleepycat.je.rep.impl.networkRestore
 
Protocol.FileInfoResp(String, long, long, byte[]) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoResp
 
Protocol.FileInfoResp(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoResp
 
Protocol.FileListReq - Class in com.sleepycat.je.rep.impl.networkRestore
 
Protocol.FileListReq() - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileListReq
 
Protocol.FileListReq(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileListReq
 
Protocol.FileListResp - Class in com.sleepycat.je.rep.impl.networkRestore
 
Protocol.FileListResp(String[]) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileListResp
 
Protocol.FileListResp(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileListResp
 
Protocol.FileReq - Class in com.sleepycat.je.rep.impl.networkRestore
Requests that a specific file be sent to the client.
Protocol.FileReq(String) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileReq
 
Protocol.FileReq(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileReq
 
Protocol.FileStart - Class in com.sleepycat.je.rep.impl.networkRestore
The message starting the response triple: FileStart FileEnd
Protocol.FileStart(String, long, long) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
Protocol.FileStart(ByteBuffer) - Constructor for class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
Protocol.GroupChange - Class in com.sleepycat.je.rep.monitor
 
Protocol.GroupChange(RepGroupImpl, String, GroupChangeEvent.GroupChangeType) - Constructor for class com.sleepycat.je.rep.monitor.Protocol.GroupChange
 
Protocol.GroupChange(String, String[]) - Constructor for class com.sleepycat.je.rep.monitor.Protocol.GroupChange
 
Protocol.HandshakeMessage - Class in com.sleepycat.je.rep.stream
Base class for all protocol handshake messages.
Protocol.HandshakeMessage() - Constructor for class com.sleepycat.je.rep.stream.Protocol.HandshakeMessage
 
Protocol.Heartbeat - Class in com.sleepycat.je.rep.stream
 
Protocol.Heartbeat(long, long) - Constructor for class com.sleepycat.je.rep.stream.Protocol.Heartbeat
 
Protocol.Heartbeat(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.Heartbeat
 
Protocol.HeartbeatResponse - Class in com.sleepycat.je.rep.stream
 
Protocol.HeartbeatResponse(VLSN, VLSN) - Constructor for class com.sleepycat.je.rep.stream.Protocol.HeartbeatResponse
 
Protocol.HeartbeatResponse(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.HeartbeatResponse
 
Protocol.JEVersions - Class in com.sleepycat.je.rep.stream
Abstract message used as the basis for the exchange of software versions between replicated nodes
Protocol.JEVersions(JEVersion, int) - Constructor for class com.sleepycat.je.rep.stream.Protocol.JEVersions
 
Protocol.JEVersions(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.JEVersions
 
Protocol.JEVersionsReject - Class in com.sleepycat.je.rep.stream
 
Protocol.JEVersionsReject(String) - Constructor for class com.sleepycat.je.rep.stream.Protocol.JEVersionsReject
 
Protocol.JEVersionsReject(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.JEVersionsReject
 
Protocol.JoinGroup - Class in com.sleepycat.je.rep.monitor
 
Protocol.JoinGroup(String, String, long) - Constructor for class com.sleepycat.je.rep.monitor.Protocol.JoinGroup
 
Protocol.JoinGroup(String, String[]) - Constructor for class com.sleepycat.je.rep.monitor.Protocol.JoinGroup
 
Protocol.LeaveGroup - Class in com.sleepycat.je.rep.monitor
 
Protocol.LeaveGroup(String, String, LeaveGroupEvent.LeaveReason, long, long) - Constructor for class com.sleepycat.je.rep.monitor.Protocol.LeaveGroup
 
Protocol.LeaveGroup(String, String[]) - Constructor for class com.sleepycat.je.rep.monitor.Protocol.LeaveGroup
 
Protocol.MasterQuery - Class in com.sleepycat.je.rep.elections
Used to query the Learner for a current master
Protocol.MasterQuery() - Constructor for class com.sleepycat.je.rep.elections.Protocol.MasterQuery
 
Protocol.MasterQuery(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.MasterQuery
 
Protocol.MasterQueryResponse - Class in com.sleepycat.je.rep.elections
The response to a Master Query request.
Protocol.MasterQueryResponse(Proposer.Proposal, Protocol.Value) - Constructor for class com.sleepycat.je.rep.elections.Protocol.MasterQueryResponse
 
Protocol.MasterQueryResponse(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.MasterQueryResponse
 
Protocol.NodeGroupInfo - Class in com.sleepycat.je.rep.stream
 
Protocol.NodeGroupInfo(String, UUID, NameIdPair, String, int, NodeType, boolean) - Constructor for class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
Protocol.NodeGroupInfo(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
Protocol.NodeGroupInfoOK - Class in com.sleepycat.je.rep.stream
 
Protocol.NodeGroupInfoOK(UUID, NameIdPair) - Constructor for class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoOK
 
Protocol.NodeGroupInfoOK(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoOK
 
Protocol.NodeGroupInfoReject - Class in com.sleepycat.je.rep.stream
 
Protocol.NodeGroupInfoReject(String) - Constructor for class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoReject
 
Protocol.NodeGroupInfoReject(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoReject
 
Protocol.Promise - Class in com.sleepycat.je.rep.elections
Promise response message.
Protocol.Promise(Proposer.Proposal, Protocol.Value, Protocol.Value, long, int, int, JEVersion) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Promise
 
Protocol.Promise(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Promise
 
Protocol.Propose - Class in com.sleepycat.je.rep.elections
Propose request used in Phase 1 of Paxos
Protocol.Propose(Proposer.Proposal) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Propose
 
Protocol.Propose(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Propose
 
Protocol.ProtocolVersion - Class in com.sleepycat.je.rep.stream
Version broadcasts the sending node's protocol version.
Protocol.ProtocolVersion(int) - Constructor for class com.sleepycat.je.rep.stream.Protocol.ProtocolVersion
 
Protocol.ProtocolVersion(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.ProtocolVersion
 
Protocol.Reject - Class in com.sleepycat.je.rep.elections
Reject response to a message.
Protocol.Reject(Proposer.Proposal) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Reject
 
Protocol.Reject(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Reject
 
Protocol.RemoteDiffRequest - Class in com.sleepycat.je.rep.util.ldiff
Message used to request records of a different area on the remote database.
Protocol.RemoteDiffRequest(MismatchedRegion) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
Protocol.RemoteDiffRequest(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
Protocol.RemoteRecord - Class in com.sleepycat.je.rep.util.ldiff
Message used to transfer a record from remote to local database.
Protocol.RemoteRecord(Record) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
Protocol.RemoteRecord(ByteBuffer) - Constructor for class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
Protocol.ReplicaJEVersions - Class in com.sleepycat.je.rep.stream
 
Protocol.ReplicaJEVersions(JEVersion, int) - Constructor for class com.sleepycat.je.rep.stream.Protocol.ReplicaJEVersions
 
Protocol.ReplicaJEVersions(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.ReplicaJEVersions
 
Protocol.ReplicaProtocolVersion - Class in com.sleepycat.je.rep.stream
The replica sends the feeder its protocol version.
Protocol.ReplicaProtocolVersion() - Constructor for class com.sleepycat.je.rep.stream.Protocol.ReplicaProtocolVersion
 
Protocol.ReplicaProtocolVersion(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.ReplicaProtocolVersion
 
Protocol.RestoreRequest - Class in com.sleepycat.je.rep.stream
Request from the replica to the feeder for sufficient information to start a network restore.
Protocol.RestoreRequest(VLSN) - Constructor for class com.sleepycat.je.rep.stream.Protocol.RestoreRequest
 
Protocol.RestoreRequest(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.RestoreRequest
 
Protocol.RestoreResponse - Class in com.sleepycat.je.rep.stream
Response when the replica needs information to instigate a network restore.
Protocol.RestoreResponse(VLSN, RepNodeImpl[]) - Constructor for class com.sleepycat.je.rep.stream.Protocol.RestoreResponse
 
Protocol.RestoreResponse(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.RestoreResponse
 
Protocol.Result - Class in com.sleepycat.je.rep.elections
Used to inform Learners of a "chosen value".
Protocol.Result(Proposer.Proposal, Protocol.Value) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Result
 
Protocol.Result(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Result
 
Protocol.Shutdown - Class in com.sleepycat.je.rep.elections
 
Protocol.Shutdown() - Constructor for class com.sleepycat.je.rep.elections.Protocol.Shutdown
 
Protocol.Shutdown(String, String[]) - Constructor for class com.sleepycat.je.rep.elections.Protocol.Shutdown
 
Protocol.ShutdownRequest - Class in com.sleepycat.je.rep.stream
Message used to shutdown a node
Protocol.ShutdownRequest(long) - Constructor for class com.sleepycat.je.rep.stream.Protocol.ShutdownRequest
 
Protocol.ShutdownRequest(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.ShutdownRequest
 
Protocol.ShutdownResponse - Class in com.sleepycat.je.rep.stream
Message in response to a shutdown request.
Protocol.ShutdownResponse() - Constructor for class com.sleepycat.je.rep.stream.Protocol.ShutdownResponse
 
Protocol.ShutdownResponse(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.ShutdownResponse
 
Protocol.SNTPRequest - Class in com.sleepycat.je.rep.stream
 
Protocol.SNTPRequest(boolean) - Constructor for class com.sleepycat.je.rep.stream.Protocol.SNTPRequest
 
Protocol.SNTPRequest(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.SNTPRequest
 
Protocol.SNTPResponse - Class in com.sleepycat.je.rep.stream
 
Protocol.SNTPResponse(Protocol.SNTPRequest) - Constructor for class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
Protocol.SNTPResponse(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
Protocol.StartStream - Class in com.sleepycat.je.rep.stream
StartStream indicates that the replica would like the feeder to start the replication stream at the proposed vlsn.
Protocol.StartStream(VLSN) - Constructor for class com.sleepycat.je.rep.stream.Protocol.StartStream
 
Protocol.StartStream(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.StartStream
 
Protocol.StringValue - Class in com.sleepycat.je.rep.elections
A String based value implementation used as the "default" Value
Protocol.StringValue() - Constructor for class com.sleepycat.je.rep.elections.Protocol.StringValue
 
Protocol.StringValue(String) - Constructor for class com.sleepycat.je.rep.elections.Protocol.StringValue
 
Protocol.Value - Interface in com.sleepycat.je.rep.elections
 
Protocol.ValueParser - Interface in com.sleepycat.je.rep.elections
 
Protocol.VLSNMessage - Class in com.sleepycat.je.rep.stream
Base class for messages which contain only a VLSN
Protocol.VLSNMessage(VLSN) - Constructor for class com.sleepycat.je.rep.stream.Protocol.VLSNMessage
 
Protocol.VLSNMessage(ByteBuffer) - Constructor for class com.sleepycat.je.rep.stream.Protocol.VLSNMessage
 
PROTOCOL_ERROR - Variable in class com.sleepycat.je.rep.impl.TextProtocol
 
PROTOCOL_ERROR - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
PROTOCOL_OLD_STRING_ENCODING - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
PROTOCOL_OLD_STRING_ENCODING - Static variable in class com.sleepycat.je.rep.ReplicationConfig
When set to true, which is currently the default, the replication network protocol will use the JVM platform default charset (text encoding) for node names and host names.
provisional - Variable in class com.sleepycat.je.log.LogItem
Whether the logged entry should be processed during recovery.
Provisional - Enum in com.sleepycat.je.log
Specifies whether to log an entry provisionally.
provisionalCount - Variable in class com.sleepycat.je.log.StatsFileReader.EntryInfo
 
ProxiedFormat - Class in com.sleepycat.persist.impl
Format for types proxied by a PersistentProxy.
ProxiedFormat(Catalog, Class, String) - Constructor for class com.sleepycat.persist.impl.ProxiedFormat
 
publish(LogRecord) - Method in class com.sleepycat.je.utilint.ConfiguredRedirectHandler
 
publish(LogRecord) - Method in class com.sleepycat.je.utilint.ConsoleRedirectHandler
 
publish(LogRecord) - Method in class com.sleepycat.je.utilint.FileRedirectHandler
 
publish(LogRecord) - Method in class com.sleepycat.je.utilint.FormatterRedirectHandler
 
PUSHED - Static variable in class com.sleepycat.asm.Label
Indicates if this basic block has been pushed in the basic block stack.
put(ByteVector) - Method in class com.sleepycat.asm.AnnotationWriter
Puts the annotations of this annotation writer list into the given byte vector.
put(AnnotationWriter[], int, ByteVector) - Static method in class com.sleepycat.asm.AnnotationWriter
Puts the given annotation lists into the given byte vector.
put(ClassWriter, byte[], int, int, int, ByteVector) - Method in class com.sleepycat.asm.Attribute
Writes all the attributes of this attribute list in the given byte vector.
put(ByteVector) - Method in class com.sleepycat.asm.FieldWriter
Puts the content of this field into the given byte vector.
put(MethodWriter, ByteVector, int, boolean) - Method in class com.sleepycat.asm.Label
Puts a reference to this label in the bytecode of a method.
put(ByteVector) - Method in class com.sleepycat.asm.MethodWriter
Puts the bytecode of this method in the given byte vector.
put(Object, Object, Object[], boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.put(), optionally returning the old value and optionally using the current key instead of the key parameter.
put(K, V) - Method in class com.sleepycat.collections.StoredMap
Associates the specified value with the specified key in this map (optional operation).
put(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Cursor
Stores a key/data pair into the database.
put(Transaction, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Database
Stores the key/data pair into the database.
put(DatabaseEntry, DatabaseEntry, LN, PutMode, DatabaseEntry, DatabaseEntry, ReplicationContext) - Method in class com.sleepycat.je.dbi.CursorImpl
Performs all put operations except for CURRENT (use putCurrent instead).
PUT - Static variable in class com.sleepycat.je.dbi.Operation
 
put(K, V) - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
Notes the addition of a new value and counts down any latches that were assigned to that threshold.
put(VLSN, long) - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
 
put(VLSN, LogItem) - Method in class com.sleepycat.je.rep.vlsn.LogItemCache
 
put(VLSN, long) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Record the LSN location for this VLSN.
put(LogItem) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
put(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryCursor
This operation is not allowed on a secondary database.
put(Transaction, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryDatabase
This operation is not allowed on a secondary database.
put(Transaction, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
put(Transaction, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.je.trigger.Trigger
The trigger method invoked after a successful put, that is, one that actually results in a modification to the database.
put(E) - Method in class com.sleepycat.persist.PrimaryIndex
Inserts an entity and returns null, or updates it if the primary key already exists and returns the existing entity.
put(Transaction, E) - Method in class com.sleepycat.persist.PrimaryIndex
Inserts an entity and returns null, or updates it if the primary key already exists and returns the existing entity.
put(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
put11(int, int) - Method in class com.sleepycat.asm.ByteVector
Puts two bytes into this byte vector.
put12(int, int) - Method in class com.sleepycat.asm.ByteVector
Puts a byte and a short into this byte vector.
putAfter(Object) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.putAfter().
putAfter(Cursor, DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.compat.DbCompat
 
putAfter(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
putAll(Map<? extends K, ? extends V>) - Method in class com.sleepycat.collections.StoredMap
Copies all of the mappings from the specified map to this map (optional operation).
putAll(Map<? extends K, ? extends V>) - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
putBackFileForCleaning(Long) - Method in class com.sleepycat.je.cleaner.FileSelector
When file cleaning is aborted, move the file back from BEING_CLEANED to TO_BE_CLEANED.
putBefore(Object) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.putBefore().
putBefore(Cursor, DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.compat.DbCompat
 
putBefore(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
putByte(int) - Method in class com.sleepycat.asm.ByteVector
Puts a byte into this byte vector.
putByteArray(byte[], int, int) - Method in class com.sleepycat.asm.ByteVector
Puts an array of bytes into this byte vector.
putCurrent(Object) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.putCurrent().
putCurrent(DatabaseEntry) - Method in class com.sleepycat.je.Cursor
Replaces the data in the key/data pair at the current cursor position.
putCurrent(byte[], DatabaseEntry, DatabaseEntry, DatabaseEntry, DatabaseEntry, ReplicationContext) - Method in class com.sleepycat.je.dbi.CursorImpl
Modify the current record with the given data, and optionally replace the key.
putCurrent(DatabaseEntry) - Method in class com.sleepycat.je.SecondaryCursor
This operation is not allowed on a secondary database.
putCurrent(DatabaseEntry) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
putFeeder(String, Feeder) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
PUTFIELD - Static variable in interface com.sleepycat.asm.Opcodes
 
putForReplay(byte[], LN, PutMode, ReplicationContext) - Method in class com.sleepycat.je.Cursor
Version of putInternal that allows passing an existing LN and does not interpret duplicates.
putForReplay(Cursor, byte[], LN, PutMode, ReplicationContext) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.putForReplay()
putIfAbsent(K, V) - Method in class com.sleepycat.collections.StoredMap
If the specified key is not already associated with a value, associate it with the given value.
putInt(int) - Method in class com.sleepycat.asm.ByteVector
Puts an int into this byte vector.
putInternal(DatabaseEntry, DatabaseEntry, PutMode) - Method in class com.sleepycat.je.Cursor
Internal version of put that does no parameter checking.
putInternal(Transaction, DatabaseEntry, DatabaseEntry, PutMode) - Method in class com.sleepycat.je.Database
Internal version of put() that does no parameter checking.
putIntoBuffer(LogEntry, long) - Method in class com.sleepycat.je.log.LogManager
Serialize a log entry into this buffer with proper entry header.
putKeyValue(Object, Object) - Method in class com.sleepycat.collections.StoredContainer
 
putLN(byte[], LN, DatabaseEntry, ReplicationContext) - Method in class com.sleepycat.je.dbi.CursorImpl
Insert the given LN in the tree or return KEYEXIST if the key is already present.
putLong(long) - Method in class com.sleepycat.asm.ByteVector
Puts a long into this byte vector.
PutMode - Enum in com.sleepycat.je.dbi
Used to distinguish Cursor put operations.
putNoDupData(Object, Object, Object[], boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.putNoDupData(), optionally returning the old value and optionally using the current key instead of the key parameter.
putNoDupData(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Cursor
Stores a key/data pair into the database.
putNoDupData(Transaction, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Database
Stores the key/data pair into the database if it does not already appear in the database.
putNoDupData(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryCursor
This operation is not allowed on a secondary database.
putNoDupData(Transaction, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryDatabase
This operation is not allowed on a secondary database.
putNoDupData(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
putNoOverwrite(Object, Object, boolean) - Method in class com.sleepycat.collections.DataCursor
Binding version of Cursor.putNoOverwrite(), optionally using the current key instead of the key parameter.
putNoOverwrite(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Cursor
Stores a key/data pair into the database.
putNoOverwrite(Transaction, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Database
Stores the key/data pair into the database if the key does not already appear in the database.
putNoOverwrite(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryCursor
This operation is not allowed on a secondary database.
putNoOverwrite(Transaction, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryDatabase
This operation is not allowed on a secondary database.
putNoOverwrite(E) - Method in class com.sleepycat.persist.PrimaryIndex
Inserts an entity and returns true, or returns false if the primary key already exists.
putNoOverwrite(Transaction, E) - Method in class com.sleepycat.persist.PrimaryIndex
Inserts an entity and returns true, or returns false if the primary key already exists.
putNoOverwrite(DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.util.keyrange.RangeCursor
 
putNoReturn(E) - Method in class com.sleepycat.persist.PrimaryIndex
Inserts an entity, or updates it if the primary key already exists (does not return the existing entity).
putNoReturn(Transaction, E) - Method in class com.sleepycat.persist.PrimaryIndex
Inserts an entity, or updates it if the primary key already exists (does not return the existing entity).
putShort(int) - Method in class com.sleepycat.asm.ByteVector
Puts a short into this byte vector.
PUTSTATIC - Static variable in interface com.sleepycat.asm.Opcodes
 
putString(String, ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
putUTF8(String) - Method in class com.sleepycat.asm.ByteVector
Puts an UTF8 string into this byte vector.

Q

queryForMaster(Set<InetSocketAddress>) - Method in class com.sleepycat.je.rep.elections.Learner
Queries other learners, in parallel, to determine whether they know of an existing master in the group.
QUEUE_METHOD - Static variable in class com.sleepycat.compat.DbCompat
 
queueSlotDeletion() - Method in class com.sleepycat.je.tree.BIN
This method is called whenever a deleted slot is observed (when the slot's PendingDeleted or KnownDeleted flag is set), to ensure that the slot is compressed away.
quiet - Variable in class com.sleepycat.je.util.DbVerify
 
QuorumPolicy - Enum in com.sleepycat.je.rep
The quorum policy determine the number of nodes that must participate to pick the winner of an election, and therefore the master of the group.
quorumSize(int) - Method in enum com.sleepycat.je.rep.QuorumPolicy
Returns the minimum number of nodes to needed meet the quorum policy.

R

range - Variable in class com.sleepycat.collections.DataView
 
range - Variable in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
RANGE_INSERT - Static variable in class com.sleepycat.je.txn.LockType
 
RANGE_KEY - Static variable in class com.sleepycat.je.rep.vlsn.VLSNRange
 
RANGE_READ - Static variable in class com.sleepycat.je.txn.LockType
 
RANGE_READ_IMMED - Static variable in class com.sleepycat.je.txn.LockUpgrade
 
RANGE_WRITE - Static variable in class com.sleepycat.je.txn.LockType
 
RANGE_WRITE_IMMED - Static variable in class com.sleepycat.je.txn.LockUpgrade
 
RANGE_WRITE_PROMOTE - Static variable in class com.sleepycat.je.txn.LockUpgrade
 
RangeConstraint - Interface in com.sleepycat.je.dbi
 
RangeCursor - Class in com.sleepycat.util.keyrange
A cursor-like interface that enforces a key range.
RangeCursor(KeyRange, KeyRange, boolean, Cursor) - Constructor for class com.sleepycat.util.keyrange.RangeCursor
Creates a range cursor with a duplicate range.
RangeRestartException - Exception in com.sleepycat.je.dbi
Thrown by the LockManager when requesting a RANGE_READ or RANGE_WRITE lock, and a RANGE_INSERT lock is held or is waiting.
RangeRestartException() - Constructor for exception com.sleepycat.je.dbi.RangeRestartException
 
RankingProposer - Class in com.sleepycat.je.rep.elections
Extends the base proposer to choose a phase 2 value based on a suggestion's relative ranking.
RankingProposer(Elections, NameIdPair) - Constructor for class com.sleepycat.je.rep.elections.RankingProposer
 
RawAbstractInput - Class in com.sleepycat.persist.impl
Base class for EntityInput implementations that type-check RawObject instances and convert them to regular persistent objects, via the Format.convertRawObject method.
RawAbstractInput(Catalog, boolean, IdentityHashMap) - Constructor for class com.sleepycat.persist.impl.RawAbstractInput
 
rawAccess - Variable in class com.sleepycat.persist.impl.AbstractInput
 
rawAccess - Variable in class com.sleepycat.persist.impl.PersistEntityBinding
 
rawAccess - Variable in class com.sleepycat.persist.impl.PersistKeyBinding
 
RawAccessor - Class in com.sleepycat.persist.impl
Implements Accessor for RawObject access.
RawAccessor(Format, Accessor, FieldInfo, List<FieldInfo>, List<FieldInfo>) - Constructor for class com.sleepycat.persist.impl.RawAccessor
 
RawAccessor(Format, List<FieldInfo>) - Constructor for class com.sleepycat.persist.impl.RawAccessor
 
RawArrayInput - Class in com.sleepycat.persist.impl
Extends RawAbstractInput to convert array (ObjectArrayFormat and PrimitiveArrayteKeyFormat) RawObject instances.
RawArrayInput(Catalog, boolean, IdentityHashMap, RawObject, Format) - Constructor for class com.sleepycat.persist.impl.RawArrayInput
 
RawComplexInput - Class in com.sleepycat.persist.impl
Extends RawAbstractInput to convert complex (ComplexFormat and CompositeKeyFormat) RawObject instances.
RawComplexInput(Catalog, boolean, IdentityHashMap, FieldInfo[], RawObject[]) - Constructor for class com.sleepycat.persist.impl.RawComplexInput
 
RawField - Interface in com.sleepycat.persist.raw
The definition of a field in a RawType.
RawObject - Class in com.sleepycat.persist.raw
A raw instance that can be used with a RawStore or Conversion.
RawObject(RawType, Map<String, Object>, RawObject) - Constructor for class com.sleepycat.persist.raw.RawObject
Creates a raw object with a given set of field values for a complex type.
RawObject(RawType, Object[]) - Constructor for class com.sleepycat.persist.raw.RawObject
Creates a raw object with the given array elements for an array type.
RawObject(RawType, String) - Constructor for class com.sleepycat.persist.raw.RawObject
Creates a raw object with the given enum value for an enum type.
RawSingleInput - Class in com.sleepycat.persist.impl
Extends RawAbstractInput to convert array (ObjectArrayFormat and PrimitiveArrayteKeyFormat) RawObject instances.
RawSingleInput(Catalog, boolean, IdentityHashMap, Object, Format) - Constructor for class com.sleepycat.persist.impl.RawSingleInput
 
RawStore - Class in com.sleepycat.persist.raw
Provides access to the raw data in a store for use by general purpose tools.
RawStore(Environment, String, StoreConfig) - Constructor for class com.sleepycat.persist.raw.RawStore
Opens an entity store for raw data access.
RawType - Interface in com.sleepycat.persist.raw
The type definition for a simple or complex persistent type, or an array of persistent types.
REACHABLE - Static variable in class com.sleepycat.asm.Label
Indicates if this label corresponds to a reachable basic block.
read(ClassReader, int, int, char[], int, Label[]) - Method in class com.sleepycat.asm.Attribute
Reads a type attribute.
read(ReadableByteChannel) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
Read and parse an incoming message, specifying the incoming version.
read(ReadableByteChannel, Class<T>) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
read(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.NamedChannel
 
read(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.NamedChannelWithTimeout
 
READ - Static variable in class com.sleepycat.je.txn.LockType
Lock types.
read() - Method in class com.sleepycat.je.util.LogVerificationInputStream
read(byte[]) - Method in class com.sleepycat.je.util.LogVerificationInputStream
read(byte[], int, int) - Method in class com.sleepycat.je.util.LogVerificationInputStream
read() - Method in class com.sleepycat.util.FastInputStream
 
read(byte[]) - Method in class com.sleepycat.util.FastInputStream
 
read(byte[], int, int) - Method in class com.sleepycat.util.FastInputStream
 
READ_COMMITTED - Static variable in class com.sleepycat.je.CursorConfig
A convenience instance to configure a cursor for read committed isolation.
READ_ONLY - Static variable in class com.sleepycat.je.rep.impl.RepGroupDB
 
READ_ONLY_TXN - Static variable in class com.sleepycat.je.Durability
A convenience constant that defines a durability policy, with ReplicaAckPolicy.NONE for use with a read only transaction.
READ_ONLY_TXN_CONFIG - Static variable in class com.sleepycat.compat.DbCompat
For read-only cursor operations on a replicated node, we must use a transaction to satisfy HA requirements.
READ_PRIMARY_MAX_RETRIES - Static variable in class com.sleepycat.je.Cursor
 
READ_UNCOMMITTED - Static variable in class com.sleepycat.je.CursorConfig
A convenience instance to configure read operations performed by the cursor to return modified but not yet committed data.
readArrayLength() - Method in interface com.sleepycat.persist.impl.EntityInput
Called by ObjectArrayFormat and PrimitiveArrayFormat to read the array length.
readArrayLength() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readArrayLength() - Method in class com.sleepycat.persist.impl.RawArrayInput
 
readArrayLength() - Method in class com.sleepycat.persist.impl.RecordInput
 
readArrayLength() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readBaseLNEntry(EnvironmentImpl, LogEntryHeader, ByteBuffer, boolean) - Method in class com.sleepycat.je.log.entry.LNLogEntry
Method shared by LNLogEntry subclasses.
readBigDecimal() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads an unsorted BigDecimal.
readBigInteger() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a BigInteger.
readBigInteger() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readBigInteger() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readBigInteger() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readBlock(int, Cursor, int) - Static method in class com.sleepycat.je.rep.util.ldiff.LDiffUtil
 
readBoolean() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a boolean (one byte) unsigned value from the buffer and returns true if it is non-zero and false if it is zero.
readBoolean(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
Read a boolean from the log.
readBoolean() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readBoolean() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readBoolean() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readBuffer - Variable in class com.sleepycat.je.log.FileReader.ReadWindow
 
readBufferSize - Variable in class com.sleepycat.je.cleaner.Cleaner
 
readByte(int) - Method in class com.sleepycat.asm.ClassReader
Reads a byte value in b.
readByte() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a signed byte (one byte) value from the buffer.
readByte() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readByte() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readByte() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readByteArray(ByteBuffer, boolean) - Static method in class com.sleepycat.je.log.LogUtils
Read a byte array from the log.
readBytes(int) - Method in class com.sleepycat.bind.tuple.TupleInput
Reads the specified number of bytes from the buffer, converting each unsigned byte value to a character of the resulting string.
readBytes(char[]) - Method in class com.sleepycat.bind.tuple.TupleInput
Reads the specified number of bytes from the buffer, converting each unsigned byte value to a character of the resulting array.
readBytesNoLength(ByteBuffer, int) - Static method in class com.sleepycat.je.log.LogUtils
Read a byte array from the log.
readChangeSetData(Environment, Transaction, String, String, DatabaseEntry) - Method in class com.sleepycat.je.sync.impl.SyncDB
 
readChangeSetData(Transaction, String, DatabaseEntry) - Method in class com.sleepycat.je.sync.SyncProcessor
Called internally by the SyncProcessor to read change set data.
readChar() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a char (two byte) unsigned value from the buffer.
readChar() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readChar() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readChar() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readChars(int) - Method in class com.sleepycat.bind.tuple.TupleInput
Reads the specified number of characters from the buffer, converting each two byte unsigned value to a character of the resulting string.
readChars(char[]) - Method in class com.sleepycat.bind.tuple.TupleInput
Reads the specified number of characters from the buffer, converting each two byte unsigned value to a character of the resulting array.
readClass(int, char[]) - Method in class com.sleepycat.asm.ClassReader
Reads a class constant pool item in b.
readClassDescriptor() - Method in class com.sleepycat.bind.serial.SerialInput
 
ReadCommittedLocker - Class in com.sleepycat.je.txn
Extends BuddyLocker to acquire write locks using the buddy locker (the transaction locker).
readCompositeKeyFields(Object, EntityInput) - Method in interface com.sleepycat.persist.impl.Accessor
Reads all composite key field values from the given EntityInput, reading in declared field number order.
readCompositeKeyFields(Object, EntityInput) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
readCompositeKeyFields(Object, EntityInput) - Method in class com.sleepycat.persist.impl.RawAccessor
 
readCompositeKeyFields(Object, EntityInput) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
readConst(int, char[]) - Method in class com.sleepycat.asm.ClassReader
Reads a numeric or string constant pool item in b.
readCursors - Variable in class com.sleepycat.collections.CurrentTransaction.CdbCursors
 
readDataForType(SyncDB.DataType, Environment) - Method in class com.sleepycat.je.sync.impl.SyncDB
 
readDouble() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads an unsorted double (eight byte) value from the buffer.
readEntity(Catalog, DatabaseEntry, Object, DatabaseEntry, boolean) - Static method in class com.sleepycat.persist.impl.PersistEntityBinding
Creates the instance, reads the entity key first to track visited entities correctly, then reads the data and returns the entity.
readEntry(EnvironmentImpl, LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.DeletedDupLNLogEntry
Extends its super class to read in the extra dup key.
readEntry(EnvironmentImpl, LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.FileHeaderEntry
For a file header, the version is not available until after reading the item.
readEntry(EnvironmentImpl, LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.INLogEntry
Read in an IN entry.
readEntry(EnvironmentImpl, LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
readEntry(EnvironmentImpl, LogEntryHeader, ByteBuffer) - Method in interface com.sleepycat.je.log.entry.LogEntry
Read in a log entry.
readEntry(EnvironmentImpl, LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
Extends its super class to read in database operation information.
readEntry(EnvironmentImpl, LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
readEnumConstant(String[]) - Method in interface com.sleepycat.persist.impl.EntityInput
Called by EnumFormat to read and return index of the enum constant.
readEnumConstant(String[]) - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readEnumConstant(String[]) - Method in class com.sleepycat.persist.impl.RecordInput
 
readEnumConstant(String[]) - Method in class com.sleepycat.persist.impl.WidenerInput
 
Reader - Interface in com.sleepycat.persist.impl
Interface to the "read object" methods of the Format class.
readFast() - Method in class com.sleepycat.util.FastInputStream
Equivalent to read() but does not throw IOException.
readFast(byte[]) - Method in class com.sleepycat.util.FastInputStream
Equivalent to read(byte[]) but does not throw IOException.
readFast(byte[], int, int) - Method in class com.sleepycat.util.FastInputStream
Equivalent to read(byte[],int,int) but does not throw IOException.
readFloat() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads an unsorted float (four byte) value from the buffer.
readFromBuffer(ByteBuffer) - Static method in class com.sleepycat.je.dbi.Operation
 
readFromDatabase(DatabaseEntry) - Static method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Instantiate this from the database.
readFromDatabase(DatabaseEntry) - Static method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
readFromFile(RandomAccessFile, ByteBuffer, long, long) - Method in class com.sleepycat.je.log.FileManager
Read a buffer from a file at a given offset.
readFromFile(RandomAccessFile, ByteBuffer, long, long, boolean) - Method in class com.sleepycat.je.log.FileManager
Read a buffer from a file at a given offset.
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.cleaner.DbFileSummary
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.cleaner.FileSummary
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.cleaner.PackedOffsets
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.dbi.DatabaseId
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.dbi.DbTree
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
 
readFromLog(ByteBuffer, int) - Method in enum com.sleepycat.je.log.entry.DbOperationType
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.log.FileHeader
 
readFromLog(ByteBuffer, int) - Method in interface com.sleepycat.je.log.Loggable
Initialize this object from the data in itemBuf.
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.log.Trace
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.recovery.CheckpointStart
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.BINDelta
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.ChildReference
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.DeltaInfo
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.FileSummaryLN
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.IN
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.LN
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.MapLN
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.NameLN
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.Node
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.tree.Tree
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.txn.RollbackEnd
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.txn.RollbackStart
"
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.txn.Txn
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.txn.TxnEnd
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.txn.TxnPrepare
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.utilint.Matchpoint
 
readFromLog(ByteBuffer, int) - Method in class com.sleepycat.je.utilint.VLSN
 
readInt(int) - Method in class com.sleepycat.asm.ClassReader
Reads a signed int value in b.
readInt(byte[], int) - Static method in class com.sleepycat.asm.MethodWriter
Reads a signed int value in the given byte array.
readInt() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a signed int (four byte) value from the buffer.
readInt(ByteBuffer, boolean) - Static method in class com.sleepycat.je.log.LogUtils
Read an int from the log in either packed or unpacked format.
readInt(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
Read a int from the log.
readInt() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readInt() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readInt() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readInt(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
Reads a packed integer at the given buffer offset and returns it.
readIntMSB(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
Read a int from the log in MSB order.
readKey(Format, Catalog, byte[], int, int, boolean) - Static method in class com.sleepycat.persist.impl.PersistKeyBinding
Binds bytes to an object for use by PersistComparator as well as entryToObject.
readKeyObject(Format) - Method in interface com.sleepycat.persist.impl.EntityInput
Called for a primary key field or a composite key field with a reference type.
readKeyObject(Format) - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readKeyObject(Format) - Method in class com.sleepycat.persist.impl.RecordInput
 
readKeyObject(Format) - Method in class com.sleepycat.persist.impl.WidenerInput
 
readLabel(int, Label[]) - Method in class com.sleepycat.asm.ClassReader
Returns the label corresponding to the given offset.
readLong(int) - Method in class com.sleepycat.asm.ClassReader
Reads a signed long value in b.
readLong() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a signed long (eight byte) value from the buffer.
readLong(ByteBuffer, boolean) - Static method in class com.sleepycat.je.log.LogUtils
Read an int from the log in either packed or unpacked format.
readLong(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
Read a long from the log.
readLong() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readLong() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readLong() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readLong(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
Reads a packed long integer at the given buffer offset and returns it.
readLongNumber(String) - Static method in class com.sleepycat.je.utilint.CmdUtil
Parse a string into a long.
readLsn(String) - Static method in class com.sleepycat.je.utilint.CmdUtil
Convert a string that is either 0xabc or 0xabc/0x123 into an lsn.
readMapTreeFromLog(long) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Set the mapping tree from the log.
readNext() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readNext() - Method in class com.sleepycat.persist.impl.RawArrayInput
 
readNext() - Method in class com.sleepycat.persist.impl.RawComplexInput
 
readNext() - Method in class com.sleepycat.persist.impl.RawSingleInput
 
readNextEntry() - Method in class com.sleepycat.je.log.FileReader
Scans the log files until either it has reached the end of the log or has hit an invalid portion.
readNextEntry() - Method in class com.sleepycat.je.log.LastFileReader
readNextEntry will stop at a bad entry.
readNextEntry() - Method in class com.sleepycat.je.log.ScavengerFileReader
 
readNextEntryAllowExceptions() - Method in class com.sleepycat.je.log.FileReader
Variant of readNextEntry that throws FileNotFoundException and ChecksumException, rather than wrapping them in an EnvironmentFailureException and invalidating the enviornment.
readNonKeyFields(Object, EntityInput, int, int, int) - Method in interface com.sleepycat.persist.impl.Accessor
Reads a range of non-key field values from the given EntityInput, reading fields in super classes first and in name order within class.
readNonKeyFields(Object, EntityInput, int, int, int) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
readNonKeyFields(Object, EntityInput, int, int, int) - Method in class com.sleepycat.persist.impl.RawAccessor
 
readNonKeyFields(Object, EntityInput, int, int, int) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ConverterReader
 
readObject() - Method in interface com.sleepycat.persist.impl.EntityInput
Called via Accessor to read all fields with reference types, except for the primary key field and composite key fields (see readKeyObject below).
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.EnumFormat
 
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.Format
Called after newInstance() to read the rest of the data bytes and fill in the object contents.
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.NonPersistentFormat
 
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
readObject() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readObject(Object, EntityInput, boolean) - Method in interface com.sleepycat.persist.impl.Reader
 
readObject() - Method in class com.sleepycat.persist.impl.RecordInput
 
readObject(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
readObject() - Method in class com.sleepycat.persist.impl.WidenerInput
 
ReadOnlyCatalog - Class in com.sleepycat.persist.impl
Read-only catalog operations used when initializing new formats.
ReadOnlyCatalog(ClassLoader, List<Format>, Map<String, Format>) - Constructor for class com.sleepycat.persist.impl.ReadOnlyCatalog
 
ReadonlyTxn - Class in com.sleepycat.je.rep.txn
A ReadonlyTxn represents a user initiated transaction on a Replica.
ReadonlyTxn(EnvironmentImpl, TransactionConfig) - Constructor for class com.sleepycat.je.rep.txn.ReadonlyTxn
 
readPackedInt() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads an unsorted packed integer.
readPackedInt(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
Read a packed int from the log.
readPackedLong() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads an unsorted packed long integer.
readPackedLong(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
Read a packed long from the log.
readPriKey(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
readPriKey(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.ConverterReader
 
readPriKey(Object, EntityInput, boolean) - Method in class com.sleepycat.persist.impl.Format
Reads the primary key from the given input bytes and sets the primary key field in the given object.
readPriKey(Object, EntityInput, boolean) - Method in interface com.sleepycat.persist.impl.Reader
 
readPriKeyField(Object, EntityInput) - Method in interface com.sleepycat.persist.impl.Accessor
Reads the primary key field value from the given EntityInput.
readPriKeyField(Object, EntityInput) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
readPriKeyField(Object, EntityInput) - Method in class com.sleepycat.persist.impl.RawAccessor
 
readPriKeyField(Object, EntityInput) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
readPrimaryAfterGet(Database, DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode, int) - Method in class com.sleepycat.je.Cursor
Reads the primary data for a primary key that was read via a secondary cursor, or a regular Cursor in the role of a secondary cursor.
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
readPrimitiveField(Object, EntityInput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
readProcessorMetadata(Environment, Transaction, SyncProcessor) - Method in class com.sleepycat.je.sync.impl.SyncDB
 
readProcessorMetadata(Transaction) - Method in class com.sleepycat.je.sync.SyncProcessor
Called internally by the SyncProcessor to read processor-specific configuration data, such as connection properties.
readProcessorTxnData(Environment, Transaction, String, String, DatabaseEntry) - Method in class com.sleepycat.je.sync.impl.SyncDB
 
readProcessorTxnData(Transaction, String, DatabaseEntry) - Method in class com.sleepycat.je.sync.SyncProcessor
Called internally by the SyncProcessor to read processor-specific transaction data.
readReverseInt(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
 
readSecKeyFields(Object, EntityInput, int, int, int) - Method in interface com.sleepycat.persist.impl.Accessor
Reads a range of secondary key field values from the given EntityInput, reading fields in super classes first and in name order within class.
readSecKeyFields(Object, EntityInput, int, int, int) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
readSecKeyFields(Object, EntityInput, int, int, int) - Method in class com.sleepycat.persist.impl.RawAccessor
 
readSecKeyFields(Object, EntityInput, int, int, int) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
readShort(int) - Method in class com.sleepycat.asm.ClassReader
Reads a signed short value in b.
readShort(byte[], int) - Static method in class com.sleepycat.asm.MethodWriter
Reads a signed short value in the given byte array.
readShort() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a signed short (two byte) value from the buffer.
readShort(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
Read a short from the log.
readShort() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readShort() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readShort() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readSortedBigDecimal() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a sorted BigDecimal, with support for correct default sorting.
readSortedBigDecimal() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readSortedBigDecimal() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readSortedBigDecimal() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readSortedDouble() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a sorted double (eight byte) value from the buffer.
readSortedDouble() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readSortedDouble() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readSortedDouble() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readSortedFloat() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a sorted float (four byte) value from the buffer.
readSortedFloat() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readSortedFloat() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readSortedFloat() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readSortedInt(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
Reads a sorted packed integer at the given buffer offset and returns it.
readSortedLong(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
Reads a sorted packed long integer at the given buffer offset and returns it.
readSortedPackedInt() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a sorted packed integer.
readSortedPackedLong() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a sorted packed long integer.
readString() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads a null-terminated UTF string from the data buffer and converts the data from UTF to Unicode.
readString(int) - Method in class com.sleepycat.bind.tuple.TupleInput
Reads the specified number of UTF characters string from the data buffer and converts the data from UTF to Unicode.
readString(char[]) - Method in class com.sleepycat.bind.tuple.TupleInput
Reads the specified number of UTF characters string from the data buffer and converts the data from UTF to Unicode.
readString(ByteBuffer, boolean, int) - Static method in class com.sleepycat.je.log.LogUtils
Read a string from the log.
readString() - Method in interface com.sleepycat.persist.impl.EntityInput
 
readString() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readString() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readStringObject() - Method in interface com.sleepycat.persist.impl.EntityInput
Called for a String field, that is not a primary key field or a composite key field with a reference type.
readStringObject() - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
readStringObject() - Method in class com.sleepycat.persist.impl.RecordInput
 
readStringObject() - Method in class com.sleepycat.persist.impl.WidenerInput
 
readTimestamp(ByteBuffer, boolean) - Static method in class com.sleepycat.je.log.LogUtils
Read a timestamp from the log.
readTriggers(ByteBuffer, int) - Static method in class com.sleepycat.je.dbi.TriggerUtils
Reads the triggers from a log buffer and returns then in their serialized byte array form.
readTypeFromLog(ByteBuffer, int) - Static method in enum com.sleepycat.je.log.entry.DbOperationType
 
readUncommittedAllowed - Variable in class com.sleepycat.collections.DataView
 
readUncommittedDefault - Variable in class com.sleepycat.je.txn.Locker
 
readUnsignedByte() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads an unsigned byte (one byte) value from the buffer.
readUnsignedInt() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads an unsigned int (four byte) value from the buffer.
readUnsignedInt(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
Unmarshall the next four bytes which hold an unsigned int into a long.
readUnsignedShort(int) - Method in class com.sleepycat.asm.ClassReader
Reads an unsigned short value in b.
readUnsignedShort(byte[], int) - Static method in class com.sleepycat.asm.MethodWriter
Reads an unsigned short value in the given byte array.
readUnsignedShort() - Method in class com.sleepycat.bind.tuple.TupleInput
Reads an unsigned short (two byte) value from the buffer.
readUTF8(int, char[]) - Method in class com.sleepycat.asm.ClassReader
Reads an UTF8 string constant pool item in b.
readVariablePortion(ByteBuffer) - Method in class com.sleepycat.je.log.LogEntryHeader
Assumes this is called directly after the constructor, and that the entryBuffer is positioned right before the VLSN.
readXid(ByteBuffer) - Static method in class com.sleepycat.je.log.LogUtils
 
reason - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol.Fail
 
rebuildINList(INList) - Method in class com.sleepycat.je.tree.IN
Add self and children to this in-memory IN list.
rebuildINList(INList) - Method in class com.sleepycat.je.tree.LN
Add yourself to the in memory list if you're a type of node that should belong.
rebuildINList(INList) - Method in class com.sleepycat.je.tree.Node
Add yourself to the in memory list if you're a type of node that should belong.
rebuildINList() - Method in class com.sleepycat.je.tree.Tree
rebuildINList is used by recovery to add all the resident nodes to the IN list.
rebuildINListMapDb() - Method in class com.sleepycat.je.dbi.DbTree
Rebuild the IN list after recovery.
recalcKeyPrefix() - Method in class com.sleepycat.je.tree.IN
Forces computation of the key prefix, without requiring a split.
recalculate(RepGroupImpl) - Method in class com.sleepycat.je.rep.impl.node.GlobalCBVLSN
Recalculate the cached, global CBVLSN.
recalculateGlobalCBVLSN() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Recalculate the Global CBVLSN, provoked by Replay, to ensure that the replica's global CBVLSN is up to date.
RECNO_METHOD - Static variable in class com.sleepycat.compat.DbCompat
 
recNumAccess - Variable in class com.sleepycat.collections.DataView
 
recNumAllowed - Variable in class com.sleepycat.collections.DataView
 
recNumRenumber - Variable in class com.sleepycat.collections.DataView
 
reconstituteBIN(DatabaseImpl) - Method in class com.sleepycat.je.tree.BINDelta
Create a BIN by fetching the full version and applying the deltas.
reconstituteBIN(DatabaseImpl, BIN) - Method in class com.sleepycat.je.tree.BINDelta
Given a full version BIN, apply the deltas.
record(DatabaseId, int) - Method in class com.sleepycat.je.recovery.LevelRecorder
 
Record - Class in com.sleepycat.je.rep.util.ldiff
 
Record(byte[], byte[], VLSN) - Constructor for class com.sleepycat.je.rep.util.ldiff.Record
 
RecordConverter - Interface in com.sleepycat.je.sync
Provides custom data conversion between records in an external table/view and raw data records in a local database.
recordCount - Variable in class com.sleepycat.je.dbi.DbTree.TruncateDbResult
 
recordExists() - Method in class com.sleepycat.je.dbi.CursorImpl.LockStanding
 
RecordInput - Class in com.sleepycat.persist.impl
Implements EntityInput to read record key-data pairs.
RecordInput(Catalog, boolean, DatabaseEntry, int, byte[], int, int) - Constructor for class com.sleepycat.persist.impl.RecordInput
Creates a new input with a empty/null visited map.
RecordMapping - Class in com.sleepycat.je.sync
Defines record conversion based on the fields/properties of a Java object, and uses a JE binding to convert between local raw records and Java objects.
RecordMapping(EntityBinding, boolean) - Constructor for class com.sleepycat.je.sync.RecordMapping
Creates a complete record mapping using an entity binding, with a null fieldMapping, fieldConverter, and newRecordClass.
RecordMapping(EntityBinding, boolean, Map<String, String>, boolean, Class) - Constructor for class com.sleepycat.je.sync.RecordMapping
Creates a record mapping using an entity binding, with an optional fieldMapping, fieldConverter, and newRecordClass.
RecordMapping(EntryBinding, EntryBinding, boolean) - Constructor for class com.sleepycat.je.sync.RecordMapping
Creates a complete record mapping using separate key and value bindings, with a null fieldMapping, fieldConverter, and newRecordClass.
RecordMapping(EntryBinding, EntryBinding, boolean, Map<String, String>, boolean, Class) - Constructor for class com.sleepycat.je.sync.RecordMapping
Creates a record mapping using separate key and value bindings, with an optional fieldMapping, fieldConverter, and newRecordClass.
RecordNumberBinding - Class in com.sleepycat.bind
 
RecordNumberBinding() - Constructor for class com.sleepycat.bind.RecordNumberBinding
Creates a byte array binding.
recordNumberToEntry(long, DatabaseEntry) - Static method in class com.sleepycat.bind.RecordNumberBinding
Utility method for use by bindings to translate a record number integer to a entry buffer.
RecordOutput - Class in com.sleepycat.persist.impl
Implements EntityOutput to write record key-data pairs.
RecordOutput(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.RecordOutput
Creates a new output with an empty/null visited map.
RecordVersion - Class in com.sleepycat.je.dbi
Used to return the VLSN and LSN for a record.
RecordVersion(long, long) - Constructor for class com.sleepycat.je.dbi.RecordVersion
 
recover(boolean) - Method in class com.sleepycat.je.recovery.RecoveryManager
Look for an existing log and use it to create an in memory structure for accessing existing databases.
recover(int) - Method in class com.sleepycat.je.XAEnvironment
 
recoveryEndFsyncInvisible() - Method in class com.sleepycat.je.recovery.RollbackTracker
 
RecoveryInfo - Class in com.sleepycat.je.recovery
RecoveryInfo keeps information about recovery processing.
RecoveryInfo() - Constructor for class com.sleepycat.je.recovery.RecoveryInfo
 
RecoveryManager - Class in com.sleepycat.je.recovery
 
RecoveryManager(EnvironmentImpl) - Constructor for class com.sleepycat.je.recovery.RecoveryManager
Make a recovery manager
RecoveryProgress - Enum in com.sleepycat.je
Describes the different phases of initialization that be executed when an Environment is instantiated.
RecoveryUtilizationTracker - Class in com.sleepycat.je.cleaner
Accumulates changes to the utilization profile during recovery.
RecoveryUtilizationTracker(EnvironmentImpl) - Constructor for class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
 
ReflectionAccessor - Class in com.sleepycat.persist.impl
Implements Accessor using reflection.
ReflectionAccessor(Catalog, Class, Accessor, FieldInfo, List<FieldInfo>, List<FieldInfo>) - Constructor for class com.sleepycat.persist.impl.ReflectionAccessor
Creates an accessor for a complex type.
ReflectionAccessor(Catalog, Class, List<FieldInfo>) - Constructor for class com.sleepycat.persist.impl.ReflectionAccessor
Creates an accessor for a composite key type.
refresh(PersistCatalog) - Method in class com.sleepycat.persist.impl.PersistEntityBinding
See Store.refresh.
refresh(PersistCatalog) - Method in class com.sleepycat.persist.impl.PersistKeyAssigner
See Store.refresh.
refresh(PersistCatalog) - Method in class com.sleepycat.persist.impl.PersistKeyBinding
See Store.refresh.
refresh(PersistCatalog) - Method in class com.sleepycat.persist.impl.PersistKeyCreator
See Store.refresh.
refresh() - Method in exception com.sleepycat.persist.impl.RefreshException
This method must be called to handle this exception in the binding methods, after the stack has unwound.
refresh(PersistCatalog, int, RefreshException) - Method in class com.sleepycat.persist.impl.Store
Called via RefreshException.refresh when handling the RefreshException in the binding methods, when a Replica detects that its in-memory metadata is stale.
refreshCachedGroup() - Method in class com.sleepycat.je.rep.impl.node.RepNode
This method must be invoked when a RepNode is first initialized and subsequently every time there is a change to the replication group.
RefreshException - Exception in com.sleepycat.persist.impl
Thrown and handled internally when metadata must be refreshed on a Replica.
RefreshException(Store, PersistCatalog, int) - Constructor for exception com.sleepycat.persist.impl.RefreshException
 
refreshTreeAdminMemoryUsage(long) - Method in class com.sleepycat.je.dbi.MemoryBudget
Called by INList when clearing tree memory usage.
refreshTreeMemoryUsage(long) - Method in class com.sleepycat.je.dbi.MemoryBudget
Called by INList when recalculating tree memory usage.
register(RollbackEnd, long) - Method in class com.sleepycat.je.recovery.RollbackTracker
Construction Pass: A RollbackEnd is seen, make new period.
register(RollbackStart, long) - Method in class com.sleepycat.je.recovery.RollbackTracker
Construction Pass: A RollbackStart is seen.
register(NamedChannelWithTimeout) - Method in class com.sleepycat.je.rep.impl.node.ChannelTimeoutTask
Registers a channel so that the timer can make periodic calls to isActive().
register() - Method in class com.sleepycat.je.rep.monitor.Monitor
Registers the monitor with the group so that it can be kept informed of the outcome of elections and group membership changes.
register(String, BlockingQueue<SocketChannel>) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
Registers a service queue with the ServiceDispatcher.
register(ServiceDispatcher.Service) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
 
register(Stat<?>) - Method in class com.sleepycat.je.utilint.StatGroup
Add a stat to the group.
registerAppStateMonitor(AppStateMonitor) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Register an AppStateMonitor with this RepNode.
registerAppStateMonitor(AppStateMonitor) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Registers an AppStateMonitor to receive the application state which this ReplicatedEnvironment is running in.
registerClass(String, Enhanced) - Static method in class com.sleepycat.persist.impl.EnhancedAccessor
Registers a prototype instance, and should be called during initialization of the prototype class.
registerClass(Class) - Method in class com.sleepycat.persist.model.EntityModel
Registers a persistent class, most importantly, a PersistentProxy class or entity subclass.
registerCursor(CursorImpl) - Method in class com.sleepycat.je.txn.BasicLocker
This txn doesn't store cursors.
registerCursor(CursorImpl) - Method in class com.sleepycat.je.txn.Locker
Tell this transaction about a cursor.
registerCursor(CursorImpl) - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Forwards this method to the transactional buddy.
registerCursor(CursorImpl) - Method in class com.sleepycat.je.txn.Txn
Increase the counter if a new Cursor is opened under this transaction.
registerDataSet(SyncDataSet) - Method in class com.sleepycat.je.sync.SyncProcessor
registerEntity(Object, int) - Method in class com.sleepycat.persist.impl.RecordInput
Registers the top level entity before reading it, to allow nested fields to reference their parent entity.
registerEntity(Object) - Method in class com.sleepycat.persist.impl.RecordOutput
Registers the top level entity before writing it, to allow nested fields to reference their parent entity.
registerEntityFormat(Format) - Method in class com.sleepycat.persist.impl.RecordInput
Registers the entity format before reading it, so that old-format String fields can be read properly.
registerExceptionListenerUser(ExceptionListenerUser) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
registerLsn(long) - Method in class com.sleepycat.je.log.LogBuffer
This LSN has been written to the log.
registerMatchpoint(VLSN) - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNTracker
Initialize the local CBVLSN with the syncup matchpoint, so that the heartbeat responses sent before the node has replayed any log entries are still valid for saving a place in the replication stream.
registerMBean(Environment) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
registerPriKeyObject(Object) - Method in interface com.sleepycat.persist.impl.EntityInput
Called via Accessor.readSecKeyFields for a primary key field with a reference type.
registerPriKeyObject(Object) - Method in interface com.sleepycat.persist.impl.EntityOutput
Called via Accessor.writeSecKeyFields for a primary key field with a reference type.
registerPriKeyObject(Object) - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
registerPriKeyObject(Object) - Method in class com.sleepycat.persist.impl.RecordInput
 
registerPriKeyObject(Object) - Method in class com.sleepycat.persist.impl.RecordOutput
 
registerPriKeyObject(Object) - Method in class com.sleepycat.persist.impl.WidenerInput
 
registerPriStringKeyObject(Object) - Method in interface com.sleepycat.persist.impl.EntityInput
Called via Accessor.readSecKeyFields for a primary String key field.
registerPriStringKeyObject(Object) - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
registerPriStringKeyObject(Object) - Method in class com.sleepycat.persist.impl.RecordInput
 
registerPriStringKeyObject(Object) - Method in class com.sleepycat.persist.impl.WidenerInput
 
registerThreadLocker(ThreadLocker) - Method in class com.sleepycat.je.txn.LockManager
Called when a ThreadLocker is created.
registerTxn(Txn) - Method in class com.sleepycat.je.txn.TxnManager
Called when txn is created.
registerVLSN(LogItem) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
registerVLSN(LogItem) - Method in class com.sleepycat.je.rep.impl.RepImpl
A replicated log entry has been written on this node.
registerWithActiveTxns(Map<Long, ReplayTxn>) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
registerXATxn(Xid, Txn, boolean) - Method in class com.sleepycat.je.txn.TxnManager
Called when txn is created.
reinformLearners(Set<InetSocketAddress>, ExecutorService) - Method in class com.sleepycat.je.rep.elections.Learner
A method to re-broadcast this Learner's notion of the master.
reinit() - Method in class com.sleepycat.je.log.LogBuffer
 
reinit(long, long) - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
Invoked each time after a replica syncup so that the Replica can re-establish it's consistency vis a vis the master and what part of the replication stream it considers as having been replayed.
reinitFirstNode(VLSN) - Method in class com.sleepycat.je.rep.impl.RepGroupDB
Deletes all the current members from the rep group database and creates a new group, with just the member supplied via the configuration.
reinitSelfElect() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Establishes this node as the master, after re-initializing the group with this as the sole node in the group.
REJECT - Variable in class com.sleepycat.je.rep.elections.Protocol
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class com.sleepycat.je.evictor.Evictor.RejectEvictHandler
 
RelatchRequiredException - Exception in com.sleepycat.je.utilint
 
relatchRequiredException - Static variable in exception com.sleepycat.je.utilint.RelatchRequiredException
 
Relationship - Enum in com.sleepycat.persist.model
Defines the relationship between instances of the entity class and the secondary keys.
release() - Method in class com.sleepycat.je.latch.Latch
Release the latch.
release() - Method in class com.sleepycat.je.latch.SharedLatch
Release an exclusive or shared latch.
release() - Method in class com.sleepycat.je.log.FileHandle
 
release() - Method in class com.sleepycat.je.log.FileHandleSource
 
release() - Method in class com.sleepycat.je.log.FileSource
 
release() - Method in class com.sleepycat.je.log.LogBuffer
 
release() - Method in interface com.sleepycat.je.log.LogSource
We're done with this log source.
release(Locker, MemoryBudget, int) - Method in interface com.sleepycat.je.txn.Lock
Releases a lock and moves the next waiter(s) to the owners.
release(Locker, MemoryBudget, int) - Method in class com.sleepycat.je.txn.LockImpl
Releases a lock and moves the next waiter(s) to the owners.
release(long, Locker) - Method in class com.sleepycat.je.txn.LockManager
Release a lock and possibly notify any waiters that they have been granted the lock.
release(Locker, MemoryBudget, int) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
release() - Method in class com.sleepycat.je.utilint.TimingLatch
 
releaseAndFindNotifyTargets(long, Locker) - Method in class com.sleepycat.je.txn.DummyLockManager
 
releaseAndFindNotifyTargets(long, Locker) - Method in class com.sleepycat.je.txn.LockManager
Release the lock, and return the set of new owners to notify, if any.
releaseAndFindNotifyTargets(long, Locker) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
releaseAndFindNotifyTargetsInternal(long, Locker, int) - Method in class com.sleepycat.je.txn.LockManager
Do the real work of releaseAndFindNotifyTargets
releaseAwait(Exception) - Method in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareCountDownLatch
The method used to free an await, ensuring that it throws an exception at the awaitOrException.
releaseBIN() - Method in class com.sleepycat.je.dbi.CursorImpl
 
releaseDatabaseImpl(DatabaseImpl) - Method in class com.sleepycat.je.cleaner.BaseLocalUtilizationTracker
Must be called after calling databaseKeyToDatabaseImpl.
releaseDatabaseImpl(DatabaseImpl) - Method in class com.sleepycat.je.cleaner.LocalUtilizationTracker
Do nothing, since DbTree.getDb was not called by databaseKeyToDatabaseImpl.
releaseDatabaseImpl(DatabaseImpl) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Must release the database, since DbTree.getDb was called by databaseKeyToDatabaseImpl.
releaseDb(DatabaseImpl) - Method in class com.sleepycat.je.dbi.DbTree
Decrements the use count of the given DB, allowing it to be evicted if the use count reaches zero.
releaseDb() - Method in class com.sleepycat.je.txn.UndoReader
 
releaseDbs(Map<DatabaseId, DatabaseImpl>) - Method in class com.sleepycat.je.dbi.DbTree
Calls releaseDb for all DBs in the given map of DatabaseId to DatabaseImpl.
releaseDbs() - Method in interface com.sleepycat.je.evictor.Evictor.DbCache
Calls DbTree.releaseDb for cached DBs, and clears the cache.
releaseExclusiveLock() - Method in class com.sleepycat.je.log.FileManager
 
releaseIfOwner() - Method in class com.sleepycat.je.latch.Latch
Release the latch.
releaseIfOwner() - Method in class com.sleepycat.je.latch.SharedLatch
Release the latch.
releaseLatch() - Method in class com.sleepycat.je.tree.IN
Release the latch on this node.
releaseLatch() - Method in class com.sleepycat.je.tree.Node
 
releaseLatchIfOwner() - Method in class com.sleepycat.je.tree.IN
Release the latch on this node.
releaseLock(long) - Method in class com.sleepycat.je.txn.Locker
Release the lock on this LN and remove from the transaction's owning set.
releaseLock(long) - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Releases the lock from this locker, or if not owned by this locker then releases it from the buddy locker.
releaseMemoryBudget() - Method in class com.sleepycat.je.tree.LN
Release the memory budget for any objects referenced by this LN.
releaseMemoryBudget() - Method in class com.sleepycat.je.tree.MapLN
 
releaseNonTxnLocks() - Method in class com.sleepycat.je.txn.BasicLocker
Releases all locks, since all locks held by this locker are non-transactional.
releaseNonTxnLocks() - Method in class com.sleepycat.je.txn.BuddyLocker
Forwards this call to the base class and to the buddy locker.
releaseNonTxnLocks() - Method in class com.sleepycat.je.txn.Locker
Releases any non-transactional locks held by this locker.
releaseNonTxnLocks() - Method in class com.sleepycat.je.txn.Txn
This locker holds no non-transactional locks.
releasePoll(Exception) - Method in class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareBlockingQueue
 
releaseRootIN(IN) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
Release the latch.
releaseRootLatch() - Method in class com.sleepycat.je.tree.Tree
 
releaseTreeAdminMemory() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Update memory budgets when this databaseImpl is closed and will never be accessed again or when it is still open when its owning MapLN will be garbage collected, due to eviction or recovery.
releaseWriteLocks() - Method in class com.sleepycat.je.txn.Txn
Releases all write locks, nulls the lock collection.
remaining() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
REMOTE_DIFF_REQUEST - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
REMOTE_RECORD - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
remove(Handler, Label, Label) - Static method in class com.sleepycat.asm.Handler
Removes the range between start and end from the given exception handlers.
remove() - Method in class com.sleepycat.collections.BlockIterator
 
remove(Object) - Method in class com.sleepycat.collections.StoredEntrySet
Removes the specified element from this set if it is present (optional operation).
remove() - Method in class com.sleepycat.collections.StoredIterator
Removes the last element that was returned by next or previous (optional operation).
remove(Object) - Method in class com.sleepycat.collections.StoredKeySet
Removes the specified key from this set if it is present (optional operation).
remove(int) - Method in class com.sleepycat.collections.StoredList
Removes the element at the specified position in this list (optional operation).
remove(Object) - Method in class com.sleepycat.collections.StoredList
Removes the first occurrence in this list of the specified element (optional operation).
remove(Object) - Method in class com.sleepycat.collections.StoredMap
Removes the mapping for this key from this map if present (optional operation).
remove(Object, Object) - Method in class com.sleepycat.collections.StoredMap
Remove entry for key only if currently mapped to given value.
remove(Object) - Method in class com.sleepycat.collections.StoredValueSet
Removes the specified value from this set if it is present (optional operation).
remove(Long) - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
Removes the DbFileSummary for the given file.
remove(IN) - Method in class com.sleepycat.je.dbi.INList
An IN is being evicted.
remove(Block) - Method in class com.sleepycat.je.rep.util.ldiff.BlockBag
Removes the given Block, plus any blocks inserted previous to the given Block.
remove(Object) - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
It's synchronized so that size() has a stable value in the above methods.
remove() - Method in class com.sleepycat.je.sync.impl.LogChangeReader.LogChangeIterator
 
remove(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
remove(Transaction) - Method in interface com.sleepycat.je.trigger.PersistentTrigger
The trigger method invoked after the successful removal of a primary Database.
remove(T) - Method in class com.sleepycat.je.utilint.TinyHashSet
 
remove() - Method in class com.sleepycat.je.utilint.TinyHashSet.SingleElementIterator
 
remove() - Method in class com.sleepycat.persist.BasicIterator
 
REMOVE_MEMBER - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
removeAll(Collection<?>) - Method in class com.sleepycat.collections.StoredCollection
Removes all this collection's elements that are also contained in the specified collection (optional operation).
removeAll() - Method in class com.sleepycat.je.rep.util.ldiff.BlockBag
Removes all blocks from the bag.
removeAllFileReferences(Long, MemoryBudget) - Method in class com.sleepycat.je.cleaner.FileSelector
Removes all references to a file.
removeBuddy(BuddyLocker) - Method in class com.sleepycat.je.txn.Locker
By default the set of buddy lockers is not maintained.
removeBuddy(BuddyLocker) - Method in class com.sleepycat.je.txn.Txn
 
removeConfigObserver(EnvConfigObserver) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Removes an observer of mutable config changes.
removeConnectionEventListener(ConnectionEventListener) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
removeCursor(ForwardCursor) - Method in class com.sleepycat.je.Database
 
removeCursor(CursorImpl) - Method in class com.sleepycat.je.tree.BIN
Unregister a cursor with this bin.
removeData(byte[]) - Static method in class com.sleepycat.je.dbi.DupKeyData
Splits twoPartKey and returns a two-part key entry containing the key portion from twoPartKey, no data, and the special PREFIX_ONLY value for the key length.
removeDatabase(Environment, Transaction, String, String) - Static method in class com.sleepycat.compat.DbCompat
Returns false if the database is not found.
removeDatabase(Transaction, String) - Method in class com.sleepycat.je.Environment
Removes a database from the environment, discarding all records in the database and removing the database name itself.
removeDatabase(String) - Method in class com.sleepycat.je.jca.ra.JEConnection
 
removeDatabase(String) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
removeDataSet(String) - Method in class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
 
removeDataSet(String) - Method in class com.sleepycat.je.sync.mobile.MobileSyncProcessor
 
removeDataSet(String) - Method in class com.sleepycat.je.sync.ProcessorMetadata
 
removeDataSet(String) - Method in class com.sleepycat.je.sync.SyncProcessor
Removes a data set that is managed by this processor.
removeDbBackup(DbBackup) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For replicated environments only; do nothing for a standalone environment.
removeDbBackup(DbBackup) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
removeDbFileSummaries(Object) - Method in class com.sleepycat.je.cleaner.BaseLocalUtilizationTracker
Deallocates all DbFileSummary objects for the given database key.
removeDbFileSummaries(Collection<Long>) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Removes the DbFileSummary for the given set of files.
removeDbFileSummaries(DatabaseImpl, Collection<Long>) - Method in class com.sleepycat.je.log.LogManager
 
removeDbFileSummaries(DatabaseImpl, Collection<Long>) - Method in class com.sleepycat.je.log.SyncedLogManager
 
removeDbFileSummariesInternal(DatabaseImpl, Collection<Long>) - Method in class com.sleepycat.je.log.LogManager
 
removeDeletedFile(Long, MemoryBudget) - Method in class com.sleepycat.je.cleaner.FileSelector
Removes file information after the log file itself has finally been deleted.
removeEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.Evictor
 
removeEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.PrivateSelector
Only supported by SharedSelector.
removeEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.SharedSelector
Synchronized so that the set of environments cannot be changed in the middle of an eviction (which is also synchronized).
removeEnvironment(EnvironmentImpl) - Method in class com.sleepycat.je.evictor.TargetSelector
Only supported by SharedEvictor.
removeFeeder(Feeder) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Remove the feeder from the sets used to track it.
removeFile(Long, Set<DatabaseId>) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Removes a file from the MapLN utilization info, the utilization database and the profile, after it has been determined that the file does not exist.
removeFromHead(EnvironmentImpl, VLSN) - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
 
removeFromHead(EnvironmentImpl, VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Remove the mappings from this bucket that are for VLSNs <= lastDuplicate.
removeFromTail(VLSN, long) - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
 
removeFromTail(VLSN, long) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Remove the mappings from this bucket that are for VLSNs >= startOfDelete.
removeGraphFrame(ObjectName, String) - Method in class com.sleepycat.je.jmx.plugin.Stats
 
removeKey(Object, Object[]) - Method in class com.sleepycat.collections.StoredContainer
 
removeLevel(Integer) - Method in class com.sleepycat.je.recovery.DirtyINMap
Removes the set corresponding to the given level.
removeListener(Learner.Listener) - Method in class com.sleepycat.je.rep.elections.Learner
Removes a Listeners from the existing set of listeners.
removeLock(long) - Method in class com.sleepycat.je.txn.BasicLocker
Remove a lock from the set owned by this txn.
removeLock(long) - Method in class com.sleepycat.je.txn.Locker
Remove the lock from the set owned by this transaction.
removeLock(long) - Method in class com.sleepycat.je.txn.Txn
Remove the lock from the set owned by this transaction.
removeMember(String) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Removes a node so that it's no longer a member of the group.
removeMember(RepNodeImpl) - Method in class com.sleepycat.je.rep.impl.RepGroupDB
Deletes a node from the replication group by marking it as such in the rep group db.
removeMember(String) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Removes a member transiently from the rep group by marking it as being deleted.
removeMember(String) - Method in class com.sleepycat.je.rep.util.DbGroupAdmin
Remove a node from the replication group.
removeMember(String) - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Removes this node from the group, so that it is no longer a member of the group.
removeNextNode(Integer) - Method in class com.sleepycat.je.recovery.DirtyINMap
 
removeNode(Integer, Long) - Method in class com.sleepycat.je.recovery.DirtyINMap
 
removePendingDB(DatabaseId) - Method in class com.sleepycat.je.cleaner.FileSelector
Removes the DatabaseId from the pending DB set.
removePendingLN(long) - Method in class com.sleepycat.je.cleaner.FileSelector
Removes the LN for the given LSN from the pending LN set.
removePerDbMetadata(Collection<Long>, Set<DatabaseId>) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Updates all MapLNs to remove the DbFileSummary for the given set of file.
removePerFileMetadata(Long) - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Removes a file from the utilization database and the profile.
removeProtectedFileRange(long) - Method in class com.sleepycat.je.cleaner.Cleaner
Removes a range of log files to be protected after calling Cleaner.addProtectedFileRange(long).
removeReferringHandle(Database) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Decrement the reference count.
removeReferringHandle(Database) - Method in class com.sleepycat.je.Environment
The referring db has been closed.
removeReferringHandle(Transaction) - Method in class com.sleepycat.je.Environment
The referring Transaction has been closed.
removeReplicaDb(Locker, String, DatabaseId, DbOpReplicationContext) - Method in class com.sleepycat.je.dbi.DbTree
Replica invocations.
removeSequence(Transaction, DatabaseEntry) - Method in class com.sleepycat.je.Database
Removes the sequence from the database.
removeTrackedFile(TrackedFileSummary) - Method in class com.sleepycat.je.log.LogManager
Removes the tracked summary for the given file.
removeTrackedFile(TrackedFileSummary) - Method in class com.sleepycat.je.log.SyncedLogManager
 
removeTrackedFileInternal(TrackedFileSummary) - Method in class com.sleepycat.je.log.LogManager
 
removeTrigger(DatabaseTrigger) - Method in class com.sleepycat.je.Database
Removes a given trigger from the list of triggers.
removeTrigger(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
removeTrigger(Transaction) - Method in interface com.sleepycat.je.trigger.Trigger
The trigger method invoked when this trigger is removed from the database, either as a result of opening the database with a different trigger configuration, or because the database it was associated with it has been removed.
removeValue(Object) - Method in class com.sleepycat.collections.StoredContainer
 
rename(Transaction, String) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
rename(Transaction, String) - Method in interface com.sleepycat.je.trigger.PersistentTrigger
The trigger method invoked after the successful renaming of a primary Database.
renameAndRemoveDatabases(Store, Transaction) - Method in class com.sleepycat.persist.impl.Evolver
 
renameDatabase(Environment, Transaction, String, String, String, String) - Static method in class com.sleepycat.compat.DbCompat
Returns false if the database is not found.
renameDatabase(Transaction, String, String) - Method in class com.sleepycat.je.Environment
Renames a database, without removing the records it contains.
renameFile(long, String) - Method in class com.sleepycat.je.log.FileManager
Rename this file to NNNNNNNN.suffix.
Renamer - Class in com.sleepycat.persist.evolve
A mutation for renaming a class or field without changing the instance or field value.
Renamer(String, int, String) - Constructor for class com.sleepycat.persist.evolve.Renamer
Creates a mutation for renaming the class of all instances of the given class version.
Renamer(String, int, String, String) - Constructor for class com.sleepycat.persist.evolve.Renamer
Creates a mutation for renaming the given field for all instances of the given class version.
renameReplicaDb(Locker, String, String, NameLN, DbOpReplicationContext) - Method in class com.sleepycat.je.dbi.DbTree
Replica invocations.
renameSecondaryDatabase(String, String, String, String) - Method in class com.sleepycat.persist.impl.Evolver
Called by ComplexFormat when a secondary key name is changed.
REP_GROUP_OPEN_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
REP_GROUP_READ_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
REP_PARAM_PREFIX - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
REP_STREAM_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
The maximum amount of time the replication group guarantees preservation of the log files constituting the replication stream.
REP_STREAM_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The maximum amount of time the replication group guarantees preservation of the log files constituting the replication stream.
repair(EnvironmentImpl) - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
Removes entries for deleted files that were created by JE 3.3.74 and earlier.
RepConfigManager - Class in com.sleepycat.je.rep.impl
 
RepConfigManager(EnvironmentConfig, RepConfigProxy) - Constructor for class com.sleepycat.je.rep.impl.RepConfigManager
 
RepConfigProxy - Interface in com.sleepycat.je.dbi
Used to pass a replication configuration instance through the non-HA code.
repContext - Variable in class com.sleepycat.je.log.LogItem
Whether the logged entry should be replicated.
repContext - Variable in class com.sleepycat.je.txn.Txn
 
repeatAddTrigger(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatAddTrigger(Transaction) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
The trigger method invoked when an addTrigger operation needs to be repeated.
repeatCreate(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatCreate(Transaction) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
The trigger method invoked when a database create trigger needs to be repeated.
repeatDelete(Transaction, DatabaseEntry) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatDelete(Transaction, DatabaseEntry) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
The trigger method invoked when a database delete trigger needs to be repeated.
repeatPut(Transaction, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatPut(Transaction, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
The trigger method invoked when a database put trigger needs to be repeated.
repeatRemove(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatRemove(Transaction) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
The trigger method invoked when a database remove trigger needs to be repeated.
repeatRemoveTrigger(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatRemoveTrigger(Transaction) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
The trigger method invoked when a removeTrigger operation needs to be repeated.
repeatRename(Transaction, String) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatRename(Transaction, String) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
The trigger method invoked when a database rename trigger needs to be repeated.
repeatTransaction(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatTransaction(Transaction) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
Used to inform the application that the trigger method calls associated with the partial transaction will be repeated.
repeatTruncate(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
repeatTruncate(Transaction) - Method in interface com.sleepycat.je.trigger.ReplicatedDatabaseTrigger
The trigger method invoked when a database truncate trigger needs to be repeated.
RepEnvConfigObserver - Interface in com.sleepycat.je.rep.impl
Implemented by observers of mutable rep config changes.
repEnvConfigUpdate(RepConfigManager, ReplicationMutableConfig) - Method in interface com.sleepycat.je.rep.impl.RepEnvConfigObserver
Notifies the observer that one or more mutable rep properties have been changed.
repEnvConfigUpdate(RepConfigManager, ReplicationMutableConfig) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
repGroupDB - Variable in class com.sleepycat.je.rep.impl.node.RepNode
 
RepGroupDB - Class in com.sleepycat.je.rep.impl
This class is used to encapsulate all access to the rep group data that is present in every replicated JE environment.
RepGroupDB(RepImpl) - Constructor for class com.sleepycat.je.rep.impl.RepGroupDB
Create an instance.
RepGroupDB.GroupBinding - Class in com.sleepycat.je.rep.impl
 
RepGroupDB.GroupBinding() - Constructor for class com.sleepycat.je.rep.impl.RepGroupDB.GroupBinding
 
RepGroupDB.NodeBinding - Class in com.sleepycat.je.rep.impl
Supports the serialization/deserialization of node info into and out of the database.
RepGroupDB.NodeBinding() - Constructor for class com.sleepycat.je.rep.impl.RepGroupDB.NodeBinding
 
RepGroupImpl - Class in com.sleepycat.je.rep.impl
Represents a snapshot of the Replication Group as a whole.
RepGroupImpl(String) - Constructor for class com.sleepycat.je.rep.impl.RepGroupImpl
Constructor to create a new empty repGroup, typically as part of environment initialization.
RepGroupImpl(String, boolean) - Constructor for class com.sleepycat.je.rep.impl.RepGroupImpl
 
RepGroupImpl(String, UUID, int, int, int, Map<Integer, RepNodeImpl>) - Constructor for class com.sleepycat.je.rep.impl.RepGroupImpl
Constructor used to recreate an existing RepGroup, typically as part of a deserialization operation.
repGroupImpl - Variable in class com.sleepycat.je.rep.ReplicationGroup
 
RepGroupImpl.BarrierState - Class in com.sleepycat.je.rep.impl
Encapsulates the last known syncup state associated with a node.
RepGroupImpl.BarrierState(VLSN, long) - Constructor for class com.sleepycat.je.rep.impl.RepGroupImpl.BarrierState
 
RepGroupImpl.NodeConflictException - Exception in com.sleepycat.je.rep.impl
 
RepGroupImpl.NodeConflictException(String) - Constructor for exception com.sleepycat.je.rep.impl.RepGroupImpl.NodeConflictException
 
RepGroupImpl.Predicate - Class in com.sleepycat.je.rep.impl
 
RepGroupImpl.Predicate() - Constructor for class com.sleepycat.je.rep.impl.RepGroupImpl.Predicate
 
RepGroupProtocol - Class in com.sleepycat.je.rep.impl
Defines the protocol used in support of group membership.
RepGroupProtocol(String, NameIdPair, RepImpl) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol
 
RepGroupProtocol.EnsureNode - Class in com.sleepycat.je.rep.impl
 
RepGroupProtocol.EnsureNode(RepNodeImpl) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureNode
 
RepGroupProtocol.EnsureNode(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureNode
 
RepGroupProtocol.EnsureOK - Class in com.sleepycat.je.rep.impl
 
RepGroupProtocol.EnsureOK(NameIdPair) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureOK
 
RepGroupProtocol.EnsureOK(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureOK
 
RepGroupProtocol.Fail - Class in com.sleepycat.je.rep.impl
Extends the class Fail, adding a reason code to distinguish amongst different types of failures.
RepGroupProtocol.Fail(RepGroupProtocol.FailReason, String) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.Fail
 
RepGroupProtocol.Fail(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.Fail
 
RepGroupProtocol.FailReason - Enum in com.sleepycat.je.rep.impl
 
RepGroupProtocol.GroupRequest - Class in com.sleepycat.je.rep.impl
 
RepGroupProtocol.GroupRequest() - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupRequest
 
RepGroupProtocol.GroupRequest(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupRequest
 
RepGroupProtocol.GroupResponse - Class in com.sleepycat.je.rep.impl
 
RepGroupProtocol.GroupResponse(RepGroupImpl) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupResponse
 
RepGroupProtocol.GroupResponse(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupResponse
 
RepGroupProtocol.RemoveMember - Class in com.sleepycat.je.rep.impl
 
RepGroupProtocol.RemoveMember(String) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.RemoveMember
 
RepGroupProtocol.RemoveMember(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.RemoveMember
 
RepGroupProtocol.TransferMaster - Class in com.sleepycat.je.rep.impl
 
RepGroupProtocol.TransferMaster(String, long, boolean) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferMaster
 
RepGroupProtocol.TransferMaster(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferMaster
 
RepGroupProtocol.TransferOK - Class in com.sleepycat.je.rep.impl
 
RepGroupProtocol.TransferOK(String) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferOK
 
RepGroupProtocol.TransferOK(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferOK
 
RepGroupProtocol.UpdateAddress - Class in com.sleepycat.je.rep.impl
 
RepGroupProtocol.UpdateAddress(String, String, int) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.UpdateAddress
 
RepGroupProtocol.UpdateAddress(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.RepGroupProtocol.UpdateAddress
 
RepImpl - Class in com.sleepycat.je.rep.impl
 
RepImpl(File, EnvironmentConfig, EnvironmentImpl, RepConfigProxy) - Constructor for class com.sleepycat.je.rep.impl.RepImpl
 
RepImplStatDefinition - Class in com.sleepycat.je.rep.impl
General information for replicated nodes.
RepImplStatDefinition() - Constructor for class com.sleepycat.je.rep.impl.RepImplStatDefinition
 
RepInternal - Class in com.sleepycat.je.rep
 
RepInternal() - Constructor for class com.sleepycat.je.rep.RepInternal
 
RepJEDiagnostics - Class in com.sleepycat.je.rep.jmx
 
RepJEDiagnostics(Environment) - Constructor for class com.sleepycat.je.rep.jmx.RepJEDiagnostics
 
RepJEDiagnostics() - Constructor for class com.sleepycat.je.rep.jmx.RepJEDiagnostics
 
RepJEMonitor - Class in com.sleepycat.je.rep.jmx
A concrete MBean for monitoring a replicated open JE Environment.
RepJEMonitor(Environment) - Constructor for class com.sleepycat.je.rep.jmx.RepJEMonitor
 
RepJEMonitor() - Constructor for class com.sleepycat.je.rep.jmx.RepJEMonitor
 
RepJEStats - Class in com.sleepycat.je.rep.jmx.plugin
 
RepJEStats(MBeanServerConnection) - Constructor for class com.sleepycat.je.rep.jmx.plugin.RepJEStats
 
RepJEStatsPlugin - Class in com.sleepycat.je.rep.jmx.plugin
 
RepJEStatsPlugin() - Constructor for class com.sleepycat.je.rep.jmx.plugin.RepJEStatsPlugin
 
replace(K, V) - Method in class com.sleepycat.collections.StoredMap
Replace entry for key only if currently mapped to some value.
replace(K, V, V) - Method in class com.sleepycat.collections.StoredMap
Replace entry for key only if currently mapped to given value.
replaceData(byte[], byte[]) - Static method in class com.sleepycat.je.dbi.DupKeyData
Splits twoPartKey and returns a two-part key entry containing the key portion of twoPartKey combined with newData.
Replay - Class in com.sleepycat.je.rep.impl.node
Replays log records from the replication stream, and manages the transactions for those records.
Replay(RepImpl, NameIdPair) - Constructor for class com.sleepycat.je.rep.impl.node.Replay
 
replay() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
Replay.TxnInfo - Class in com.sleepycat.je.rep.impl.node
Simple helper class to package a Txn vlsn and its associated commit time.
REPLAY_DB_HANDLE_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
REPLAY_DB_HANDLE_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
REPLAY_DB_HANDLE_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationMutableConfig
The maximum amount of time that an inactive database handle is kept open during a replay of the replication stream.
REPLAY_LOGGING_THRESHOLD - Static variable in class com.sleepycat.je.rep.impl.RepParams
Used to log an info message when the time taken to replay a single log entry at a replica exceeds this threshold.
REPLAY_MAX_OPEN_DB_HANDLES - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
REPLAY_MAX_OPEN_DB_HANDLES - Static variable in class com.sleepycat.je.rep.ReplicationConfig
REPLAY_MAX_OPEN_DB_HANDLES - Static variable in class com.sleepycat.je.rep.ReplicationMutableConfig
The maximum number of most recently used database handles that are kept open during the replay of the replication stream.
REPLAY_TXN_LOCK_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
The lock timeout for replay transactions.
REPLAY_TXN_LOCK_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The maximum amount of time for a replay transaction to wait for a lock.
replayEntry(NamedChannel, Protocol, Protocol.Entry) - Method in class com.sleepycat.je.rep.impl.node.Replay
Apply the operation represented by this log entry on this replica node.
ReplayStatDefinition - Class in com.sleepycat.je.rep.impl.node
Per-stat Metadata for HA Replay statistics.
ReplayStatDefinition() - Constructor for class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
ReplayTxn - Class in com.sleepycat.je.rep.txn
Used for replaying replicated operations at replica nodes.
ReplayTxn(EnvironmentImpl, TransactionConfig, long, Map<Long, ReplayTxn>, Logger) - Constructor for class com.sleepycat.je.rep.txn.ReplayTxn
Used when creating ReplayTxns for Replay.
ReplayTxn(EnvironmentImpl, TransactionConfig, long, Logger) - Constructor for class com.sleepycat.je.rep.txn.ReplayTxn
Used when creating ReplayTxns at recovery.
replayTxns - Variable in class com.sleepycat.je.recovery.RecoveryInfo
ReplayTxns that are resurrected during recovery processing, for replication.
Replica - Class in com.sleepycat.je.rep.impl.node
The Replica class is the locus of the replay operations and replica transaction consistency tracking and management operations at a replica node.
Replica(RepNode, Replay) - Constructor for class com.sleepycat.je.rep.impl.node.Replica
 
replica() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
Replica.ConnectRetryException - Exception in com.sleepycat.je.rep.impl.node
 
Replica.ConnectRetryException(String, int, int) - Constructor for exception com.sleepycat.je.rep.impl.node.Replica.ConnectRetryException
 
Replica.ConsistencyTracker - Class in com.sleepycat.je.rep.impl.node
Tracks the consistency of this replica wrt the Master.
Replica.ConsistencyTracker() - Constructor for class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
 
Replica.HardRecoveryElectionException - Exception in com.sleepycat.je.rep.impl.node
Indicates that an election is needed before the hard recovery can proceed.
Replica.HardRecoveryElectionException(NameIdPair, VLSN, VLSN) - Constructor for exception com.sleepycat.je.rep.impl.node.Replica.HardRecoveryElectionException
 
Replica.ReplayThread - Class in com.sleepycat.je.rep.impl.node
The thread responsible for the replay of messages delivered over the replication stream.
Replica.ReplayThread(EnvironmentImpl, String) - Constructor for class com.sleepycat.je.rep.impl.node.Replica.ReplayThread
 
Replica.RetryException - Exception in com.sleepycat.je.rep.impl.node
Thrown to indicate that the Replica must retry connecting to the same master, after some period of time.
Replica.RetryException(String, int, int) - Constructor for exception com.sleepycat.je.rep.impl.node.Replica.RetryException
 
REPLICA_ACK_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
REPLICA_ACK_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The amount of time that the Transaction.commit(com.sleepycat.je.Durability) on the Master will wait for a sufficient number of acknowledgments from the Replicas.
REPLICA_JE_VERSIONS - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
REPLICA_MESSAGE_QUEUE_SIZE - Static variable in class com.sleepycat.je.rep.impl.RepParams
The size of the message queue used for communication between the thread reading the replication stream and the thread doing the replay.
REPLICA_PROTOCOL_VERSION - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
REPLICA_RECEIVE_BUFFER_SIZE - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
REPLICA_RECEIVE_BUFFER_SIZE - Static variable in class com.sleepycat.je.rep.ReplicationConfig
The size of the the TCP receive buffer associated with the socket used by the replica to transfer the replication stream.
REPLICA_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
REPLICA_TIMEOUT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
A heartbeat is exchanged between the feeder and replica to ensure they are alive.
ReplicaConsistencyException - Exception in com.sleepycat.je.rep
This exception is thrown by a Replica to indicate it could not meet the consistency requirements as defined by the ReplicaConsistencyPolicy in effect for the transaction, within the allowed timeout period.
ReplicaConsistencyException(ReplicaConsistencyPolicy, boolean) - Constructor for exception com.sleepycat.je.rep.ReplicaConsistencyException
 
ReplicaConsistencyException(String, ReplicaConsistencyPolicy) - Constructor for exception com.sleepycat.je.rep.ReplicaConsistencyException
 
ReplicaConsistencyPolicy - Interface in com.sleepycat.je
The interface for Consistency policies used to provide consistency guarantees at a Replica.
ReplicaFactory - Class in com.sleepycat.je.rep.impl.node
 
ReplicaFactory() - Constructor for class com.sleepycat.je.rep.impl.node.ReplicaFactory
 
ReplicaFactory.ReplicaType - Enum in com.sleepycat.je.rep.impl.node
 
ReplicaFeederHandshake - Class in com.sleepycat.je.rep.stream
Implements the Replica side of the handshake protocol between the Replica and the Feeder.
ReplicaFeederHandshake(RepNode, NamedChannel) - Constructor for class com.sleepycat.je.rep.stream.ReplicaFeederHandshake
An instance of this class is created with each new handshake preceding the setting up of a connection.
ReplicaFeederSyncup - Class in com.sleepycat.je.rep.stream
Establish where the replication stream should start for a replica and feeder pair.
ReplicaFeederSyncup(RepNode, Replay, NamedChannel, Protocol, boolean) - Constructor for class com.sleepycat.je.rep.stream.ReplicaFeederSyncup
 
ReplicaFeederSyncup.TestHook<T> - Interface in com.sleepycat.je.rep.stream
This interface is used instead of com.sleepycat.je.utilint.TestHook because the doHook method needs to throw InterruptedException.
replicaNodeName - Variable in class com.sleepycat.je.rep.impl.node.MasterTransfer.VLSNProgress
 
ReplicaStatDefinition - Class in com.sleepycat.je.rep.impl.node
Per-stat Metadata for HA Replica statistics.
ReplicaStatDefinition() - Constructor for class com.sleepycat.je.rep.impl.node.ReplicaStatDefinition
 
ReplicaStateException - Exception in com.sleepycat.je.rep
This exception indicates that the application attempted an operation that is not permitted when it is in the Replicator.State.Replica state.
ReplicaStateException(String) - Constructor for exception com.sleepycat.je.rep.ReplicaStateException
For internal use only.
ReplicaSyncupReader - Class in com.sleepycat.je.rep.stream
The ReplicaSyncupReader scans the log backwards for requested log entries.
ReplicaSyncupReader(EnvironmentImpl, VLSNIndex, long, int, NameIdPair, VLSN, long, MatchpointSearchResults) - Constructor for class com.sleepycat.je.rep.stream.ReplicaSyncupReader
 
ReplicatedDatabaseConfig - Class in com.sleepycat.je.dbi
This class contains all fields of the database configuration which are persistent.
ReplicatedDatabaseConfig() - Constructor for class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
For reading
ReplicatedDatabaseConfig(byte, int, byte[], byte[], byte[][]) - Constructor for class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
For writing
ReplicatedDatabaseTrigger - Interface in com.sleepycat.je.trigger
ReplicatedTrigger defines trigger methods that are invoked on a replica when a replica needs to resume a transaction that's only partially present in the replica's logs and needs to be resumed so that it can be replayed to a conclusion, that is, to the point where the partial transaction has been committed or aborted by the master.
ReplicatedEnvironment - Class in com.sleepycat.je.rep
A replicated database environment that is a node in a replication group.
ReplicatedEnvironment(File, ReplicationConfig, EnvironmentConfig, ReplicaConsistencyPolicy, QuorumPolicy) - Constructor for class com.sleepycat.je.rep.ReplicatedEnvironment
Creates a replicated environment handle and starts participating in the replication group as either a Master or a Replica.
ReplicatedEnvironment(File, ReplicationConfig, EnvironmentConfig) - Constructor for class com.sleepycat.je.rep.ReplicatedEnvironment
A convenience constructor that defaults the replica consistency policy and the initial election policy to be used.
ReplicatedEnvironment(File, ReplicationConfig, EnvironmentConfig, ReplicaConsistencyPolicy, QuorumPolicy, boolean, RepImpl) - Constructor for class com.sleepycat.je.rep.ReplicatedEnvironment
For internal use only.
ReplicatedEnvironment.State - Enum in com.sleepycat.je.rep
The replication node state determines the operations that the application can perform against its replicated environment.
ReplicatedEnvironmentStats - Class in com.sleepycat.je.rep
Statistics for a replicated environment.
ReplicatedEnvironmentStats(RepImpl, StatsConfig) - Constructor for class com.sleepycat.je.rep.ReplicatedEnvironmentStats
 
ReplicaThreadLocker - Class in com.sleepycat.je.rep.txn
A ReplicaThreadLocker is used with a user initiated non-transactional operation on a Replica.
ReplicaThreadLocker(RepImpl) - Constructor for class com.sleepycat.je.rep.txn.ReplicaThreadLocker
 
ReplicationConfig - Class in com.sleepycat.je.rep
Specifies the immutable attributes of a replicated environment.
ReplicationConfig() - Constructor for class com.sleepycat.je.rep.ReplicationConfig
Creates a ReplicationConfig initialized with the system default settings.
ReplicationConfig(String, String, String) - Constructor for class com.sleepycat.je.rep.ReplicationConfig
Creates a ReplicationConfig initialized with the system default settings and the specified group name, node name, and hostname/port values.
ReplicationConfig(Properties) - Constructor for class com.sleepycat.je.rep.ReplicationConfig
Creates a ReplicationConfig which includes the properties specified in the properties parameter.
ReplicationConfig(Properties, boolean) - Constructor for class com.sleepycat.je.rep.ReplicationConfig
Internal use only, from RepConfigManager.
ReplicationConfigBeanInfo - Class in com.sleepycat.je.rep
 
ReplicationConfigBeanInfo() - Constructor for class com.sleepycat.je.rep.ReplicationConfigBeanInfo
 
ReplicationContext - Class in com.sleepycat.je.log
ReplicationContext provides context about high-level operations so that the logging level can determine which replication related actions are required for a given Loggable item.
ReplicationContext(boolean) - Constructor for class com.sleepycat.je.log.ReplicationContext
 
ReplicationContext(VLSN) - Constructor for class com.sleepycat.je.log.ReplicationContext
Used to pass the VLSN held in an arriving message down to the logging levels.
ReplicationContext(VLSN, boolean) - Constructor for class com.sleepycat.je.log.ReplicationContext
Used to pass the VLSN held in a migrated LN down to the logging levels.
ReplicationFormatter - Class in com.sleepycat.je.rep.utilint
Formatter for replication log messages
ReplicationFormatter(NameIdPair) - Constructor for class com.sleepycat.je.rep.utilint.ReplicationFormatter
 
ReplicationGroup - Class in com.sleepycat.je.rep
An administrative view of the collection of nodes that form the replication group.
ReplicationGroup(RepGroupImpl) - Constructor for class com.sleepycat.je.rep.ReplicationGroup
 
ReplicationGroupAdmin - Class in com.sleepycat.je.rep.util
Administrative APIs for use by applications which do not have direct access to a replicated environment.
ReplicationGroupAdmin(String, Set<InetSocketAddress>) - Constructor for class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Constructs a group admin object.
ReplicationMutableConfig - Class in com.sleepycat.je.rep
Specifies the attributes that may be changed after a ReplicatedEnvironment has been created.
ReplicationMutableConfig() - Constructor for class com.sleepycat.je.rep.ReplicationMutableConfig
Create a ReplicationMutableConfig initialized with the system default settings.
ReplicationMutableConfig(Properties, boolean) - Constructor for class com.sleepycat.je.rep.ReplicationMutableConfig
Used by ReplicationConfig to support construction from a property file.
ReplicationMutableConfigBeanInfo - Class in com.sleepycat.je.rep
 
ReplicationMutableConfigBeanInfo() - Constructor for class com.sleepycat.je.rep.ReplicationMutableConfigBeanInfo
 
ReplicationNode - Interface in com.sleepycat.je.rep
An administrative view of a node in a replication group.
ReplicaWriteException - Exception in com.sleepycat.je.rep
This exception indicates that an update operation was attempted while in the ReplicatedEnvironment.State.REPLICA state.
ReplicaWriteException(Locker, StateChangeEvent) - Constructor for exception com.sleepycat.je.rep.ReplicaWriteException
For internal use only.
repMasterNodeId - Variable in class com.sleepycat.je.txn.TxnEnd
 
repNode - Variable in class com.sleepycat.je.rep.impl.GroupService
 
repNode() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Returns the RepNode associated with the FeederManager
RepNode - Class in com.sleepycat.je.rep.impl.node
Represents a replication node.
RepNode(RepImpl, Replay, NodeState) - Constructor for class com.sleepycat.je.rep.impl.node.RepNode
 
RepNode(NameIdPair) - Constructor for class com.sleepycat.je.rep.impl.node.RepNode
 
RepNode() - Constructor for class com.sleepycat.je.rep.impl.node.RepNode
 
RepNode(NameIdPair, ServiceDispatcher) - Constructor for class com.sleepycat.je.rep.impl.node.RepNode
 
RepNode.Clock - Class in com.sleepycat.je.rep.impl.node
 
RepNodeImpl - Class in com.sleepycat.je.rep.impl
Describes a node that is a member of the replication group.
RepNodeImpl(NameIdPair, NodeType, boolean, boolean, String, int, RepGroupImpl.BarrierState, int) - Constructor for class com.sleepycat.je.rep.impl.RepNodeImpl
 
RepNodeImpl(NameIdPair, NodeType, boolean, boolean, String, int, int) - Constructor for class com.sleepycat.je.rep.impl.RepNodeImpl
 
RepNodeImpl(NameIdPair, NodeType, String, int) - Constructor for class com.sleepycat.je.rep.impl.RepNodeImpl
 
RepNodeImpl(ReplicationConfig) - Constructor for class com.sleepycat.je.rep.impl.RepNodeImpl
 
RepNodeImpl(String, String, int) - Constructor for class com.sleepycat.je.rep.impl.RepNodeImpl
 
RepNodeImpl(Protocol.NodeGroupInfo) - Constructor for class com.sleepycat.je.rep.impl.RepNodeImpl
 
REPOS_EOF - Static variable in class com.sleepycat.collections.DataCursor
Repositioned failed, no records on or after the key/data pair given.
REPOS_EXACT - Static variable in class com.sleepycat.collections.DataCursor
Repositioned exactly to the key/data pair given.
REPOS_NEXT - Static variable in class com.sleepycat.collections.DataCursor
Repositioned on a record following the key/data pair given.
repositionExact(byte[], byte[], byte[], boolean) - Method in class com.sleepycat.collections.DataCursor
Repositions to a given raw key/data pair.
repositionRange(byte[], byte[], byte[], boolean) - Method in class com.sleepycat.collections.DataCursor
Repositions to a given raw key/data pair, or just past it if that record has been deleted.
RepParams - Class in com.sleepycat.je.rep.impl
 
RepParams() - Constructor for class com.sleepycat.je.rep.impl.RepParams
 
RepParams.IdentifierConfigParam - Class in com.sleepycat.je.rep.impl
A JE/HA configuration parameter describing an Identifier name.
RepParams.IdentifierConfigParam(String, String, boolean, boolean) - Constructor for class com.sleepycat.je.rep.impl.RepParams.IdentifierConfigParam
 
REPSTREAM_OPEN_TIMEOUT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
RepUtils - Class in com.sleepycat.je.rep.utilint
 
RepUtils() - Constructor for class com.sleepycat.je.rep.utilint.RepUtils
 
RepUtils.ConsistencyPolicyFormat<T extends ReplicaConsistencyPolicy> - Interface in com.sleepycat.je.rep.utilint
ReplicaConsistencyPolicy must be stored as a String for use with ReplicationConfig and je.properties.
RepUtils.ExceptionAwareBlockingQueue<T> - Class in com.sleepycat.je.rep.utilint
Like LinkedBlockingQueue, but provides a pollOrException() method that should be used instead of poll(), so that callers don't have to treat exception cases specially.
RepUtils.ExceptionAwareBlockingQueue(EnvironmentImpl, T) - Constructor for class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareBlockingQueue
 
RepUtils.ExceptionAwareCountDownLatch - Class in com.sleepycat.je.rep.utilint
Like CountDownLatch, but makes provision in the await for the await, or more specifically the new awaitOrException method to be exited via an exception.
RepUtils.ExceptionAwareCountDownLatch(EnvironmentImpl, int) - Constructor for class com.sleepycat.je.rep.utilint.RepUtils.ExceptionAwareCountDownLatch
 
requestDispatch(SocketChannel) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingService
 
requestDispatch(SocketChannel) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.LazyQueuingService
 
requestDispatch(SocketChannel) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.QueuingService
 
requestShutdown() - Method in class com.sleepycat.je.cleaner.Cleaner
 
requestShutdown() - Method in interface com.sleepycat.je.utilint.DaemonRunner
 
requestShutdown() - Method in class com.sleepycat.je.utilint.DaemonThread
 
requestShutdownDaemons() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
requestShutdownPool() - Method in class com.sleepycat.je.evictor.Evictor
 
RESERVED - Static variable in class com.sleepycat.asm.MethodWriter
Reserved for future use
reset() - Method in class com.sleepycat.je.cleaner.FileSummary
Reset all totals to zero.
reset() - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Overrides reset for a tracked file, and is called when a FileSummaryLN is written to the log.
reset() - Method in class com.sleepycat.je.dbi.CursorImpl
Reset a cursor to an uninitialized state, but unlike close(), allow it to be used further.
reset(long, boolean, DbConfigManager) - Method in class com.sleepycat.je.dbi.MemoryBudget
Initialize at construction time and when the cache is resized.
reset() - Method in class com.sleepycat.je.log.ChecksumValidator
 
reset(DbConfigManager) - Method in class com.sleepycat.je.log.LogBufferPool
Initialize the pool at construction time and when the cache is resized.
reset() - Method in class com.sleepycat.je.recovery.DirtyINMap
Must be called after a checkpoint or Database.sync is complete.
reset() - Method in class com.sleepycat.je.rep.util.DbResetRepGroup
Replaces the existing group with the new group having a single new node as described by the constructor arguments.
reset() - Method in class com.sleepycat.je.tree.TreeLocation
 
reset() - Method in class com.sleepycat.je.utilint.Adler32
Reset Adler-32 checksum to initial value.
reset() - Method in class com.sleepycat.util.FastInputStream
 
reset() - Method in class com.sleepycat.util.FastOutputStream
 
RESET_REP_GROUP - Static variable in class com.sleepycat.je.rep.impl.RepParams
An internal option, accessed only via the utility DbResetRepGroup utility, to reset a replication group to a single new member when the replicated environment is opened.
resetAndGetMemorySize() - Method in class com.sleepycat.je.tree.IN
Called as part of a memory budget reset (during a checkpoint) to clear the accumulated delta and return the total memory size.
resetConfigManager(EnvironmentConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Make a new config manager that has all the properties needed.
resetConfigManager(EnvironmentConfig) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
resetDbInfo(DatabaseId) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Clears all accmulated utilization info for the given database.
resetFile(TrackedFileSummary) - Method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Called after the FileSummaryLN is written to the log during checkpoint.
resetFileInfo(long) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Clears all accmulated utilization info for the given file.
resetLoggingLevel(String, Level) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Reset the logging level for specified loggers in a JE environment.
resetLoggingParams - Static variable in class com.sleepycat.je.jmx.JEDiagnostics
 
resetMBeanInfo() - Method in class com.sleepycat.je.jmx.JEMBean
Create the available management interface for this environment.
resetPerRunCounters() - Method in class com.sleepycat.je.recovery.Checkpointer.FlushStats
 
resetPool(DbConfigManager) - Method in class com.sleepycat.je.log.LogManager
Reset the pool when the cache is resized.
resetReadyLatch(Exception) - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
resetRequiredAckCount() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
resetStats() - Method in class com.sleepycat.je.rep.impl.node.Feeder
 
resetStats() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
resetStats() - Method in class com.sleepycat.je.rep.impl.node.Replay
 
resetStats() - Method in class com.sleepycat.je.rep.impl.node.Replica
 
resetStats() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
resetStats() - Method in class com.sleepycat.je.rep.stream.FeederTxns
 
resetStats() - Method in class com.sleepycat.je.rep.stream.VLSNReader
 
resetStats() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
RESIZE - Static variable in class com.sleepycat.asm.ClassReader
True to enable JSR_W and GOTO_W support.
RESIZED - Static variable in class com.sleepycat.asm.Label
Indicates if this label has been updated, after instruction resizing.
resolve(MethodWriter, int, byte[]) - Method in class com.sleepycat.asm.Label
Resolves all forward references to this label.
resolveClass(String) - Method in interface com.sleepycat.persist.impl.Catalog
 
resolveClass(String) - Method in class com.sleepycat.persist.impl.PersistCatalog
 
resolveClass(String) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
resolveClass(String, ClassLoader) - Static method in class com.sleepycat.persist.impl.SimpleCatalog
 
resolveClass(String) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
resolveClass(String) - Method in class com.sleepycat.persist.model.EntityModel
Should be called by entity model implementations instead of calling Class.forName whenever loading an application class.
resolveClass(String, ClassLoader) - Static method in class com.sleepycat.util.ClassResolver
A specialized Class.forName method that supports use of a user-specified ClassLoader.
resolveClass(ObjectStreamClass) - Method in class com.sleepycat.util.ClassResolver.Stream
 
RESOLVED - Static variable in class com.sleepycat.asm.Label
Indicates if the position of this label is known.
resolveKeyClass(String) - Method in interface com.sleepycat.persist.impl.Catalog
 
resolveKeyClass(String) - Method in class com.sleepycat.persist.impl.PersistCatalog
 
resolveKeyClass(String) - Method in class com.sleepycat.persist.impl.ReadOnlyCatalog
 
resolveKeyClass(String, ClassLoader) - Static method in class com.sleepycat.persist.impl.SimpleCatalog
 
resolveKeyClass(String) - Method in class com.sleepycat.persist.impl.SimpleCatalog
 
resolvePartialEntry(DatabaseEntry, byte[]) - Static method in class com.sleepycat.je.tree.LN
Merges the partial entry with the given byte array, effectively applying a partial entry to an existing record, and returns a enw byte array.
response - Variable in exception com.sleepycat.je.rep.utilint.ServiceDispatcher.ServiceConnectFailedException
 
RESTART - Static variable in class com.sleepycat.je.txn.LockConflict
 
RESTART - Static variable in class com.sleepycat.je.txn.LockType
RESTART is used for waiting for a restart and does not appear in the conflict or upgrade matrices.
restartNetworkBackup() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Restarts the network backup service *after* a rollback has been completed and the log files are once again in a consistent state.
RestartRequiredException - Exception in com.sleepycat.je.rep
RestartRequiredException serves as the base class for all exceptions which makes it impossible for HA to proceed without some form of corrective action on the part of the user, followed by a restart of the application.
RestartRequiredException(EnvironmentImpl, EnvironmentFailureReason) - Constructor for exception com.sleepycat.je.rep.RestartRequiredException
 
RestartRequiredException(EnvironmentImpl, EnvironmentFailureReason, Exception) - Constructor for exception com.sleepycat.je.rep.RestartRequiredException
 
RestartRequiredException(String, RestartRequiredException) - Constructor for exception com.sleepycat.je.rep.RestartRequiredException
For internal use only.
RESTORE_REQUEST - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
RESTORE_RESPONSE - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
restoreLastPosition() - Method in class com.sleepycat.je.log.FileManager
 
RESULT - Variable in class com.sleepycat.je.rep.elections.Protocol
 
resyncReader(long, boolean) - Method in class com.sleepycat.je.log.FileReader
 
resyncReader(long, boolean) - Method in class com.sleepycat.je.log.ScavengerFileReader
 
RET - Static variable in class com.sleepycat.asm.Label
Indicates if this basic block ends with a RET instruction.
RET - Static variable in interface com.sleepycat.asm.Opcodes
 
retainAll(Collection<?>) - Method in class com.sleepycat.collections.StoredCollection
Retains only the elements in this collection that are contained in the specified collection (optional operation).
retries() - Method in class com.sleepycat.je.rep.elections.Elections.RetryPredicate
The number of times a retry was attempted
retries() - Method in interface com.sleepycat.je.rep.elections.Proposer.RetryPredicate
 
retries - Variable in exception com.sleepycat.je.rep.impl.node.Replica.RetryException
 
retrieveNext(DatabaseEntry, DatabaseEntry, LockMode, GetMode) - Method in class com.sleepycat.je.Cursor
Retrieves the next or previous record.
retrieveNext(Cursor, DatabaseEntry, DatabaseEntry, LockMode, GetMode) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.retrieveNext().
retrieveNext(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode, GetMode) - Method in class com.sleepycat.je.SecondaryCursor
Calls retrieveNext() and retrieves primary data.
retry() - Method in class com.sleepycat.je.rep.elections.Elections.RetryPredicate
Implements the protocol
retry() - Method in interface com.sleepycat.je.rep.elections.Proposer.RetryPredicate
 
retrySleepMs - Variable in exception com.sleepycat.je.rep.impl.node.Replica.RetryException
 
RETURN - Static variable in interface com.sleepycat.asm.Opcodes
 
returnedTheObject - Variable in class com.sleepycat.je.utilint.TinyHashSet.SingleElementIterator
 
returnValue(OperationStatus) - Method in class com.sleepycat.persist.BasicCursor
 
revertKnownDeleted - Variable in class com.sleepycat.je.txn.TxnChain.RevertInfo
 
revertLsn - Variable in class com.sleepycat.je.txn.TxnChain.RevertInfo
 
revertToNull() - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
 
rewriteMapTreeRoot(long) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Force a rewrite of the map tree root if required.
RGFAIL_RESP - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
RIGHT - Static variable in class com.sleepycat.je.tree.Tree.SearchType
 
rollback() - Method in class com.sleepycat.je.jca.ra.JELocalTransaction
 
rollback(Long, LNFileReader, RecoveryUtilizationTracker) - Method in class com.sleepycat.je.recovery.RollbackTracker.Scanner
Rollback the filereader's current LN_TX.
rollback(VLSN, long) - Method in class com.sleepycat.je.rep.impl.node.Replay
Go through all active txns and rollback up to but not including the log entry represented by the matchpoint VLSN.
rollback(long) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
Rollback all write operations that are logged with an LSN > the matchpointLsn parameter.
rollback(Xid) - Method in class com.sleepycat.je.XAEnvironment
 
RollbackEnd - Class in com.sleepycat.je.txn
This class indicates the end of a partial rollback at syncup.
RollbackEnd(long, long) - Constructor for class com.sleepycat.je.txn.RollbackEnd
 
RollbackEnd() - Constructor for class com.sleepycat.je.txn.RollbackEnd
For constructing from the log.
RollbackException - Exception in com.sleepycat.je.rep
This asynchronous exception indicates that a new master has been selected, this Replica's log is ahead of the current Master, and in this case, the Replica was unable to rollback without a recovery.
RollbackException(RepImpl, VLSN, VLSN, MatchpointSearchResults) - Constructor for exception com.sleepycat.je.rep.RollbackException
For internal use only.
RollbackException(String, RollbackException) - Constructor for exception com.sleepycat.je.rep.RollbackException
For internal use only.
RollbackProhibitedException - Exception in com.sleepycat.je.rep
This exception may be thrown by a Replica during the replication stream sync-up phase of startup.
RollbackProhibitedException(RepImpl, int, VLSN, MatchpointSearchResults) - Constructor for exception com.sleepycat.je.rep.RollbackProhibitedException
For internal use only.
RollbackProhibitedException(String, RollbackProhibitedException) - Constructor for exception com.sleepycat.je.rep.RollbackProhibitedException
For internal use only.
RollbackStart - Class in com.sleepycat.je.txn
This class indicates the end of a partial rollback at syncup.
RollbackStart(VLSN, long, Set<Long>) - Constructor for class com.sleepycat.je.txn.RollbackStart
 
RollbackStart() - Constructor for class com.sleepycat.je.txn.RollbackStart
For constructing from the log.
RollbackTracker - Class in com.sleepycat.je.recovery
RollbackTracker is used to detect rollback periods in the log that are the result of HA replica syncups.
RollbackTracker(EnvironmentImpl) - Constructor for class com.sleepycat.je.recovery.RollbackTracker
 
RollbackTracker.BackwardScanner - Class in com.sleepycat.je.recovery
In a backward scanner, the currentPeriod field is always pointing to the period that contains this lsn.
RollbackTracker.BackwardScanner() - Constructor for class com.sleepycat.je.recovery.RollbackTracker.BackwardScanner
 
RollbackTracker.RollbackPeriod - Class in com.sleepycat.je.recovery
A RollbackPeriod describes a section of the log that is logically truncated.
RollbackTracker.RollbackPeriod(RollbackTracker, RollbackEnd, long) - Constructor for class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
RollbackTracker.RollbackPeriod(RollbackTracker, RollbackStart, long) - Constructor for class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
RollbackTracker.RollbackPeriod(long, long, long, long) - Constructor for class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
RollbackTracker.Scanner - Class in com.sleepycat.je.recovery
A Scanner is to process LNs during a recovery pass.
RollbackTracker.Scanner() - Constructor for class com.sleepycat.je.recovery.RollbackTracker.Scanner
 
RollbackTracker.UnderConstructionScanner - Class in com.sleepycat.je.recovery
 
RollbackTracker.UnderConstructionScanner() - Constructor for class com.sleepycat.je.recovery.RollbackTracker.UnderConstructionScanner
 
rollbackUndo(Logger, Level, UndoReader, TxnChain.RevertInfo, TreeLocation, long) - Static method in class com.sleepycat.je.recovery.RecoveryManager
 
rollup(Latency) - Method in class com.sleepycat.utilint.Latency
Add the measurements from "other" and recalculate the min, max, and average values.
rollup(LatencyStat) - Method in class com.sleepycat.utilint.LatencyStat
Add the measurement in "other" to the measurements held here, in order to generate min, max, avg, 95th, 99th percentile for two Latency Stats.
rollWindow() - Method in class com.sleepycat.je.rep.util.ldiff.Window
Roll a window forward by one key.
rootExists() - Method in class com.sleepycat.je.tree.Tree
 
run(TransactionWorker) - Method in class com.sleepycat.collections.TransactionRunner
Calls the TransactionWorker.doWork() method and, for transactional environments, may begin and end a transaction.
run() - Method in class com.sleepycat.je.dbi.TriggerManager.MapOver
 
run(S) - Method in class com.sleepycat.je.dbi.TriggerManager.MapOver
 
run() - Method in class com.sleepycat.je.evictor.Evictor.BackgroundEvictTask
 
run() - Method in class com.sleepycat.je.rep.elections.Acceptor
The Acceptor thread body.
run() - Method in class com.sleepycat.je.rep.elections.Learner
The main Learner loop.
run() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateService.NodeStateServiceRunnable
 
run() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager.Lease
 
run() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
The dispatcher method that starts up new log file feeders.
run() - Method in class com.sleepycat.je.rep.impl.networkRestore.LogFileFeeder
The main driver loop that enforces the protocol message sequence and implements it.
run() - Method in class com.sleepycat.je.rep.impl.node.ChannelTimeoutTask
Runs once a second checking to see if a channel is still active.
run() - Method in class com.sleepycat.je.rep.impl.node.LogFlusher.LogFlushTask
Check the RepNode.currentCommitVLSN difference to see if there is any dirty data between two actions.
run() - Method in class com.sleepycat.je.rep.impl.node.Replica.ReplayThread
 
run() - Method in class com.sleepycat.je.rep.impl.node.RepNode
The top level Master/Feeder or Replica loop in support of replication.
run() - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
 
run() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffService.LDiffServiceRunnable
 
run() - Method in class com.sleepycat.je.rep.utilint.DbDumpGroup
 
run() - Method in class com.sleepycat.je.rep.utilint.DbStreamVerify
 
run() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingRunnable
 
run() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
The central run method.
run() - Method in class com.sleepycat.je.utilint.DaemonThread
 
RUN_LOG_FLUSH_TASK - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
RUN_LOG_FLUSH_TASK - Static variable in class com.sleepycat.je.rep.ReplicationMutableConfig
If true, JE HA (replication) will flush all committed transactions to disk at the specified time interval.
runAbortTriggers(Txn) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with the abort of a transaction.
runCloseTriggers(Locker, DatabaseImpl) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with the closing of a database.
runCommitTriggers(Txn) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with the commit of a transaction.
runDeleteTriggers(Locker, DatabaseImpl, DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with a delete operation.
runEnvDiff(Protocol.EnvDiff, Protocol) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffService.LDiffServiceRunnable
 
runFeeders() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
The core feeder listener loop that is run either in a Master node, or in a Replica that is serving as a Feeder to other Replica nodes.
runLDiff(Protocol.DbBlocks, Protocol) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffService.LDiffServiceRunnable
 
runOpenTriggers(Locker, Database, boolean) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with the opening of a database.
runOpenTriggers(Locker, DatabaseImpl, boolean) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with the opening of a database.
runOrPause(boolean) - Method in class com.sleepycat.je.cleaner.Cleaner
 
runOrPause(boolean) - Method in interface com.sleepycat.je.utilint.DaemonRunner
 
runOrPause(boolean) - Method in class com.sleepycat.je.utilint.DaemonThread
If run is true, starts the thread if not started or unpauses it if already started; if run is false, pauses the thread if started or does nothing if not started.
runPutTriggers(Locker, DatabaseImpl, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with a put operation.
RunRecoveryException - Exception in com.sleepycat.je
RunRecoveryException(String) - Constructor for exception com.sleepycat.je.RunRecoveryException
Deprecated.
For internal use only.
RunRecoveryException(String, Throwable) - Constructor for exception com.sleepycat.je.RunRecoveryException
Deprecated.
For internal use only.
runRemoveTriggers(Locker, DatabaseImpl) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with the removal of a database.
runRenameTriggers(Locker, DatabaseImpl, String) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with the renaming of a database.
runReplicaLoop() - Method in class com.sleepycat.je.rep.impl.node.Replica
The core control loop when the node is serving as a Replica.
RuntimeExceptionWrapper - Exception in com.sleepycat.util
A RuntimeException that can contain nested exceptions.
RuntimeExceptionWrapper(Throwable) - Constructor for exception com.sleepycat.util.RuntimeExceptionWrapper
 
runTruncateTriggers(Locker, DatabaseImpl) - Static method in class com.sleepycat.je.dbi.TriggerManager
Invokes the trigger methods associated with the truncation of a database.

S

s - Variable in class com.sleepycat.je.rep.impl.TextProtocol.StringFormatable
 
SALOAD - Static variable in interface com.sleepycat.asm.Opcodes
 
SAME_FRAME - Static variable in class com.sleepycat.asm.MethodWriter
Frame has exactly the same locals as the previous stack map frame and number of stack items is zero.
SAME_FRAME_EXTENDED - Static variable in class com.sleepycat.asm.MethodWriter
Frame has exactly the same locals as the previous stack map frame and number of stack items is zero.
SAME_LOCALS_1_STACK_ITEM_FRAME - Static variable in class com.sleepycat.asm.MethodWriter
Frame has exactly the same locals as the previous stack map frame and number of stack items is 1
SAME_LOCALS_1_STACK_ITEM_FRAME_EXTENDED - Static variable in class com.sleepycat.asm.MethodWriter
Frame has exactly the same locals as the previous stack map frame and number of stack items is 1.
SASTORE - Static variable in interface com.sleepycat.asm.Opcodes
 
SAVED_EFE - Variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
saveLastLoggedFileSummaryLN(long, long) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Saves the LSN of the last logged FileSummaryLN.
saveLastLoggedMapLN(DatabaseId, long) - Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
Saves the LSN of the last logged MapLN.
saveLastPosition() - Method in class com.sleepycat.je.log.FileManager
 
saveShutdownException(Exception) - Method in class com.sleepycat.je.utilint.StoppableThread
 
SBYTE_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of instructions with an signed byte argument.
scanBackwards(VLSN) - Method in class com.sleepycat.je.rep.stream.FeederSyncupReader
Backward scanning for records for the feeder's part in syncup.
scanBackwards(VLSN) - Method in class com.sleepycat.je.rep.stream.ReplicaSyncupReader
Backward scanning for the replica's part in syncup.
scanForwards(VLSN, int) - Method in class com.sleepycat.je.rep.stream.FeederReader
Forward scanning for feeding the replica: get the log record for this VLSN.
ScavengerFileReader - Class in com.sleepycat.je.log
A ScavengerFileReader reads the log backwards.
ScavengerFileReader(EnvironmentImpl, int, long, long, long) - Constructor for class com.sleepycat.je.log.ScavengerFileReader
Create this reader to start at a given LSN.
search(DatabaseEntry, DatabaseEntry, LockMode, CursorImpl.SearchMode) - Method in class com.sleepycat.je.Cursor
Performs search by key, data, or both.
search(Cursor, DatabaseEntry, DatabaseEntry, LockMode, CursorImpl.SearchMode) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.search().
search(DatabaseEntry, DatabaseEntry, DatabaseEntry, LockMode, CursorImpl.SearchMode) - Method in class com.sleepycat.je.SecondaryCursor
Calls search() and retrieves primary data.
search(byte[], Tree.SearchType, BINBoundary, CacheMode, Comparator<byte[]>) - Method in class com.sleepycat.je.tree.Tree
Search the tree, starting at the root.
searchAndPosition(DatabaseEntry, CursorImpl.SearchMode, LockType) - Method in class com.sleepycat.je.dbi.CursorImpl
 
searchAndPosition(DatabaseEntry, CursorImpl.SearchMode, LockType, Comparator<byte[]>) - Method in class com.sleepycat.je.dbi.CursorImpl
Position the cursor at the key.
searchDeletableSubTree(IN, byte[], ArrayList<Tree.SplitInfo>) - Method in class com.sleepycat.je.tree.Tree
Search down the tree using a key, but instead of returning the BIN that houses that key, find the point where we can detach a deletable subtree.
SearchFileReader - Class in com.sleepycat.je.log
SearchFileReader searches for the a given entry type.
SearchFileReader(EnvironmentImpl, int, boolean, long, long, LogEntryType) - Constructor for class com.sleepycat.je.log.SearchFileReader
Create this reader to start at a given LSN.
searchForBIN(DatabaseImpl, BINReference) - Method in class com.sleepycat.je.incomp.INCompressor
Search the tree for the BIN that corresponds to this BINReference.
searchForReplay(DatabaseEntry, DatabaseEntry, LockMode, CursorImpl.SearchMode) - Method in class com.sleepycat.je.Cursor
Version of search that does not interpret duplicates.
searchForReplay(Cursor, DatabaseEntry, DatabaseEntry, LockMode, CursorImpl.SearchMode) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.searchForReplay().
SearchResult - Class in com.sleepycat.je.tree
Contains the result of a tree search
SearchResult() - Constructor for class com.sleepycat.je.tree.SearchResult
 
searchSplitsAllowed(byte[], CacheMode, Comparator<byte[]>) - Method in class com.sleepycat.je.tree.Tree
Do a key based search, permitting pre-emptive splits.
secDb - Variable in class com.sleepycat.collections.DataView
 
secKeyCreator - Variable in class com.sleepycat.collections.DataView
 
SECONDARIES - Static variable in class com.sleepycat.compat.DbCompat
 
SecondaryConfig - Class in com.sleepycat.je
The configuration properties of a SecondaryDatabase extend those of a primary Database.
SecondaryConfig() - Constructor for class com.sleepycat.je.SecondaryConfig
Creates an instance with the system's default settings.
SecondaryConfigBeanInfo - Class in com.sleepycat.je
 
SecondaryConfigBeanInfo() - Constructor for class com.sleepycat.je.SecondaryConfigBeanInfo
 
SecondaryConstraintException - Exception in com.sleepycat.je
Base class for exceptions thrown when a write operation fails because of a secondary constraint.
SecondaryConstraintException(Locker, String, String, DatabaseEntry, DatabaseEntry) - Constructor for exception com.sleepycat.je.SecondaryConstraintException
For internal use only.
SecondaryConstraintException(String, SecondaryReferenceException) - Constructor for exception com.sleepycat.je.SecondaryConstraintException
For internal use only.
SecondaryCursor - Class in com.sleepycat.je
A database cursor for a secondary database.
SecondaryCursor(SecondaryDatabase, Transaction, CursorConfig) - Constructor for class com.sleepycat.je.SecondaryCursor
Cursor constructor.
SecondaryCursor(SecondaryDatabase, Locker, CursorConfig) - Constructor for class com.sleepycat.je.SecondaryCursor
Cursor constructor.
SecondaryDatabase - Class in com.sleepycat.je
A secondary database handle.
SecondaryDatabase(Environment, SecondaryConfig, Database) - Constructor for class com.sleepycat.je.SecondaryDatabase
Creates a secondary database but does not open or fully initialize it.
SecondaryIndex<SK,PK,E> - Class in com.sleepycat.persist
The secondary index for an entity class and a secondary key.
SecondaryIndex(SecondaryDatabase, Database, PrimaryIndex<PK, E>, Class<SK>, EntryBinding<SK>) - Constructor for class com.sleepycat.persist.SecondaryIndex
Creates a secondary index without using an EntityStore.
SecondaryIntegrityException - Exception in com.sleepycat.je
Thrown when an integrity problem is detected while accessing a secondary database, including access to secondaries while writing to a primary database.
SecondaryIntegrityException(Locker, String, String, DatabaseEntry, DatabaseEntry) - Constructor for exception com.sleepycat.je.SecondaryIntegrityException
For internal use only.
SecondaryKey - Annotation Type in com.sleepycat.persist.model
Indicates a secondary key field of an entity class.
SecondaryKeyCreator - Interface in com.sleepycat.je
The interface implemented for extracting single-valued secondary keys from primary records.
SecondaryKeyMetadata - Class in com.sleepycat.persist.model
The metadata for a secondary key field.
SecondaryKeyMetadata(String, String, String, String, String, Relationship, String, DeleteAction) - Constructor for class com.sleepycat.persist.model.SecondaryKeyMetadata
Used by an EntityModel to construct secondary key metadata.
SecondaryMultiKeyCreator - Interface in com.sleepycat.je
The interface implemented for extracting multi-valued secondary keys from primary records.
SecondaryReferenceException - Exception in com.sleepycat.je
Base class for exceptions thrown when a read or write operation fails because of a secondary constraint or integrity problem.
SecondaryReferenceException(Locker, String, String, DatabaseEntry, DatabaseEntry) - Constructor for exception com.sleepycat.je.SecondaryReferenceException
For internal use only.
SecondaryReferenceException(String, SecondaryReferenceException) - Constructor for exception com.sleepycat.je.SecondaryReferenceException
For internal use only.
secondaryRefersToMissingPrimaryKey(Locker, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.Database
Creates a SecondaryIntegrityException using the information given.
SecondaryTrigger - Class in com.sleepycat.je
 
SecondaryTrigger(SecondaryDatabase) - Constructor for class com.sleepycat.je.SecondaryTrigger
 
SEGMENT_CAPACITY - Static variable in class com.sleepycat.je.cleaner.OffsetList
 
selectDirtyINsForCheckpoint() - Method in class com.sleepycat.je.recovery.DirtyINMap
Scan the INList for all dirty INs, excluding temp DB INs.
selectDirtyINsForDbSync(DatabaseImpl) - Method in class com.sleepycat.je.recovery.DirtyINMap
Scan the INList for all dirty INs for a given database.
selectFileForCleaning(UtilizationCalculator, SortedMap<Long, FileSummary>, boolean, boolean, int) - Method in class com.sleepycat.je.cleaner.FileSelector
Returns the best file that qualifies for cleaning, or null if no file qualifies.
selectFileForCorrection(UtilizationCalculator, SortedMap<Long, FileSummary>) - Method in class com.sleepycat.je.cleaner.FileSelector
Returns the best file for correcting utilization, or null if correction is not needed.
selectIN(int) - Method in class com.sleepycat.je.evictor.TargetSelector
Select a single node to evict.
selectKey(K) - Method in interface com.sleepycat.persist.KeySelector
Returns whether a given key should be returned via the cursor.
sendConnectionEvent(ConnectionEvent) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
sendVersion - Variable in class com.sleepycat.je.rep.impl.TextProtocol.Message
 
SEPARATE_DATABASE_FILES - Static variable in class com.sleepycat.compat.DbCompat
 
SEPARATOR - Static variable in class com.sleepycat.je.rep.impl.TextProtocol
 
SEPARATOR - Static variable in class com.sleepycat.je.rep.utilint.HostPortPair
 
SEPARATOR_REGEXP - Static variable in class com.sleepycat.je.rep.impl.TextProtocol
 
Sequence - Class in com.sleepycat.je
A Sequence handle is used to manipulate a sequence record in a database.
Sequence(Database, Transaction, DatabaseEntry, SequenceConfig) - Constructor for class com.sleepycat.je.Sequence
Opens a sequence handle, adding the sequence record if appropriate.
SEQUENCE_CACHE_LAST - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
SEQUENCE_CACHE_SIZE - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
SEQUENCE_CACHE_VALUE - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
SEQUENCE_CACHED_GETS - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
SEQUENCE_GETS - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
SEQUENCE_RANGE_MAX - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
SEQUENCE_RANGE_MIN - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
SEQUENCE_STORED_VALUE - Static variable in class com.sleepycat.je.dbi.SequenceStatDefinition
 
SequenceConfig - Class in com.sleepycat.je
Specifies the attributes of a sequence.
SequenceConfig() - Constructor for class com.sleepycat.je.SequenceConfig
An instance created using the default constructor is initialized with the system's default settings.
SequenceConfigBeanInfo - Class in com.sleepycat.je
 
SequenceConfigBeanInfo() - Constructor for class com.sleepycat.je.SequenceConfigBeanInfo
 
SequenceExistsException - Exception in com.sleepycat.je
Thrown by Database.openSequence if the sequence record already exists and the SequenceConfig ExclusiveCreate parameter is true.
SequenceExistsException(String) - Constructor for exception com.sleepycat.je.SequenceExistsException
For internal use only.
SequenceIntegrityException - Exception in com.sleepycat.je
Thrown by Sequence.get if the sequence record has been deleted.
SequenceIntegrityException(String) - Constructor for exception com.sleepycat.je.SequenceIntegrityException
For internal use only.
SequenceNotFoundException - Exception in com.sleepycat.je
Thrown by Database.openSequence if the sequence record does not exist and the SequenceConfig AllowCreate parameter is false.
SequenceNotFoundException(String) - Constructor for exception com.sleepycat.je.SequenceNotFoundException
For internal use only.
SequenceOverflowException - Exception in com.sleepycat.je
Thrown by Sequence.get if the end of the sequence is reached and wrapping is not configured.
SequenceOverflowException(String) - Constructor for exception com.sleepycat.je.SequenceOverflowException
For internal use only.
SequenceStatDefinition - Class in com.sleepycat.je.dbi
Per-stat Metadata for JE sequence statistics.
SequenceStatDefinition() - Constructor for class com.sleepycat.je.dbi.SequenceStatDefinition
 
SequenceStats - Class in com.sleepycat.je
A SequenceStats object is used to return sequence statistics.
SequenceStats(StatGroup) - Constructor for class com.sleepycat.je.SequenceStats
 
SerialBase - Class in com.sleepycat.bind.serial
A base class for serial bindings creators that provides control over the allocation of the output buffer.
SerialBase() - Constructor for class com.sleepycat.bind.serial.SerialBase
Initializes the initial output buffer size to zero.
SerialBinding<E> - Class in com.sleepycat.bind.serial
A concrete EntryBinding that treats a key or data entry as a serialized object.
SerialBinding(ClassCatalog, Class<E>) - Constructor for class com.sleepycat.bind.serial.SerialBinding
Creates a serial binding.
SerialInput - Class in com.sleepycat.bind.serial
A specialized ObjectInputStream that gets class description information from a ClassCatalog.
SerialInput(InputStream, ClassCatalog) - Constructor for class com.sleepycat.bind.serial.SerialInput
Creates a serial input stream.
SerialInput(InputStream, ClassCatalog, ClassLoader) - Constructor for class com.sleepycat.bind.serial.SerialInput
Creates a serial input stream.
serialize(ByteBuffer, BinaryProtocol) - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
Serializes into a ByteBuffer for a given protocol.
serialize(TupleOutput) - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
Serializes into a TupleOutput before storing.
serializeBytes(RepNodeImpl) - Static method in class com.sleepycat.je.rep.impl.RepGroupImpl
Serialize the node into its byte representation.
serializedSize(BinaryProtocol) - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
Returns serialized for a given protocol.
serializeHex() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns a serialized character based form of the group suitable for use in subclasses of SimpleProtocol.
serializeHex(RepNodeImpl) - Static method in class com.sleepycat.je.rep.impl.RepGroupImpl
Returns the serialized form of the node as a sequence of hex characters suitable for use by the text based protocols.
serialLog(LogItem[], LogContext) - Method in class com.sleepycat.je.log.LogManager
Log one or more items while latched or synchronized in order to serialize log output.
serialLog(LogItem[], LogContext) - Method in class com.sleepycat.je.log.SyncedLogManager
 
serialLogInternal(LogItem[], LogContext) - Method in class com.sleepycat.je.log.LogManager
Called within the log write critical section.
SerialOutput - Class in com.sleepycat.bind.serial
A specialized ObjectOutputStream that stores class description information in a ClassCatalog.
SerialOutput(OutputStream, ClassCatalog) - Constructor for class com.sleepycat.bind.serial.SerialOutput
Creates a serial output stream.
SerialSerialBinding<K,D,E> - Class in com.sleepycat.bind.serial
An abstract EntityBinding that treats an entity's key entry and data entry as serialized objects.
SerialSerialBinding(ClassCatalog, Class<K>, Class<D>) - Constructor for class com.sleepycat.bind.serial.SerialSerialBinding
Creates a serial-serial entity binding.
SerialSerialBinding(SerialBinding<K>, SerialBinding<D>) - Constructor for class com.sleepycat.bind.serial.SerialSerialBinding
Creates a serial-serial entity binding.
SerialSerialKeyCreator<PK,D,SK> - Class in com.sleepycat.bind.serial
A abstract key creator that uses a serial key and a serial data entry.
SerialSerialKeyCreator(ClassCatalog, Class<PK>, Class<D>, Class<SK>) - Constructor for class com.sleepycat.bind.serial.SerialSerialKeyCreator
Creates a serial-serial key creator.
SerialSerialKeyCreator(SerialBinding<PK>, SerialBinding<D>, SerialBinding<SK>) - Constructor for class com.sleepycat.bind.serial.SerialSerialKeyCreator
Creates a serial-serial entity binding.
serialVersionUID - Static variable in class com.sleepycat.je.utilint.Timestamp
 
server - Variable in class com.sleepycat.je.jmx.JEMBean
 
SERVER_VERSION - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
serverLoadThreshold - Variable in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackup
 
SERVICE_NAME - Static variable in class com.sleepycat.je.rep.elections.Acceptor
 
SERVICE_NAME - Static variable in class com.sleepycat.je.rep.elections.Learner
 
SERVICE_NAME - Static variable in class com.sleepycat.je.rep.impl.BinaryNodeStateService
 
SERVICE_NAME - Static variable in class com.sleepycat.je.rep.impl.GroupService
 
SERVICE_NAME - Static variable in class com.sleepycat.je.rep.impl.NodeStateService
 
SERVICE_NAME - Static variable in class com.sleepycat.je.rep.monitor.MonitorService
 
serviceDispatcher - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
ServiceDispatcher - Class in com.sleepycat.je.rep.utilint
ServiceDispatcher listens on a specific socket for service requests and dispatches control to the service that is being requested.
ServiceDispatcher(InetSocketAddress, RepImpl) - Constructor for class com.sleepycat.je.rep.utilint.ServiceDispatcher
Create a ServiceDispatcher listening on a specific socket for service requests.
ServiceDispatcher(InetSocketAddress) - Constructor for class com.sleepycat.je.rep.utilint.ServiceDispatcher
Convenience overloading for when the dispatcher is created without a replicated environment, e.g.
ServiceDispatcher.ExecutingRunnable - Class in com.sleepycat.je.rep.utilint
 
ServiceDispatcher.ExecutingRunnable(SocketChannel, TextProtocol, boolean) - Constructor for class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingRunnable
 
ServiceDispatcher.ExecutingService - Class in com.sleepycat.je.rep.utilint
A service that is run immediately in a thread allocated to it.
ServiceDispatcher.ExecutingService(String, ServiceDispatcher) - Constructor for class com.sleepycat.je.rep.utilint.ServiceDispatcher.ExecutingService
 
ServiceDispatcher.LazyQueuingService - Class in com.sleepycat.je.rep.utilint
A queuing service that starts the thread that services the requests lazily, upon first request and terminates the thread when the service is unregistered.
ServiceDispatcher.LazyQueuingService(String, BlockingQueue<SocketChannel>, Thread) - Constructor for class com.sleepycat.je.rep.utilint.ServiceDispatcher.LazyQueuingService
 
ServiceDispatcher.QueuingService - Class in com.sleepycat.je.rep.utilint
A service where requests are simply added to the supplied queue.
ServiceDispatcher.QueuingService(String, BlockingQueue<SocketChannel>) - Constructor for class com.sleepycat.je.rep.utilint.ServiceDispatcher.QueuingService
 
ServiceDispatcher.Response - Enum in com.sleepycat.je.rep.utilint
The response to a service request.
ServiceDispatcher.ServiceConnectFailedException - Exception in com.sleepycat.je.rep.utilint
 
ServiceDispatcher.ServiceConnectFailedException(String, ServiceDispatcher.Response) - Constructor for exception com.sleepycat.je.rep.utilint.ServiceDispatcher.ServiceConnectFailedException
 
serviceName - Variable in exception com.sleepycat.je.rep.utilint.ServiceDispatcher.ServiceConnectFailedException
 
set(int) - Method in class com.sleepycat.asm.Item
Sets this item to an integer item.
set(long) - Method in class com.sleepycat.asm.Item
Sets this item to a long item.
set(float) - Method in class com.sleepycat.asm.Item
Sets this item to a float item.
set(double) - Method in class com.sleepycat.asm.Item
Sets this item to a double item.
set(int, String, String, String) - Method in class com.sleepycat.asm.Item
Sets this item to an item that do not hold a primitive value.
set(String, String, int) - Method in class com.sleepycat.asm.Item
Sets the item to an InvokeDynamic item.
set(int, int) - Method in class com.sleepycat.asm.Item
Sets the item to a BootstrapMethod item.
set(E) - Method in class com.sleepycat.collections.BlockIterator
 
set(E) - Method in class com.sleepycat.collections.StoredIterator
Replaces the last element returned by next or previous with the specified element (optional operation).
set(int, E) - Method in class com.sleepycat.collections.StoredList
Replaces the element at the specified position in this list with the specified element (optional operation).
set(int, ELEMENT_TYPE, IN) - Method in class com.sleepycat.je.tree.INArrayRep
Sets the array element at idx to the node.
set(int, byte[], IN) - Method in class com.sleepycat.je.tree.INKeyRep.Default
 
set(int, byte[], IN) - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
set(int, Node, IN) - Method in class com.sleepycat.je.tree.INTargetRep.Default
 
set(int, Node, IN) - Method in class com.sleepycat.je.tree.INTargetRep.None
 
set(int, Node, IN) - Method in class com.sleepycat.je.tree.INTargetRep.Sparse
 
set(int, long, IN) - Method in class com.sleepycat.je.tree.VLSNCache.DefaultCache
Mutates to a DefaultCache with a larger number of bytes if necessary to hold the given value.
set(int, long, IN) - Method in class com.sleepycat.je.tree.VLSNCache
 
set(TransactionStats.Active[]) - Method in class com.sleepycat.je.utilint.ActiveTxnArrayStat
 
set(Integer) - Method in class com.sleepycat.je.utilint.AtomicIntStat
 
set(Long) - Method in class com.sleepycat.je.utilint.AtomicLongStat
 
set(long) - Method in class com.sleepycat.je.utilint.BitMap
 
set(Boolean) - Method in class com.sleepycat.je.utilint.BooleanStat
 
set(Float) - Method in class com.sleepycat.je.utilint.FloatStat
 
set(Integer) - Method in class com.sleepycat.je.utilint.IntStat
 
set(long[]) - Method in class com.sleepycat.je.utilint.LongArrayStat
 
set(Long) - Method in class com.sleepycat.je.utilint.LongStat
 
set(T) - Method in class com.sleepycat.je.utilint.Stat
Set the stat value.
set(String) - Method in class com.sleepycat.je.utilint.StringStat
 
set(long) - Method in class com.sleepycat.utilint.LatencyStat
 
set(int, long) - Method in class com.sleepycat.utilint.LatencyStat
Record a set of operations that took "nanolatency" long.
setAbortInfo(DatabaseImpl, int) - Method in class com.sleepycat.je.txn.WriteLockInfo
 
setAbortKnownDeleted(boolean) - Method in class com.sleepycat.je.txn.WriteLockInfo
 
setAbortLsn(long, boolean) - Method in class com.sleepycat.je.txn.LockResult
 
setAbortLsn(long, boolean, boolean) - Method in class com.sleepycat.je.txn.LockResult
 
setAbortLsn(long) - Method in class com.sleepycat.je.txn.WriteLockInfo
 
setAddHook(TestHook) - Method in class com.sleepycat.je.sync.SyncProcessor
 
setAdjustmentHook(TestHook<UtilizationCalculator.TestAdjustment>) - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
See UtilizationCorrectionTest.
setAggressive(boolean) - Method in class com.sleepycat.je.VerifyConfig
Configures Environment.verify and Database.verify to perform fine granularity consistency checking that includes verifying in memory constructs.
setAggressiveVoid(boolean) - Method in class com.sleepycat.je.VerifyConfig
 
setAllowConvert(ReplicationConfig, boolean) - Static method in class com.sleepycat.je.rep.RepInternal
 
setAllowConvert(boolean) - Method in class com.sleepycat.je.rep.ReplicationConfig
For internal use only.
setAllowCreate(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Configures the Environment.openDatabase method to create the database if it does not already exist.
setAllowCreate(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
If true, creates the database environment if it doesn't already exist.
setAllowCreate(boolean) - Method in class com.sleepycat.je.SequenceConfig
Configures the Database.openSequence method to create the sequence if it does not already exist.
setAllowCreate(boolean) - Method in class com.sleepycat.persist.StoreConfig
Specifies whether creation of a new store is allowed.
setAllowCreateVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setAllowCreateVoid(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
 
setAllowCreateVoid(boolean) - Method in class com.sleepycat.je.SequenceConfig
 
setAllowCreateVoid(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setAllowEviction(boolean) - Method in class com.sleepycat.je.dbi.CursorImpl
Disables or enables eviction during cursor operations.
setAllowFlush(boolean) - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Allows or prohibits this summary from being flushed or evicted during cleaning.
setAllowMultithreadedAccess(boolean) - Method in class com.sleepycat.je.txn.Locker
See ThreadLocker.allowMultithreadedAccess.
setAllowNestedTransactions(boolean) - Method in class com.sleepycat.collections.TransactionRunner
Changes whether nested transactions will be created if run() is called when a transaction is already active for the current thread.
setAllowNewDataSets(boolean) - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
setAllowPopulate(boolean) - Method in class com.sleepycat.je.SecondaryConfig
Specifies whether automatic population of the secondary is allowed.
setAllowPopulateVoid(boolean) - Method in class com.sleepycat.je.SecondaryConfig
 
setAllowUpdate(boolean) - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNTracker
 
setAlreadyThrown(boolean) - Method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
setAlwaysValidateChecksum(boolean) - Method in class com.sleepycat.je.log.FileReader
Whether to always validate the checksum, even for non-target entries.
setAttribute(Attribute) - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
setAttribute(Environment, Attribute) - Method in class com.sleepycat.je.jmx.JEMBeanHelper
Deprecated.
Set an attribute value for the given environment.
setAttribute(Attribute) - Method in class com.sleepycat.je.jmx.JEMonitor
 
setAttributes(AttributeList) - Method in class com.sleepycat.je.jmx.JEDiagnostics
 
setAttributes(AttributeList) - Method in class com.sleepycat.je.jmx.JEMonitor
 
setAutoCommitNoSync(boolean) - Method in class com.sleepycat.je.SequenceConfig
Configures auto-commit operations on the sequence to not flush the transaction log.
setAutoCommitNoSyncVoid(boolean) - Method in class com.sleepycat.je.SequenceConfig
 
setBackgroundSleepHook(TestHook<?>) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
setBackupProhibited(boolean) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
setBackwardPosition() - Method in class com.sleepycat.je.log.FileReader
Ensure that the next target is in the window.
setBarrierState(RepGroupImpl.BarrierState) - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
setBeforeFinishInitHook(TestHook<CountDownLatch>) - Method in class com.sleepycat.je.dbi.DbEnvPool
 
setBeforeFlushHook(TestHook) - Static method in class com.sleepycat.je.recovery.Checkpointer
 
setBeforeFlushTrackerHook(TestHook) - Method in class com.sleepycat.je.incomp.INCompressor
 
setBeginData(byte[]) - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
setBeginKey(byte[]) - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
setBIN(BIN) - Method in class com.sleepycat.je.dbi.CursorImpl
 
setBlockDiffBegin(Block, int) - Method in class com.sleepycat.je.rep.util.ldiff.DiffTracker
 
setBlockSize(int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Configure the number of records to include in each block analyzed by the LDiff operation.
setBlockSizeVoid(int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setBooleanVal(Properties, BooleanConfigParam, boolean, boolean) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for setting boolean values.
setBtreeComparator(DatabaseConfig, Comparator<byte[]>) - Static method in class com.sleepycat.compat.DbCompat
 
setBtreeComparator(Comparator<byte[]>) - Method in class com.sleepycat.je.DatabaseConfig
By default, a byte by byte lexicographic comparison is used for btree keys.
setBtreeComparator(Class<? extends Comparator<byte[]>>) - Method in class com.sleepycat.je.DatabaseConfig
By default, a byte by byte lexicographic comparison is used for btree keys.
setBtreeComparator(Comparator<byte[]>, boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Set the btree comparison function for this database.
setBtreeComparatorInternal(Comparator<byte[]>, boolean) - Method in class com.sleepycat.je.DatabaseConfig
Used to set the comparator when filling in a configuration from an existing database.
setBtreeComparatorVoid(Comparator<byte[]>) - Method in class com.sleepycat.je.DatabaseConfig
 
setBtreeComparatorVoid(Class<? extends Comparator<byte[]>>) - Method in class com.sleepycat.je.DatabaseConfig
 
setBtreeRecordNumbers(DatabaseConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setCacheMissEnd(long) - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
 
setCacheMissStart(long) - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
 
setCacheMode(CacheMode) - Method in class com.sleepycat.je.Cursor
Sets the CacheMode used for subsequent operations performed using this cursor.
setCacheMode(CacheMode) - Method in class com.sleepycat.je.DatabaseConfig
Sets the default CacheMode used for operations performed on this database.
setCacheMode(CacheMode) - Method in class com.sleepycat.je.dbi.CursorImpl
Sets the effective cache mode to use for the next operation.
setCacheMode(CacheMode) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Sets the default mode for this database (all handles).
setCacheMode(CacheMode) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Sets the default CacheMode used for operations performed in this environment.
setCacheMode(CacheMode) - Method in class com.sleepycat.persist.BasicCursor
 
setCacheMode(CacheMode) - Method in interface com.sleepycat.persist.EntityCursor
Changes the CacheMode used for operations performed using this cursor.
setCacheModeStrategy(CacheModeStrategy) - Method in class com.sleepycat.je.DatabaseConfig
 
setCacheModeStrategy(CacheModeStrategy) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Sets the default strategy for this database (all handles).
setCacheModeStrategy(CacheModeStrategy) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setCacheModeStrategyVoid(CacheModeStrategy) - Method in class com.sleepycat.je.DatabaseConfig
 
setCacheModeStrategyVoid(CacheModeStrategy) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setCacheModeVoid(CacheMode) - Method in class com.sleepycat.je.DatabaseConfig
 
setCacheModeVoid(CacheMode) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setCachePercent(int) - Method in class com.sleepycat.je.EnvironmentMutableConfig
By default, JE sets its cache size proportionally to the JVM memory.
setCachePercentVoid(int) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setCacheSize(long) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Configures the memory available to the database system, in bytes.
setCacheSize(int) - Method in class com.sleepycat.je.SequenceConfig
Set the Configure the number of elements cached by a sequence handle.
setCacheSizeVoid(long) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setCacheSizeVoid(int) - Method in class com.sleepycat.je.SequenceConfig
 
setCatalog(PersistCatalog) - Method in class com.sleepycat.persist.impl.StoredModel
This method is used to initialize the model when catalog creation is complete, and reinitialize it when a Replica refresh occurs.
setCatalog(PersistCatalog) - Method in class com.sleepycat.persist.model.EntityModel
 
setCatalog(EntityModel, PersistCatalog) - Static method in class com.sleepycat.persist.model.ModelInternal
Internal access method that should not be used by applications.
setChangeListener(StateChangeListener) - Method in class com.sleepycat.je.rep.impl.node.NodeState
 
setChangeListener(StateChangeListener) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
setChangeVersion(int) - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
setCheckpointId(long) - Method in class com.sleepycat.je.recovery.Checkpointer
Set checkpoint id -- can only be done after recovery.
setCheckpointStart(long) - Method in class com.sleepycat.je.recovery.RollbackTracker
 
setCheckpointUP(EnvironmentConfig, boolean) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentConfig.setCheckpointUP()
setCheckpointUP(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
For unit testing, to prevent writing utilization data during checkpoint.
setCkptHook(TestHook) - Method in class com.sleepycat.je.tree.Tree
 
setCkptStats(StatGroup) - Method in class com.sleepycat.je.EnvironmentStats
 
setClassLoader(ClassLoader) - Method in class com.sleepycat.je.EnvironmentConfig
Configure the environment to use a specified ClassLoader for loading user-supplied classes by name.
setClassLoader(ClassLoader) - Method in class com.sleepycat.persist.model.EntityModel
 
setClassLoader(EntityModel, ClassLoader) - Static method in class com.sleepycat.persist.model.ModelInternal
Internal access method that should not be used by applications.
setClassLoaderVoid(ClassLoader) - Method in class com.sleepycat.je.EnvironmentConfig
 
setCleanerBarrierHook(TestHook<Long>) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
setCleanerStats(StatGroup) - Method in class com.sleepycat.je.EnvironmentStats
 
setClear(boolean) - Method in class com.sleepycat.je.StatsConfig
Configures the statistics operation to reset statistics after they are returned.
setClearVoid(boolean) - Method in class com.sleepycat.je.StatsConfig
 
setClosingLocker(CursorImpl) - Method in class com.sleepycat.je.dbi.CursorImpl
Called when a cursor has been duplicated prior to being moved.
setClosingLocker(Locker) - Method in class com.sleepycat.je.txn.Locker
This method is called to set the closingLocker when a cursor has been duplicated prior to being moved.
setConfig(RepConfigManager) - Method in class com.sleepycat.je.rep.impl.node.DbCache
Updates the configuration of the db cache, by resetting maxEntries and timeoutMs to the configured values.
setConfigParam(Properties, String, String, boolean, boolean, boolean, boolean) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for environment and replication configuration classes.
setConfigParam(String, String) - Method in class com.sleepycat.je.EnvironmentConfig
 
setConfigParam(String, String) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Set this configuration parameter.
setConfigParam(String, String) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setConfigParam(String, String) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Set this configuration parameter with this value.
setConfigProperties(Locker, String, DatabaseConfig, EnvironmentImpl) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setConnection(MBeanServerConnection) - Method in class com.sleepycat.je.jmx.plugin.Stats
 
setConnectionConfig(JDBCConnectionConfig) - Method in class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
Changes the connection configuration.
setConnectionConfig(MobileConnectionConfig) - Method in class com.sleepycat.je.sync.mobile.MobileSyncProcessor
Changes the connection configuration.
setConsistencyPolicy(ReplicaConsistencyPolicy) - Method in class com.sleepycat.je.rep.ReplicationConfig
Sets the consistency policy to be associated with the configuration.
setConsistencyPolicy(ReplicaConsistencyPolicy) - Method in class com.sleepycat.je.TransactionConfig
Associates a consistency policy with this configuration.
setConsistencyPolicyVoid(ReplicaConsistencyPolicy) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setConsistencyPolicyVoid(ReplicaConsistencyPolicy) - Method in class com.sleepycat.je.TransactionConfig
 
setCreateConfig(ReplicatedDatabaseConfig) - Method in class com.sleepycat.je.log.DbOpReplicationContext
 
setCreatedThisTxn(boolean) - Method in class com.sleepycat.je.txn.WriteLockInfo
 
setCreateUP(EnvironmentConfig, boolean) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentConfig.setCreateUP()
setCreateUP(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
For unit testing, to prevent creating the utilization profile DB.
setData(byte[]) - Method in class com.sleepycat.je.DatabaseEntry
Sets the byte array.
setData(byte[], int, int) - Method in class com.sleepycat.je.DatabaseEntry
Sets the byte array, offset and size.
setDatabase(DatabaseImpl) - Method in class com.sleepycat.je.tree.IN
Set the database reference for this node.
setDatabase(DatabaseImpl) - Method in class com.sleepycat.je.tree.Tree
Set the database for this tree.
setDatabaseName(String) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
setDatabaseName(String) - Method in interface com.sleepycat.je.trigger.Trigger
Sets the database name associated with this trigger.
setDatabaseNamer(DatabaseNamer) - Method in class com.sleepycat.persist.StoreConfig
 
setDatabaseNamerVoid(DatabaseNamer) - Method in class com.sleepycat.persist.StoreConfig
 
setDbImplStats(StatGroup) - Method in class com.sleepycat.je.BtreeStats
 
setDbName(String) - Method in class com.sleepycat.je.util.DbLoad
Sets the database name to load.
setDeadlockStackTrace(boolean) - Static method in class com.sleepycat.je.txn.LockInfo
Called when the je.txn.deadlockStackTrace property is changed.
setDebugDatabaseName(String) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setDecrement(boolean) - Method in class com.sleepycat.je.SequenceConfig
Specifies that the sequence should be decremented.
setDecrementVoid(boolean) - Method in class com.sleepycat.je.SequenceConfig
 
setDefaultVersion(int) - Static method in class com.sleepycat.je.rep.stream.Protocol
 
setDeferredWrite(DatabaseConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setDeferredWrite(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Sets the deferred-write option.
setDeferredWrite(boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Sets the deferred write property for the first opened handle.
setDeferredWrite(boolean) - Method in class com.sleepycat.persist.StoreConfig
Sets the deferred-write configuration property.
setDeferredWriteVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setDeferredWriteVoid(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setDelayVLSNRegisterHook(TestHook<Object>) - Method in class com.sleepycat.je.log.LogManager
 
setDeleted(boolean) - Method in class com.sleepycat.persist.impl.Format
Called by the Evolver when applying a Deleter mutation.
setDeletedDatabaseState(boolean) - Method in class com.sleepycat.je.txn.Txn
 
setDesignatedPrimary(boolean) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
If isPrimary is true, designate this node as a Primary.
setDesignatedPrimaryVoid(boolean) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
 
setDiffAnalysis(boolean) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Configure an LDiff object to provide detailed analysis about diff failures.
setDiffAnalysisVoid(boolean) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setDirty(boolean) - Method in class com.sleepycat.je.tree.IN
 
setDirty() - Method in class com.sleepycat.je.tree.LN
 
setDirtyUtilization() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Sets utilization dirty in order to force the MapLN to be flushed later.
setDontProcessStream() - Method in class com.sleepycat.je.rep.impl.node.Replica
For unit testing only!
setDumpCorruptedBounds(boolean) - Method in class com.sleepycat.je.log.ScavengerFileReader
Set to true if corrupted boundaries should be dumped to stderr.
setDumpCorruptedBounds(boolean) - Method in class com.sleepycat.je.util.DbScavenger
Set to true if corrupted boundaries should be dumped out.
setDupConvertPreloadConfig(PreloadConfig) - Method in class com.sleepycat.je.EnvironmentConfig
 
setDupConvertPreloadConfigVoid(PreloadConfig) - Method in class com.sleepycat.je.EnvironmentConfig
 
setDuplicateComparator(Comparator<byte[]>) - Method in class com.sleepycat.je.DatabaseConfig
By default, a byte by byte lexicographic comparison is used for duplicate data items in a duplicate set.
setDuplicateComparator(Class<? extends Comparator<byte[]>>) - Method in class com.sleepycat.je.DatabaseConfig
By default, a byte by byte lexicographic comparison is used for duplicate data items in a duplicate set.
setDuplicateComparator(Comparator<byte[]>, boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Set the duplicate comparison function for this database.
setDuplicateComparatorInternal(Comparator<byte[]>, boolean) - Method in class com.sleepycat.je.DatabaseConfig
Used to set the comparator when filling in a configuration from an existing database.
setDuplicateComparatorVoid(Comparator<byte[]>) - Method in class com.sleepycat.je.DatabaseConfig
 
setDuplicateComparatorVoid(Class<? extends Comparator<byte[]>>) - Method in class com.sleepycat.je.DatabaseConfig
 
setDupsConverted() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setDupsConverted() - Method in class com.sleepycat.je.dbi.DbTree
 
setDurability(Durability) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Configures the durability associated with transactions.
setDurability(Durability) - Method in class com.sleepycat.je.sync.ExportConfig
 
setDurability(Durability) - Method in class com.sleepycat.je.sync.ImportConfig
 
setDurability(Durability) - Method in class com.sleepycat.je.TransactionConfig
Configures the durability associated with a transaction when it commits.
setDurabilityVoid(Durability) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setDurabilityVoid(Durability) - Method in class com.sleepycat.je.TransactionConfig
 
setDurationVal(Properties, DurationConfigParam, long, TimeUnit, boolean) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for setting duration values.
setElectableGroupSizeOverride(int) - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
setElectableGroupSizeOverride(int) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Sets the size used to determine the number of electable nodes.
setElectableGroupSizeOverrideVoid(int) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
 
setElements(RawObject, Object[]) - Static method in class com.sleepycat.persist.impl.CollectionProxy
 
setEmpty() - Method in class com.sleepycat.je.tree.LN
Sets data to empty and returns old data.
setEncryptionType(String) - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
setEndOfFile() - Method in class com.sleepycat.je.log.LastFileReader
 
setEntry(DatabaseEntry) - Method in class com.sleepycat.je.tree.LN
Copies the non-deleted LN's byte array to the entry.
setEntry(DatabaseEntry, byte[]) - Static method in class com.sleepycat.je.tree.LN
Copies the given byte array to the entry, copying only partial data if the entry is specified to be partial.
setEnv(Environment) - Method in class com.sleepycat.je.util.DbLoad
Sets the Environment to load from.
setEnvImplStats(StatGroup) - Method in class com.sleepycat.je.EnvironmentStats
 
setEnvironmentImpl(EnvironmentImpl) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Set the db environment after reading in the DatabaseImpl from the log.
setEvictProfileHook(TestHook<IN>) - Method in class com.sleepycat.je.evictor.Evictor
 
setEvolveListener(EvolveListener) - Method in class com.sleepycat.persist.evolve.EvolveConfig
Sets a progress listener that is notified each time an entity is read.
setEvolveListenerVoid(EvolveListener) - Method in class com.sleepycat.persist.evolve.EvolveConfig
 
setEvolveNeeded(boolean) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
setEvolveNeeded(boolean) - Method in class com.sleepycat.persist.impl.Format
Called by the Evolver with true when an entity format or any of its nested format were changed.
setExceptionListener(ExceptionListener) - Method in class com.sleepycat.je.cleaner.Cleaner
 
setExceptionListener(ExceptionListener) - Method in class com.sleepycat.je.EnvironmentMutableConfig
Sets the exception listener for an Environment.
setExceptionListener(ExceptionListener) - Method in interface com.sleepycat.je.utilint.DaemonRunner
 
setExceptionListener(ExceptionListener) - Method in class com.sleepycat.je.utilint.DaemonThread
 
setExceptionListener(ExceptionListener) - Method in interface com.sleepycat.je.utilint.ExceptionListenerUser
 
setExceptionListener(ExceptionListener) - Method in class com.sleepycat.je.utilint.StoppableThread
Set every time a new exception listener is registered.
setExceptionListenerVoid(ExceptionListener) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setExclusiveCreate(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Configure the Environment.openDatabase method to fail if the database already exists.
setExclusiveCreate(boolean) - Method in class com.sleepycat.je.SequenceConfig
Configures the Database.openSequence method to fail if the database already exists.
setExclusiveCreate(boolean) - Method in class com.sleepycat.persist.StoreConfig
Specifies whether opening an existing store is prohibited.
setExclusiveCreateVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setExclusiveCreateVoid(boolean) - Method in class com.sleepycat.je.SequenceConfig
 
setExclusiveCreateVoid(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setExclusiveOnly(boolean) - Method in class com.sleepycat.je.latch.SharedLatch
Indicate whether this latch can only be set exclusively (not shared).
setFactory(MasterTxn.MasterTxnFactory) - Static method in class com.sleepycat.je.rep.txn.MasterTxn
Method used for unit testing.
setFast(boolean) - Method in class com.sleepycat.je.StatsConfig
Configures the statistics operation to return only the values which do not incur some performance penalty.
setFastVoid(boolean) - Method in class com.sleepycat.je.StatsConfig
 
setField(Object, int, int, boolean, Object) - Method in interface com.sleepycat.persist.impl.Accessor
Changes the value of a given field, representing primitives as primitive wrapper objects.
setField(Object, int, int, boolean, Object) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
setField(Object, int, int, boolean, Object) - Method in class com.sleepycat.persist.impl.RawAccessor
 
setField(Object, int, int, boolean, Object) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
setFileChosenHook(TestHook) - Method in class com.sleepycat.je.cleaner.Cleaner
 
setFileHeaderVersion(int) - Method in class com.sleepycat.je.log.LogEntryHeader
Called to set the version for a file header entry after reading the version from the item data.
setFileNum(long, int) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
Ensure that whenever we change the fileNum, the logVersion is also updated.
setFirstPass(boolean) - Method in class com.sleepycat.je.recovery.RollbackTracker
 
setFlushLogHook(TestHook<CountDownLatch>) - Method in class com.sleepycat.je.log.LogManager
 
setForce(boolean) - Method in class com.sleepycat.je.CheckpointConfig
Configures the checkpoint force option.
setForceVoid(boolean) - Method in class com.sleepycat.je.CheckpointConfig
 
setForeignKeyDatabase(Database) - Method in class com.sleepycat.je.SecondaryConfig
Defines a foreign key integrity constraint for a given foreign key database.
setForeignKeyDatabaseVoid(Database) - Method in class com.sleepycat.je.SecondaryConfig
 
setForeignKeyDeleteAction(ForeignKeyDeleteAction) - Method in class com.sleepycat.je.SecondaryConfig
Specifies the action taken when a referenced record in the foreign key database is deleted.
setForeignKeyDeleteActionVoid(ForeignKeyDeleteAction) - Method in class com.sleepycat.je.SecondaryConfig
 
setForeignKeyNullifier(ForeignKeyNullifier) - Method in class com.sleepycat.je.SecondaryConfig
Specifies the user-supplied object used for setting single-valued foreign keys to null.
setForeignKeyNullifierVoid(ForeignKeyNullifier) - Method in class com.sleepycat.je.SecondaryConfig
 
setForeignMultiKeyNullifier(ForeignMultiKeyNullifier) - Method in class com.sleepycat.je.SecondaryConfig
Specifies the user-supplied object used for setting multi-valued foreign keys to null.
setForeignMultiKeyNullifierVoid(ForeignMultiKeyNullifier) - Method in class com.sleepycat.je.SecondaryConfig
 
setForReplication(boolean) - Method in class com.sleepycat.je.config.ConfigParam
 
setForwardPosition() - Method in class com.sleepycat.je.log.FileReader
Ensure that the next target is in the window.
setGeneration(CacheMode) - Method in class com.sleepycat.je.tree.IN
 
setGeneration(long) - Method in class com.sleepycat.je.tree.IN
 
setGlobalSyncupEndHook(ReplicaFeederSyncup.TestHook<Object>) - Static method in class com.sleepycat.je.rep.stream.ReplicaFeederSyncup
 
setGroupMaster(InetSocketAddress, NameIdPair) - Method in class com.sleepycat.je.rep.stream.MasterStatus
 
setGroupName(String) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Sets the name for the replication group.
setGroupName(String) - Method in class com.sleepycat.je.rep.ReplicationConfig
Sets the name for the replication group.
setGroupNameVoid(String) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
setGroupNameVoid(String) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setGTEHook(TestHook<?>) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
setHardRecoveryInfo(RollbackException) - Method in class com.sleepycat.je.rep.impl.RepImpl
If this node was started with a hard recovery, preserve that information.
setHelperHosts(String) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Identify one or more helpers nodes by their host and port pairs in this format:
setHelperHosts(String) - Method in class com.sleepycat.je.rep.ReplicationConfig
Identify one or more helpers nodes by their host and port pairs in this format:
setHelperHostsVoid(String) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
setHelperHostsVoid(String) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setHostName(String) - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
setId(DatabaseId) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setId(int) - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
 
setId(DatabaseId) - Method in class com.sleepycat.je.tree.NameLN
 
setId(int) - Method in class com.sleepycat.persist.impl.Format
Called by the Catalog to set the format ID when a new format is added to the format list, before calling initializeIfNeeded().
setIdentifierKey(byte[]) - Method in class com.sleepycat.je.tree.IN
Set the identifier key for this node.
setIgnoreUnknownConfig(boolean) - Method in class com.sleepycat.je.util.DbLoad
Sets whether to ignore unknown parameters in the config file.
setImmutableSecondaryKey(boolean) - Method in class com.sleepycat.je.SecondaryConfig
Specifies whether the secondary key is immutable.
setImmutableSecondaryKeyVoid(boolean) - Method in class com.sleepycat.je.SecondaryConfig
 
setImportunate(Transaction, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setImportunate(boolean) - Method in class com.sleepycat.je.txn.Locker
Set the state of a transaction's IMPORTUNATE bit.
setImportunate(boolean) - Method in class com.sleepycat.je.txn.Txn
Set the state of a transaction's IMPORTUNATE bit.
setIncludeDeletedFiles(boolean) - Method in class com.sleepycat.je.log.FileManager
 
setINCompStats(StatGroup) - Method in class com.sleepycat.je.EnvironmentStats
 
setIndex(int) - Method in class com.sleepycat.je.dbi.CursorImpl
 
setIndex(int) - Method in class com.sleepycat.je.tree.TrackingInfo
 
setInitializeCache(EnvironmentConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setInitializeCDB(EnvironmentConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setInitializeLocking(EnvironmentConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setInitialReplayHook(TestHook<BinaryProtocol.Message>) - Static method in class com.sleepycat.je.rep.impl.node.Replica
Sets a test hook for installation into Replica class instances to be created in the future.
setInitialValue(long) - Method in class com.sleepycat.je.SequenceConfig
Sets the initial value for a sequence.
setInitialValueVoid(long) - Method in class com.sleepycat.je.SequenceConfig
 
setInListResident(boolean) - Method in class com.sleepycat.je.tree.IN
Called when adding/removing this IN to/from the INList.
setInputReader(BufferedReader) - Method in class com.sleepycat.je.util.DbLoad
Sets the BufferedReader to load from.
setInternalMemoryLimit(long) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
setInternalMemoryLimit(long) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Set the maximum amount of non JE Cache Memory that the DiskOrderedScan can use at one time.
setInternalMemoryLimit(long) - Method in class com.sleepycat.je.PreloadConfig
Set the maximum amount of non JE Cache Memory that preload can use at one time.
setInternalMemoryLimitVoid(long) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
 
setInternalMemoryLimitVoid(long) - Method in class com.sleepycat.je.PreloadConfig
 
setIntVal(Properties, IntConfigParam, int, boolean) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for setting integer values.
setIsRepConverted() - Method in class com.sleepycat.je.dbi.DbTree
 
setIsReplicated() - Method in class com.sleepycat.je.dbi.DbTree
 
setIsReplicatedBit() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setIsRoot(boolean) - Method in class com.sleepycat.je.tree.IN
 
setIteratorBlockSize(int) - Method in class com.sleepycat.collections.StoredCollection
Changes the number of records read at one time by iterators returned by the StoredCollection.iterator() method.
setKBytes(int) - Method in class com.sleepycat.je.CheckpointConfig
Configures the checkpoint log data threshold, in kilobytes.
setKBytesVoid(int) - Method in class com.sleepycat.je.CheckpointConfig
 
setKey(byte[]) - Method in class com.sleepycat.je.tree.ChildReference
Set the key for this ChildReference.
setKeyCreator(SecondaryKeyCreator) - Method in class com.sleepycat.je.SecondaryConfig
Specifies the user-supplied object used for creating single-valued secondary keys.
setKeyCreatorVoid(SecondaryKeyCreator) - Method in class com.sleepycat.je.SecondaryConfig
 
setKeyPrefix(byte[]) - Method in class com.sleepycat.je.tree.IN
 
setKeyPrefixing(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Configure the database to support key prefixing.
setKeyPrefixing() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setKeyPrefixingVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setKeysOnly(boolean) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Specify whether the DiskOrderedCursor should return only the key or key + data.
setKeysOnlyVoid(boolean) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
 
setKnownDeleted(int) - Method in class com.sleepycat.je.tree.BIN
Mark this entry as deleted, using the delete flag.
setKnownDeleted(int) - Method in class com.sleepycat.je.tree.IN
Set knownDeleted to true.
setKnownDeletedClearAll(int) - Method in class com.sleepycat.je.tree.BIN
 
setLastAppliedVLSN(VLSN) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
setLastDbId(long, long) - Method in class com.sleepycat.je.dbi.DbTree
Initialize the db ids, from recovery.
setLastFullLsn(long) - Method in class com.sleepycat.je.tree.IN
Sets the last full version LSN.
setLastLoggedLsn(long) - Method in class com.sleepycat.je.tree.BIN
Overrides the IN method to account for deltas.
setLastLoggedLsn(long) - Method in class com.sleepycat.je.tree.IN
Sets the last logged LSN, which for a BIN may be a delta.
setLastLoggedSize(int) - Method in class com.sleepycat.je.tree.LN
Saves the last logged size.
setLastLsnAtRecovery(long) - Method in class com.sleepycat.je.log.LogManager
 
setLastNodeId(long, long) - Method in class com.sleepycat.je.dbi.NodeSequence
Initialize the node IDs, from recovery.
setLastPosition(long, long, long) - Method in class com.sleepycat.je.log.FileManager
Set the file manager's "end of log".
setLastSyncEnd(long) - Method in class com.sleepycat.je.sync.impl.LogChangeSet
 
setLastTxnId(long, long) - Method in class com.sleepycat.je.txn.TxnManager
Set the txn id sequence.
setLatch() - Method in class com.sleepycat.je.rep.elections.Elections.ElectionListener
Returns a new latch to be associated with the RetryPredicate.
setLatestVersion(Format) - Method in class com.sleepycat.persist.impl.Format
Called by Evolver to set the latest format when this old format is evolved.
setLeaseDuration(long) - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
setList(List<Map.Entry<String, String>>) - Method in class com.sleepycat.je.jmx.plugin.Stats.StatsTableModel
 
setLoadLNs(boolean) - Method in class com.sleepycat.je.PreloadConfig
Configure the preload load LNs option.
setLoadLNsVoid(boolean) - Method in class com.sleepycat.je.PreloadConfig
 
setLoadPropertyFile(EnvironmentConfig, boolean) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentConfig.setLoadPropertyFile()
setLoadPropertyFile(boolean) - Method in class com.sleepycat.je.EnvironmentMutableConfig
For unit testing, to prevent loading of je.properties.
setLocalBeginData(byte[]) - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
setLocalBeginKey(byte[]) - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
setLocalDiffSize(long) - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
setLocalTransaction(JELocalTransaction) - Method in class com.sleepycat.je.jca.ra.JEConnection
 
setLockDetectModeOldest(EnvironmentConfig) - Static method in class com.sleepycat.compat.DbCompat
 
setLocker(Locker) - Method in class com.sleepycat.je.txn.LockInfo
Change this lockInfo over to the prescribed locker.
setLocking(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
Configures the database environment for no locking.
setLockingVoid(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
 
setLockStats(StatGroup) - Method in class com.sleepycat.je.EnvironmentStats
 
setLockTableDump(boolean) - Static method in class com.sleepycat.je.txn.LockManager
Called when the je.txn.dumpLocks property is changed.
setLockTimeout(long, TimeUnit) - Method in class com.sleepycat.je.EnvironmentConfig
Configures the lock timeout.
setLockTimeout(long) - Method in class com.sleepycat.je.EnvironmentConfig
Deprecated.
setLockTimeout(long, TimeUnit) - Method in class com.sleepycat.je.Transaction
Configures the lock request timeout value for the transaction.
setLockTimeout(long) - Method in class com.sleepycat.je.Transaction
Deprecated.
setLockTimeout(long) - Method in class com.sleepycat.je.txn.BuddyLocker
Sets the lock timeout of the buddy locker, since this locker has no independent timeout.
setLockTimeout(long) - Method in class com.sleepycat.je.txn.Locker
Set the lock timeout period for any locks in this transaction, in milliseconds.
setLockTimeoutVoid(long, TimeUnit) - Method in class com.sleepycat.je.EnvironmentConfig
 
setLockTimeoutVoid(long) - Method in class com.sleepycat.je.EnvironmentConfig
 
setLockType(LockType) - Method in class com.sleepycat.je.txn.LockInfo
 
setLoggingHandler(Handler) - Method in class com.sleepycat.je.EnvironmentConfig
Set a java.util.logging.Handler which will be used by all java.util.logging.Loggers instantiated by this Environment.
setLoggingHandlerVoid(Handler) - Method in class com.sleepycat.je.EnvironmentConfig
 
setLogItem(LogItem) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.VLSNAwaitLatch
 
setLogProviders(List<ReplicationNode>) - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
Sets the prioritized list of members used to select a node from which to obtain log files for the NetworkRestore operation.
setLogProvidersVoid(List<ReplicationNode>) - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
 
setLogStats(StatGroup) - Method in class com.sleepycat.je.EnvironmentStats
 
setLogSummary(CleanerLogSummary) - Method in class com.sleepycat.je.cleaner.Cleaner
 
setLogSummary(CleanerLogSummary) - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Restores log summary info that was read from persistent storage.
setLogType(LogEntryType) - Method in class com.sleepycat.je.log.entry.BaseEntry
Inform a BaseEntry instance of its corresponding LogEntryType.
setLogType(LogEntryType) - Method in interface com.sleepycat.je.log.entry.LogEntry
Inform a LogEntry instance of its corresponding LogEntryType.
setLogWriter(PrintWriter) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
setLogWriter(PrintWriter) - Method in class com.sleepycat.je.jca.ra.JEManagedConnectionFactory
 
setLsn(long) - Method in class com.sleepycat.je.tree.ChildReference
Sets the target LSN for this ChildReference.
setLSNBatchSize(long) - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
setLSNBatchSize(long) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Set the maximum number of LSNs to gather and sort at any one time.
setLSNBatchSize(long) - Method in class com.sleepycat.je.PreloadConfig
Set the maximum number of LSNs to gather and sort at any one time.
setLSNBatchSizeVoid(long) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
 
setLSNBatchSizeVoid(long) - Method in class com.sleepycat.je.PreloadConfig
 
setLsnElement(int, long) - Method in class com.sleepycat.je.tree.IN
 
setManagedConnection(JEManagedConnection, JELocalTransaction) - Method in class com.sleepycat.je.jca.ra.JEConnection
 
setMasterTransfer(MasterTransfer) - Method in class com.sleepycat.je.rep.impl.node.Feeder
 
setMatchpoint(long) - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
At the end of the search for a matchpoint, set the matchpointLSN and adjust the debugging list of passed transactions.
setMax(long) - Method in class com.sleepycat.je.utilint.LongMaxStat
Set stat to MAX(current stat value, newValue).
setMaxBytes(long) - Method in class com.sleepycat.je.PreloadConfig
Configure the maximum number of bytes to preload.
setMaxBytesVoid(long) - Method in class com.sleepycat.je.PreloadConfig
 
setMaxClockDelta(long, TimeUnit) - Method in class com.sleepycat.je.rep.ReplicationConfig
Sets the maximum acceptable clock skew between this Replica and its Feeder, which is the node that is the source of its replication stream.
setMaxClockDeltaVoid(long, TimeUnit) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setMaxConnectionAttempts(int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setMaxConnectionAttemptsVoid(int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setMaxErrors(int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Configure the maximum number of errors to be analyzed before ending the LDiff operation.
setMaxErrorsVoid(int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setMaxFlushLevelHook(TestHook) - Static method in class com.sleepycat.je.recovery.Checkpointer
 
setMaxMillisecs(long) - Method in class com.sleepycat.je.PreloadConfig
Configure the maximum number of milliseconds to execute preload.
setMaxMillisecsVoid(long) - Method in class com.sleepycat.je.PreloadConfig
 
setMaxOperations(long) - Method in class com.sleepycat.je.sync.ExportConfig
 
setMaxOperations(long) - Method in class com.sleepycat.je.sync.ImportConfig
 
setMaxRetries(int) - Method in class com.sleepycat.collections.TransactionRunner
Changes the maximum number of retries that will be performed when deadlocks are detected.
setMaxSeedMillisecs(long) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Set the maximum time in milliseconds to spend seeding the Disk Ordered Scan.
setMaxSeedMillisecsVoid(long) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
 
setMaxSeedNodes(long) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Set the maximum number of internal nodes to use to seed the Disk Ordered Scan.
setMaxSeedNodesVoid(long) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
 
setMaxSeedTestHook(TestHook) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
 
setMaxTime(long, TimeUnit) - Method in class com.sleepycat.je.sync.ExportConfig
 
setMaxTime(long, TimeUnit) - Method in class com.sleepycat.je.sync.ImportConfig
 
setMBAndEvictorStats(StatGroup, StatGroup) - Method in class com.sleepycat.je.EnvironmentStats
 
setMd5Hash(byte[]) - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
setMigrate(boolean) - Method in class com.sleepycat.je.tree.ChildReference
Set the entry migrate status.
setMigrate(int, boolean) - Method in class com.sleepycat.je.tree.IN
Set the idx'th migrate status.
setMin(long) - Method in class com.sleepycat.je.utilint.LongMinStat
Set stat to MIN(current stat value, newValue).
setMinimizeRecoveryTime(boolean) - Method in class com.sleepycat.je.CheckpointConfig
Configures the minimize recovery time option.
setMinimizeRecoveryTimeVoid(boolean) - Method in class com.sleepycat.je.CheckpointConfig
 
setMinutes(int) - Method in class com.sleepycat.je.CheckpointConfig
Configures the checkpoint time threshold, in minutes.
setMinutesVoid(int) - Method in class com.sleepycat.je.CheckpointConfig
 
setModel(EntityModel) - Method in class com.sleepycat.persist.StoreConfig
Sets the entity model that defines entity classes and index keys.
setModelVoid(EntityModel) - Method in class com.sleepycat.persist.StoreConfig
 
setMultiKeyCreator(SecondaryMultiKeyCreator) - Method in class com.sleepycat.je.SecondaryConfig
Specifies the user-supplied object used for creating multi-valued secondary keys.
setMultiKeyCreatorVoid(SecondaryMultiKeyCreator) - Method in class com.sleepycat.je.SecondaryConfig
 
setMutableConfig(EnvironmentImpl, EnvironmentMutableConfig) - Method in class com.sleepycat.je.dbi.DbEnvPool
Called by EnvironmentImpl.setMutableConfig to perform the setMutableConfig operation while synchronized on the DbEnvPool.
setMutableConfig(EnvironmentMutableConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Changes the mutable config properties that are present in the given config, and notifies all config observer.
setMutableConfig(EnvironmentMutableConfig) - Method in class com.sleepycat.je.Environment
Sets database environment attributes.
setMutations(Mutations) - Method in class com.sleepycat.persist.StoreConfig
Configures mutations for performing lazy evolution of stored instances.
setMutationsVoid(Mutations) - Method in class com.sleepycat.persist.StoreConfig
 
setName(String) - Method in class com.sleepycat.je.latch.Latch
Set the latch name, used for latches in objects instantiated from the log.
setName(String) - Method in class com.sleepycat.je.latch.SharedLatch
Set the latch name, used for latches in objects instantiated from the log.
setName(String) - Method in class com.sleepycat.je.Transaction
Set the user visible name for the transaction.
setNameIdPair(NameIdPair) - Method in class com.sleepycat.je.rep.utilint.NamedChannel
 
setNeverLocked(boolean) - Method in class com.sleepycat.je.txn.WriteLockInfo
 
setNext(OffsetList.Segment) - Method in class com.sleepycat.je.cleaner.OffsetList.Segment
Sets the next pointer during a merge.
setNextSyncStart(long) - Method in class com.sleepycat.je.sync.impl.LogChangeSet
 
setNodeHostPort(String) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Sets the hostname and port associated with this monitor.
setNodeHostPort(String) - Method in class com.sleepycat.je.rep.ReplicationConfig
Sets the hostname and port associated with this node.
setNodeHostPortVoid(String) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
setNodeHostPortVoid(String) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setNodeId(long) - Method in class com.sleepycat.je.tree.IN
 
setNodeIdSequence(int) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Set the node id sequence.
setNodeMaxDupTreeEntries(int) - Method in class com.sleepycat.je.DatabaseConfig
Deprecated.
this property no longer has any effect; DatabaseConfig.setNodeMaxEntries(int) should be used instead.
setNodeMaxDupTreeEntriesVoid(int) - Method in class com.sleepycat.je.DatabaseConfig
 
setNodeMaxEntries(int) - Method in class com.sleepycat.je.DatabaseConfig
Configures the Environment.openDatabase method to have a B+Tree fanout of nodeMaxEntries.
setNodeMaxEntriesVoid(int) - Method in class com.sleepycat.je.DatabaseConfig
 
setNodeMaxTreeEntries(int) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setNodeName(String) - Method in class com.sleepycat.je.EnvironmentConfig
Sets the user defined nodeName for the Environment.
setNodeName(String) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Sets the name to be associated with this monitor.
setNodeName(String) - Method in class com.sleepycat.je.rep.ReplicationConfig
Sets the name to be associated with this node.
setNodeNameVoid(String) - Method in class com.sleepycat.je.EnvironmentConfig
 
setNodeNameVoid(String) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
setNodeNameVoid(String) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setNodePriority(int) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Sets the election priority for the node.
setNodePriorityVoid(int) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
 
setNodes(Map<Integer, RepNodeImpl>) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Sets the nodes associated with the Rep group.
setNodeType(NodeType) - Method in class com.sleepycat.je.rep.ReplicationConfig
Sets the type of this node.
setNodeTypeVoid(NodeType) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setNonCloning(boolean) - Method in class com.sleepycat.je.Cursor
Prevents this cursor from being cloned to perform an operation that changes the cursor position.
setNonCloning(Cursor, boolean) - Static method in class com.sleepycat.je.DbInternal
Proxy to Cursor.setNonCloning.
setNoOverwrite(boolean) - Method in class com.sleepycat.je.util.DbLoad
Sets whether the load should overwrite existing data or not.
setNoSort(boolean) - Method in class com.sleepycat.je.JoinConfig
Specifies whether automatic sorting of the input cursors is disabled.
setNoSortVoid(boolean) - Method in class com.sleepycat.je.JoinConfig
 
setNoSync(boolean) - Method in class com.sleepycat.je.TransactionConfig
setNoSyncVoid(boolean) - Method in class com.sleepycat.je.TransactionConfig
 
setNoteLatch(boolean) - Method in class com.sleepycat.je.latch.SharedLatch
Indicate whether this latch should be tracked in the debugging LatchSupport.latchTable.
setNoWait(boolean) - Method in class com.sleepycat.je.TransactionConfig
Configures the transaction to not wait if a lock request cannot be immediately granted.
setNoWaitVoid(boolean) - Method in class com.sleepycat.je.TransactionConfig
 
setNumRecords(int) - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
setNumRetries(int) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Sets the number of times a ping thread attempts to contact a node before deeming it unreachable.
setNumRetriesVoid(int) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
setOffset(int) - Method in class com.sleepycat.je.DatabaseEntry
Sets the byte offset into the data array.
setOnlyAbortable(OperationFailureException) - Method in class com.sleepycat.je.txn.BuddyLocker
Forwards to the buddy locker, since the buddy may be transactional.
setOnlyAbortable(OperationFailureException) - Method in class com.sleepycat.je.txn.Locker
Set the state of a transaction to abort-only.
setOnlyAbortable(OperationFailureException) - Method in class com.sleepycat.je.txn.Txn
Set the state of a transaction to abort-only.
setOverrideBtreeComparator(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Sets to true if the database exists and the btree comparator specified in this configuration object should override the current comparator.
setOverrideBtreeComparatorVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setOverrideDuplicateComparator(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Sets to true if the database exists and the duplicate comparator specified in this configuration object should override the current comparator.
setOverrideDuplicateComparatorVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setOverrideTriggers(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setOverrideTriggers(boolean) - Method in class com.sleepycat.je.SecondaryConfig
 
setOverrideTriggersVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setOverrideValidateParams(boolean) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
For unit testing only
setOwnerTxnIds(long[]) - Method in exception com.sleepycat.je.LockConflictException
 
setPartial(int, int, boolean) - Method in class com.sleepycat.je.DatabaseEntry
Configures this DatabaseEntry to read or write partial records.
setPartial(boolean) - Method in class com.sleepycat.je.DatabaseEntry
Configures this DatabaseEntry to read or write partial records.
setPartialLength(int) - Method in class com.sleepycat.je.DatabaseEntry
Sets the byte length of the partial record being read or written by the application, in bytes.
setPartialOffset(int) - Method in class com.sleepycat.je.DatabaseEntry
Sets the offset of the partial record being read or written by the application, in bytes.
setPassword(char[]) - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
setPendingDeleted(int) - Method in class com.sleepycat.je.tree.IN
Set pendingDeleted to true.
setPendingDeletedHook(TestHook<?>) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setPort(int) - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
setPosition(long) - Method in class com.sleepycat.je.rep.stream.VLSNReader
 
setPreemptable(boolean) - Method in class com.sleepycat.je.txn.Locker
Allows/disallows my locks from being stolen/preemted.
setPreempted(String, String) - Method in class com.sleepycat.je.Database
Marks the handle as preempted when the handle lock is stolen by the HA replayer, during replay of a naming operation (remove, truncate or rename).
setPreempted(Database, String, String) - Static method in class com.sleepycat.je.DbInternal
Proxy to Database.setPreempted()
setPreempted() - Method in class com.sleepycat.je.txn.Locker
Called when a lock is stolen from this locker by the HA replayer.
setPreEvictINHook(TestHook<Object>) - Method in class com.sleepycat.je.evictor.Evictor
 
setPrepared(boolean) - Method in class com.sleepycat.je.txn.Txn
 
setPriField(Object, Object) - Method in interface com.sleepycat.persist.impl.Accessor
Changes the value of the primary key field, representing primitives as primitive wrapper objects.
setPriField(Object, Object) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
setPriField(Object, Object) - Method in class com.sleepycat.persist.impl.RawAccessor
 
setPriField(Object, Object) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
setPrimaryConfig(Class, DatabaseConfig) - Method in class com.sleepycat.persist.EntityStore
Configures the primary database for an entity class using the Berkeley DB engine API.
setPrimaryConfig(Class, DatabaseConfig) - Method in class com.sleepycat.persist.impl.Store
 
setPrintInfo(boolean) - Method in class com.sleepycat.je.VerifyConfig
Configures Environment.verify and Database.verify to print basic verification information to System.out.
setPrintInfoVoid(boolean) - Method in class com.sleepycat.je.VerifyConfig
 
setProgress(RecoveryProgress) - Method in class com.sleepycat.je.dbi.StartupTracker
Record new progress states for any registered environment progress listener.
setProgressInterval(long) - Method in class com.sleepycat.je.util.DbLoad
If progressInterval is set, progress status messages are generated to stdout at set percentages of the load.
setProgressListener(ProgressListener<PreloadConfig.Phases>) - Method in class com.sleepycat.je.PreloadConfig
Configure the preload operation to make periodic calls to a ProgressListener to provide feedback on preload progress.
setProgressListenerVoid(ProgressListener<PreloadConfig.Phases>) - Method in class com.sleepycat.je.PreloadConfig
 
setProhibitNextDelta() - Method in class com.sleepycat.je.tree.BIN
If cleaned or compressed, must log full version.
setProhibitNextDelta() - Method in class com.sleepycat.je.tree.IN
Do nothing since INs don't support deltas.
setPropagateExceptions(boolean) - Method in class com.sleepycat.je.VerifyConfig
Configures Environment.verify and Database.verify to propagate exceptions found during verification.
setPropagateExceptionsVoid(boolean) - Method in class com.sleepycat.je.VerifyConfig
 
setProtectedFiles() - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Determine which files are protectd from deletion, which influences which files are cleaned.
setProxiedFormat(Format) - Method in class com.sleepycat.persist.impl.Format
Called by ProxiedFormat to set the proxied format.
setQueueFileNum(long) - Method in class com.sleepycat.je.log.FileManager.LogEndFileDescriptor
 
setQueueSize(int) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Set the queue size for entries being passed between the DiskOrderedCursor producer thread and the application's consumer thread.
setQueueSizeVoid(int) - Method in class com.sleepycat.je.DiskOrderedCursorConfig
 
setQuorumAck(boolean) - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
setRange(long, long) - Method in class com.sleepycat.je.SequenceConfig
Configures a sequence range.
setRangeConstraint(RangeConstraint) - Method in class com.sleepycat.je.Cursor
 
setRangeMax(long) - Method in class com.sleepycat.je.SequenceConfig
 
setRangeMaxVoid(long) - Method in class com.sleepycat.je.SequenceConfig
 
setRangeMin(long) - Method in class com.sleepycat.je.SequenceConfig
 
setRangeMinVoid(long) - Method in class com.sleepycat.je.SequenceConfig
 
setRawAccess(boolean) - Method in class com.sleepycat.persist.impl.AbstractInput
 
setRawAccess(boolean) - Method in interface com.sleepycat.persist.impl.EntityInput
Changes raw mode and returns the original mode, which is normally restored later.
setRawAccess(boolean) - Method in class com.sleepycat.persist.impl.RecordInput
 
setReadCommitted(boolean) - Method in class com.sleepycat.je.CursorConfig
Configures read operations performed by the cursor to obey read committed isolation.
setReadCommitted(boolean) - Method in class com.sleepycat.je.TransactionConfig
Configures the transaction for read committed isolation.
setReadCommittedVoid(boolean) - Method in class com.sleepycat.je.CursorConfig
 
setReadCommittedVoid(boolean) - Method in class com.sleepycat.je.TransactionConfig
 
setReader(Reader) - Method in class com.sleepycat.persist.impl.Format
Changes the reader during format evolution.
setReadHook(TestHook) - Method in class com.sleepycat.je.log.LogManager
 
setReadModifyWrite(boolean) - Method in class com.sleepycat.collections.StoredIterator
Changes whether write-locks will be obtained when reading with this cursor.
setReadOnly(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Configures the database in read-only mode.
setReadOnly(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
Configures the database environment to be read-only, and any attempt to modify a database will fail.
setReadOnly(boolean) - Method in class com.sleepycat.persist.StoreConfig
Sets the read-only configuration property.
setReadOnlyVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setReadOnlyVoid(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
 
setReadOnlyVoid(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setReadUncommitted(DatabaseConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setReadUncommitted(boolean) - Method in class com.sleepycat.je.CursorConfig
Configures read operations performed by the cursor to return modified but not yet committed data.
setReadUncommitted(boolean) - Method in class com.sleepycat.je.TransactionConfig
Configures read operations performed by the transaction to return modified but not yet committed data.
setReadUncommittedVoid(boolean) - Method in class com.sleepycat.je.CursorConfig
 
setReadUncommittedVoid(boolean) - Method in class com.sleepycat.je.TransactionConfig
 
setRecalcToggle(boolean) - Method in class com.sleepycat.je.tree.IN
 
setRecalculate(boolean) - Method in class com.sleepycat.je.util.DbSpace
 
setReceiveBufferSize(int) - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
Sets the size of the receive buffer associated with the socket used to transfer files during the NetworkRestore operation.
setReceiveBufferSizeVoid(int) - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
 
setReconnectDelay(int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setReconnectDelayVoid(int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setRecordLength(DatabaseConfig, int) - Static method in class com.sleepycat.compat.DbCompat
 
setRecordNumber(DatabaseEntry, int) - Static method in class com.sleepycat.compat.DbCompat
 
setRecordPad(DatabaseConfig, int) - Static method in class com.sleepycat.compat.DbCompat
 
setRecoveryInfo(RecoveryInfo) - Method in class com.sleepycat.je.dbi.StartupTracker
 
setRecoveryProgressListener(ProgressListener<RecoveryProgress>) - Method in class com.sleepycat.je.EnvironmentConfig
Configure the environment to make periodic calls to a ProgressListener to provide feedback on environment startup (recovery).
setRecoveryProgressListenerVoid(ProgressListener<RecoveryProgress>) - Method in class com.sleepycat.je.EnvironmentConfig
 
setReference(Reference) - Method in class com.sleepycat.je.jca.ra.JEConnectionFactoryImpl
 
setRefreshAll(boolean) - Method in class com.sleepycat.je.sync.ImportConfig
 
setRemoteBeginData(byte[]) - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
setRemoteBeginKey(byte[]) - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
setRemoteDiffSize(long) - Method in class com.sleepycat.je.rep.util.ldiff.MismatchedRegion
 
setRemoved(boolean) - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
setRemoveHook(TestHook) - Method in class com.sleepycat.je.sync.SyncProcessor
 
setRenumbering(DatabaseConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setRepContext(ReplicationContext) - Method in class com.sleepycat.je.rep.txn.ReplayTxn
ReplicatedTxns set it when the txn commit or abort arrives.
setRepeatIteratorReads(long) - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
 
setReplayHook(TestHook<BinaryProtocol.Message>) - Method in class com.sleepycat.je.rep.impl.node.Replica
Sets a test hook which is executed in the reply loop.
setReplicaAckTimeout(long, TimeUnit) - Method in class com.sleepycat.je.rep.ReplicationConfig
Set the replica commit timeout.
setReplicaAckTimeoutVoid(long, TimeUnit) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setReplicaFeederSyncupHook(ReplicaFeederSyncup.TestHook<Object>) - Method in class com.sleepycat.je.rep.impl.node.Replica
Set a test hook which is executed when the ReplicaFeederSyncup finishes.
setReplicated(boolean) - Method in class com.sleepycat.je.DatabaseConfig
For internal use only.
setReplicated(DatabaseConfig, boolean) - Static method in class com.sleepycat.je.DbInternal
 
setReplicated(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setReplicatedVoid(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setReplicaType(ReplicaFactory.ReplicaType) - Static method in class com.sleepycat.je.rep.impl.node.ReplicaFactory
 
setRepMutableConfig(ReplicationMutableConfig) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
setRepMutableConfig(ReplicationMutableConfig) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
 
setRepNodeShutdownException(RuntimeException) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
setResponseMessage(TextProtocol.ResponseMessage) - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
 
setRetainLogFiles(boolean) - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
If true retains obsolete log files, by renaming them instead of deleting them.
setRetainLogFilesVoid(boolean) - Method in class com.sleepycat.je.rep.NetworkRestoreConfig
 
setRetryInterval(long) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Sets the number of milliseconds between ping thread retries.
setRetryIntervalVoid(long) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
setRewriteAllowed() - Method in class com.sleepycat.je.log.LogBuffer
 
setRollback() - Method in class com.sleepycat.je.txn.Txn
 
setRollingChksum(long) - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
setRoot(ChildReference, boolean) - Method in class com.sleepycat.je.tree.Tree
Set the root for the tree.
setRunnableHook(TestHook<Boolean>) - Method in class com.sleepycat.je.evictor.Arbiter
 
setRunnableHook(TestHook<Boolean>) - Method in class com.sleepycat.je.evictor.Evictor
 
setScanIterator(Iterator<IN>) - Method in class com.sleepycat.je.evictor.PrivateSelector
 
setScanIterator(Iterator<IN>) - Method in class com.sleepycat.je.evictor.SharedSelector
 
setScanIterator(Iterator<IN>) - Method in class com.sleepycat.je.evictor.TargetSelector
 
setSearchHook(TestHook) - Method in class com.sleepycat.je.tree.Tree
 
setSecKeyCorrectlyOrdered(String) - Method in class com.sleepycat.persist.impl.ComplexFormat
Called when creating a new secondary database that should have a dup comparator configured.
setSecondaryBulkLoad(boolean) - Method in class com.sleepycat.persist.StoreConfig
Sets the bulk-load-secondaries configuration property.
setSecondaryBulkLoadVoid(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setSecondaryConfig(Class, String, SecondaryConfig) - Method in class com.sleepycat.persist.EntityStore
Configures a secondary database for an entity class and key name using the Berkeley DB engine API.
setSecondaryConfig(Class, String, SecondaryConfig) - Method in class com.sleepycat.persist.impl.Store
 
setSendVersion(String) - Method in class com.sleepycat.je.rep.impl.TextProtocol.Message
 
setSequenceConfig(String, SequenceConfig) - Method in class com.sleepycat.persist.EntityStore
Configures a named key sequence using the Berkeley DB engine API.
setSequenceConfig(String, SequenceConfig) - Method in class com.sleepycat.persist.impl.Store
 
setSerialBufferSize(int) - Method in class com.sleepycat.bind.serial.SerialBase
Sets the initial byte size of the output buffer that is allocated by the default implementation of SerialBase.getSerialOutput(java.lang.Object).
setSerializableIsolation(TransactionConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setSerializableIsolation(boolean) - Method in class com.sleepycat.je.TransactionConfig
Configures this transaction to have serializable (degree 3) isolation.
setSerializableIsolationVoid(boolean) - Method in class com.sleepycat.je.TransactionConfig
 
setSetupTimeout() - Method in class com.sleepycat.je.rep.impl.node.JoinGroupTimeouts
Set the currently active timeout to be the env setup timeout.
setSharedCache(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
If true, the shared cache is used by this environment.
setSharedCacheVoid(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
 
setShowProgressInterval(int) - Method in class com.sleepycat.je.StatsConfig
When the statistics operation is configured to display progress the showProgressInterval is the number of LNs between each progress report.
setShowProgressInterval(int) - Method in class com.sleepycat.je.VerifyConfig
When the verify operation is configured to display progress the showProgressInterval is the number of LNs between each progress report.
setShowProgressIntervalVoid(int) - Method in class com.sleepycat.je.StatsConfig
 
setShowProgressIntervalVoid(int) - Method in class com.sleepycat.je.VerifyConfig
 
setShowProgressStream(PrintStream) - Method in class com.sleepycat.je.StatsConfig
Configures the statistics operation to display progress to the PrintStream argument.
setShowProgressStream(PrintStream) - Method in class com.sleepycat.je.VerifyConfig
Configures the verify operation to display progress to the PrintStream argument.
setShowProgressStreamVoid(PrintStream) - Method in class com.sleepycat.je.StatsConfig
 
setShowProgressStreamVoid(PrintStream) - Method in class com.sleepycat.je.VerifyConfig
 
setSimulateIOException(String, boolean) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
 
setSize(int) - Method in class com.sleepycat.je.DatabaseEntry
Sets the byte size of the data array.
setSkewMs(int) - Static method in class com.sleepycat.je.rep.impl.RepImpl
Used during testing to introduce artificial clock skews.
setSocketConnectTimeout(int) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
Sets the socketConnection timeout, in milliseconds, used when the ping thread attempts to establish a connection with a replication node.
setSocketConnectTimeoutVoid(int) - Method in class com.sleepycat.je.rep.monitor.MonitorConfig
 
setSortedDuplicates(DatabaseConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setSortedDuplicates(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Configures the database to support records with duplicate keys.
setSortedDuplicates() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setSortedDuplicatesVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setSprayAfterNMessagesCount(long) - Static method in class com.sleepycat.je.rep.impl.node.Feeder
 
setStateChangeListener(StateChangeListener) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Sets the listener used to receive asynchronous replication node state change events.
setStats(StartupTracker.Phase, StatGroup) - Method in class com.sleepycat.je.dbi.StartupTracker
Save stats for a given phase.
setStatsInterval(long) - Static method in class com.sleepycat.je.rep.impl.node.ReplicaFactory
 
setStatus(PreloadStatus) - Method in class com.sleepycat.je.PreloadStats
 
setSuperFormat(Format) - Method in class com.sleepycat.persist.impl.Format
Called to set the format of the superclass during initialize().
setSuppressGroupDBUpdates(boolean) - Static method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNUpdater
Used during testing to suppress CBVLSN updates at this node.
setSuspended(boolean) - Method in class com.sleepycat.je.txn.Txn
 
setSync(boolean) - Method in class com.sleepycat.je.TransactionConfig
Configures the transaction to write and synchronously flush the log it when commits.
setSyncAtFileEnd(boolean) - Method in class com.sleepycat.je.log.FileManager
May be used to disable sync at file end to speed unit tests.
setSyncHook(Store.SyncHook) - Static method in class com.sleepycat.persist.impl.Store
For unit testing.
setSyncupProgress(SyncupProgress) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
setSyncupProgress(SyncupProgress, long, long) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
setSyncupProgressListener(ProgressListener<SyncupProgress>) - Method in class com.sleepycat.je.rep.ReplicationConfig
Configure the environment to make periodic calls to a ProgressListener to provide feedback on replication stream sync-up.
setSyncupProgressListenerVoid(ProgressListener<SyncupProgress>) - Method in class com.sleepycat.je.rep.ReplicationConfig
 
setSyncVoid(boolean) - Method in class com.sleepycat.je.TransactionConfig
 
setTarget(int, Node) - Method in class com.sleepycat.je.tree.BIN
Updates the VLSN cache when an LN target is evicted.
setTarget(Node) - Method in class com.sleepycat.je.tree.ChildReference
Sets the target for this ChildReference.
setTarget(int, Node) - Method in class com.sleepycat.je.tree.IN
Sets the idx'th target.
setTargetType(LogEntryType) - Method in class com.sleepycat.je.log.LastFileReader
Tell the reader that we are interested in these kind of entries.
setTargetType(LogEntryType) - Method in class com.sleepycat.je.log.ScavengerFileReader
Tell the reader that we are interested in these kind of entries.
setTemporary(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Sets the temporary database option.
setTemporary(boolean) - Method in class com.sleepycat.persist.StoreConfig
Sets the temporary configuration property.
setTemporaryVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setTemporaryVoid(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setTestBarrier(CyclicBarrier) - Method in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackup
 
setTestDelayMs(int) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
 
setTestDelayMs(int) - Method in class com.sleepycat.je.rep.impl.node.Replica
For unit testing only!
setTestHook(TestHook) - Method in class com.sleepycat.je.dbi.CursorImpl
 
setTestHook(TestHook) - Method in class com.sleepycat.je.util.DbBackup
 
setTestLogVersion(int) - Static method in class com.sleepycat.je.rep.stream.FeederReplicaHandshake
 
setTextFileMode(boolean) - Method in class com.sleepycat.je.util.DbLoad
Sets whether the load data is in text file format.
setThreadTransaction(Transaction) - Method in class com.sleepycat.je.Environment
Sets the transaction associated with this thread if implied transactions are being used.
setTimeOut(long) - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
 
setTimeoutMillis(long) - Method in exception com.sleepycat.je.LockConflictException
 
setTimeoutMs(int) - Method in class com.sleepycat.je.rep.utilint.NamedChannelWithTimeout
Used to modify the timeout associated with the channel.
setTimeouts(RepImpl, DurationConfigParam, DurationConfigParam) - Method in class com.sleepycat.je.rep.impl.TextProtocol
Set the network timeouts associated with uses of this protocol instance.
setTotalLoadBytes(long) - Method in class com.sleepycat.je.util.DbLoad
Used for progress status messages.
setTrackedSummary(TrackedFileSummary) - Method in class com.sleepycat.je.tree.FileSummaryLN
Sets the live summary object that will be added to the base summary at the time the LN is logged.
setTransaction(Transaction) - Method in class com.sleepycat.je.txn.Txn
 
setTransactional(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Encloses the database open within a transaction.
setTransactional(boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Sets the transactional property for the first opened handle.
setTransactional(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
Configures the database environment for transactions.
setTransactional(boolean) - Method in class com.sleepycat.persist.StoreConfig
Sets the transactional configuration property.
setTransactionalVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setTransactionalVoid(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
 
setTransactionalVoid(boolean) - Method in class com.sleepycat.persist.StoreConfig
 
setTransactionConfig(TransactionConfig) - Method in class com.sleepycat.collections.TransactionRunner
setTransactionTimeout(int) - Method in class com.sleepycat.je.XAEnvironment
 
setTree(Tree) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
setTreeStats(StatGroup) - Method in class com.sleepycat.je.BtreeStats
 
setTreeStatsAccumulator(TreeWalkerStatsAccumulator) - Method in class com.sleepycat.je.dbi.CursorImpl
 
setTreeStatsAccumulator(TreeWalkerStatsAccumulator) - Method in class com.sleepycat.je.tree.Tree
 
setTriggers(List<Trigger>) - Method in class com.sleepycat.je.DatabaseConfig
 
setTriggers(Locker, String, List<Trigger>, boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Sets the list of triggers associated with the database.
setTriggers(List<Trigger>) - Method in class com.sleepycat.je.SecondaryConfig
 
setTriggersVoid(List<Trigger>) - Method in class com.sleepycat.je.DatabaseConfig
 
setTruncateOldDbId(DatabaseId) - Method in class com.sleepycat.je.log.DbOpReplicationContext
 
setTupleBufferSize(int) - Method in class com.sleepycat.bind.tuple.TupleBase
Sets the initial byte size of the output buffer that is allocated by the default implementation of TupleBase.getTupleOutput(E).
setTxnForThread(Transaction) - Method in class com.sleepycat.je.txn.TxnManager
Called when txn is assoc'd with this thread.
setTxnNoSync(boolean) - Method in class com.sleepycat.je.EnvironmentMutableConfig
setTxnNoSyncVoid(boolean) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setTxnReadCommitted(EnvironmentConfig, boolean) - Static method in class com.sleepycat.je.DbInternal
Proxy to EnvironmentConfig.setTxnReadCommitted()
setTxnReadCommitted(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
For unit testing, sets readCommitted as the default.
setTxnSerializableIsolation(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
Configures all transactions for this environment to have Serializable (Degree 3) isolation.
setTxnSerializableIsolationVoid(boolean) - Method in class com.sleepycat.je.EnvironmentConfig
 
setTxnTimeout(long, TimeUnit) - Method in class com.sleepycat.je.EnvironmentConfig
Configures the transaction timeout.
setTxnTimeout(long) - Method in class com.sleepycat.je.EnvironmentConfig
Deprecated.
setTxnTimeout(long, TimeUnit) - Method in class com.sleepycat.je.Transaction
Configures the timeout value for the transaction lifetime.
setTxnTimeout(long) - Method in class com.sleepycat.je.Transaction
Deprecated.
setTxnTimeout(long) - Method in class com.sleepycat.je.txn.BuddyLocker
Sets the transaction timeout of the buddy locker, since this locker has no independent timeout.
setTxnTimeout(long) - Method in class com.sleepycat.je.txn.Locker
Set the timeout period for this transaction, in milliseconds.
setTxnTimeoutVoid(long, TimeUnit) - Method in class com.sleepycat.je.EnvironmentConfig
 
setTxnTimeoutVoid(long) - Method in class com.sleepycat.je.EnvironmentConfig
 
setTxnWriteNoSync(boolean) - Method in class com.sleepycat.je.EnvironmentMutableConfig
setTxnWriteNoSyncVoid(boolean) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setTypeBtree(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
setTypeHash(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
setTypeQueue(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
setTypeRecno(DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
 
setUnsortedDuplicates(DatabaseConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setUnused(boolean) - Method in class com.sleepycat.persist.impl.Format
Called by the Evolver for a format that is never referenced.
setupClose(PrintWriter) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Release any resources from a subclass that need to be released before close is called on regular environment components.
setupClose(PrintWriter) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
setupForAcks(MasterTxn) - Method in class com.sleepycat.je.rep.stream.FeederTxns
Create a new TxnInfo so that transaction commit can wait onthe latch it sets up.
setUpgrade(LockType) - Method in class com.sleepycat.je.txn.LockUpgrade
 
setupHardRecovery(VLSNRange) - Method in class com.sleepycat.je.rep.stream.ReplicaFeederSyncup
Hard recovery: truncate the files, repeat recovery.
setupRepConfig(File, RepConfigProxy, EnvironmentConfig) - Method in class com.sleepycat.je.Environment
 
setupRepConfig(File, RepConfigProxy, EnvironmentConfig) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
 
setURL(String) - Method in class com.sleepycat.je.sync.jdbc.JDBCConnectionConfig
 
setURL(String) - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
setUseExistingConfig(boolean) - Method in class com.sleepycat.je.DatabaseConfig
Setting useExistingConfig to true allows a program to open a database without knowing a prior what its configuration is.
setUseExistingConfig(DatabaseConfig, boolean) - Static method in class com.sleepycat.je.DbInternal
Proxy to DatabaseConfig.setUseExistingConfig()
setUseExistingConfigVoid(boolean) - Method in class com.sleepycat.je.DatabaseConfig
 
setUserName(String) - Method in class com.sleepycat.je.sync.mobile.MobileConnectionConfig
 
setUUID(UUID) - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Sets the UUID.
setVal(Properties, ConfigParam, String, boolean) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for environment and replication configuration classes.
setVal(Properties, ConfigParam, String, String, boolean) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Helper method for environment and replication configuration classes.
setValidateParams(boolean) - Method in class com.sleepycat.je.EnvironmentMutableConfig
 
setValue(V) - Method in class com.sleepycat.collections.MapEntryParameter
Always throws UnsupportedOperationException since this object is not attached to a map.
setValue(Object) - Method in class com.sleepycat.collections.StoredMapEntry
 
setValueInternal(V) - Method in class com.sleepycat.collections.MapEntryParameter
 
setVerbose(boolean) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Configure whether or not the operation will output information on its success or failure.
setVerbose(boolean) - Method in class com.sleepycat.persist.model.ClassEnhancer
Sets verbose mode.
setVerbose(boolean) - Method in class com.sleepycat.persist.model.ClassEnhancerTask
 
setVerboseVoid(boolean) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setVersion(int) - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
setVLSNSequence(long) - Method in class com.sleepycat.je.tree.LN
Called by LogManager after writing an LN with a newly assigned VLSN, and called by LNLogEntry after reading the LN with the VLSN from the log entry header.
setVLSNSequence(long) - Method in class com.sleepycat.je.tree.VersionedLN
 
setWaiterTxnIds(long[]) - Method in exception com.sleepycat.je.LockConflictException
 
setWaitHook(TestHook) - Method in class com.sleepycat.je.sync.impl.LogChangeReader
 
setWaitHook(TestHook) - Method in class com.sleepycat.je.tree.Tree
 
setWaitIfBusy(boolean, int, int) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
Configure whether or not the operation should wait for the remote service to become available, if the remote service is busy.
setWaitIfBusyVoid(boolean) - Method in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
setWaitingFor(Lock) - Method in class com.sleepycat.je.txn.Locker
 
setWrap(boolean) - Method in class com.sleepycat.je.SequenceConfig
Specifies that the sequence should wrap around when it is incremented (decremented) past the specified maximum (minimum) value.
setWrapperFormat(SimpleFormat) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
setWrapVoid(boolean) - Method in class com.sleepycat.je.SequenceConfig
 
setWriteCursor(CursorConfig, boolean) - Static method in class com.sleepycat.compat.DbCompat
 
setWriteNoSync(boolean) - Method in class com.sleepycat.je.TransactionConfig
setWriteNoSyncVoid(boolean) - Method in class com.sleepycat.je.TransactionConfig
 
setXATransaction(Xid, Transaction) - Method in class com.sleepycat.je.XAEnvironment
Used to set the Transaction object for an XA Xid.
severe(Logger, EnvironmentImpl, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
SHARED_CACHE - Static variable in class com.sleepycat.je.EnvironmentConfig
The SharedCache property.
SharedEvictor - Class in com.sleepycat.je.evictor
Create an evictor for a shared cache.
SharedEvictor(EnvironmentImpl) - Constructor for class com.sleepycat.je.evictor.SharedEvictor
 
SharedLatch - Class in com.sleepycat.je.latch
Simple thread-based non-transactional reader-writer/shared-exclusive latch.
SharedLatch(String) - Constructor for class com.sleepycat.je.latch.SharedLatch
 
SharedSelector - Class in com.sleepycat.je.evictor
A shared cache is really a way of processing the caches of multiple environments.
SharedSelector(EnvironmentImpl) - Constructor for class com.sleepycat.je.evictor.SharedSelector
 
sharesLocksWith(Locker) - Method in class com.sleepycat.je.txn.BuddyLocker
Returns whether this locker can share locks with the given locker.
sharesLocksWith(Locker) - Method in class com.sleepycat.je.txn.HandleLocker
Returns whether this locker can share locks with the given locker.
sharesLocksWith(Locker) - Method in class com.sleepycat.je.txn.Locker
Returns whether this locker can share locks with the given locker.
sharesLocksWith(Locker) - Method in class com.sleepycat.je.txn.ThreadLocker
Returns whether this locker can share locks with the given locker.
SHORT - Static variable in class com.sleepycat.asm.Frame
The SHORT type.
SHORT - Static variable in class com.sleepycat.asm.Type
The sort of the short type.
SHORT_BYTES - Static variable in class com.sleepycat.je.log.LogUtils
 
SHORT_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of instructions with an signed short argument.
SHORT_TYPE - Static variable in class com.sleepycat.asm.Type
The short type.
shortArraySize(int) - Static method in class com.sleepycat.je.dbi.MemoryBudget
 
ShortBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a Short primitive wrapper or a short primitive.
ShortBinding() - Constructor for class com.sleepycat.bind.tuple.ShortBinding
 
shortClassName() - Method in class com.sleepycat.je.tree.BIN
 
shortClassName() - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
shortClassName() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
shortClassName() - Method in class com.sleepycat.je.tree.IN
 
ShortConfigParam - Class in com.sleepycat.je.config
A JE configuration parameter with an short value.
ShortConfigParam(String, Short, Short, Short, boolean, boolean) - Constructor for class com.sleepycat.je.config.ShortConfigParam
 
shortenFromEnd(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
shortenFromHead(VLSN) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
shortToEntry(short, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.ShortBinding
Converts a simple short value into an entry buffer.
shouldLogDelta() - Method in class com.sleepycat.je.tree.BIN
Decide whether to log a full or partial BIN, depending on the ratio of the delta size to full BIN size, and the number of deltas that have been logged since the last full.
shouldPerformProbe(long) - Method in class com.sleepycat.je.cleaner.UtilizationCalculator
Returns whether a correction probe should be attempted, if worst case utilization also indicates that cleaning may be needed.
shouldUpdateLsn(long, long) - Method in class com.sleepycat.je.tree.IN
For a deferred write database, ensure that information is not lost when a new LSN is assigned.
shutdown() - Method in class com.sleepycat.je.cleaner.Cleaner
 
shutdown() - Method in class com.sleepycat.je.evictor.Evictor
Request and wait for a shutdown of all running eviction tasks.
shutdown() - Method in class com.sleepycat.je.rep.elections.ElectionAgentThread
Shuts down the Agent.
shutdown() - Method in class com.sleepycat.je.rep.elections.Elections
Shuts down just the election support at this node.
shutDown() - Method in class com.sleepycat.je.rep.elections.Proposer
Shut down the proposer and reclaim its resources.
SHUTDOWN - Variable in class com.sleepycat.je.rep.elections.Protocol
 
shutdown() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateService
 
shutdown - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
shutdown() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
shutdown() - Method in class com.sleepycat.je.rep.impl.networkRestore.LogFileFeeder
 
shutdown(Exception) - Method in class com.sleepycat.je.rep.impl.node.Feeder
Shutdown the feeder, closing its channel and releasing its threads.
shutdown - Variable in class com.sleepycat.je.rep.impl.node.FeederManager
 
shutdown() - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
Shutdown the consistency tracker.
shutdown() - Method in class com.sleepycat.je.rep.impl.node.Replica
Shutdown the Replica, free any threads that may have been waiting for the replica to reach some degree of consistency.
shutdown() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Used to shutdown all activity associated with this replication stream.
shutdown - Variable in class com.sleepycat.je.rep.monitor.Monitor
 
shutdown() - Method in class com.sleepycat.je.rep.monitor.Monitor
Release monitor resources and shut down the monitor.
shutdown() - Method in class com.sleepycat.je.rep.util.ldiff.LDiffService
 
shutdown() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
Shuts down the dispatcher, so that it's no longer listening for service requests.
shutdown() - Method in interface com.sleepycat.je.utilint.DaemonRunner
 
shutdown() - Method in class com.sleepycat.je.utilint.DaemonThread
Requests shutdown and calls join() to wait for the thread to stop.
SHUTDOWN_REQUEST - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
SHUTDOWN_RESPONSE - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
shutdownAcceptorsLearners(Set<InetSocketAddress>, Set<InetSocketAddress>) - Method in class com.sleepycat.je.rep.elections.Elections
Shutdown all acceptor and learner agents by broadcasting a Shutdown message.
shutdownChannel(NamedChannel) - Static method in class com.sleepycat.je.rep.utilint.RepUtils
Forces a shutdown of the channel ignoring any errors that may be encountered in the process.
shutdownCheckpointer() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
shutdownCleaner() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
public for unit tests.
shutdownDaemons() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Ask all daemon threads to shut down.
shutdownDone() - Method in class com.sleepycat.je.utilint.StoppableThread
Shutdown methods should only be executed once.
shutdownEvictor() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
shutdownFeeder(RepNodeImpl) - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Shuts down a specific feeder.
shutdownGroup(long, TimeUnit) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
Closes this handle and shuts down the Replication Group by forcing all active Replicas to exit.
shutdownGroupOnClose(long) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Must be invoked on the Master via the last open handle.
shutdownGroupSetup(long) - Method in class com.sleepycat.je.rep.impl.RepImpl
Sets up the environment for group shutdown when the environment is closed.
shutdownINCompressor() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
shutdownNetworkBackup() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Shuts down the Network backup service *before* a rollback is initiated as part of syncup, thus ensuring that NetworkRestore does not see an inconsistent set of log files.
shutdownQueue() - Method in class com.sleepycat.je.rep.impl.node.FeederManager
Clears and shuts down the runFeeders by inserting a special EOF marker value into the queue.
shutdownThread(Logger) - Method in class com.sleepycat.je.utilint.StoppableThread
This method is invoked from another thread of control to shutdown this thread.
signature - Variable in class com.sleepycat.asm.MethodWriter
The signature of this method.
SIGNATURES - Static variable in class com.sleepycat.asm.ClassReader
True to enable signatures support.
SimpleCatalog - Class in com.sleepycat.persist.impl
A static catalog containing simple types only.
SimpleCatalog(ClassLoader) - Constructor for class com.sleepycat.persist.impl.SimpleCatalog
 
SimpleFormat - Class in com.sleepycat.persist.impl
Format for simple types, including primitives.
SimpleFormat(Catalog, Class, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat
 
SimpleFormat.FBigDec - Class in com.sleepycat.persist.impl
 
SimpleFormat.FBigDec(Catalog) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FBigDec
 
SimpleFormat.FBigInt - Class in com.sleepycat.persist.impl
 
SimpleFormat.FBigInt(Catalog) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FBigInt
 
SimpleFormat.FBool - Class in com.sleepycat.persist.impl
 
SimpleFormat.FBool(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FBool
 
SimpleFormat.FByte - Class in com.sleepycat.persist.impl
 
SimpleFormat.FByte(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FByte
 
SimpleFormat.FChar - Class in com.sleepycat.persist.impl
 
SimpleFormat.FChar(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FChar
 
SimpleFormat.FDate - Class in com.sleepycat.persist.impl
 
SimpleFormat.FDate(Catalog) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FDate
 
SimpleFormat.FDouble - Class in com.sleepycat.persist.impl
 
SimpleFormat.FDouble(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
SimpleFormat.FFloat - Class in com.sleepycat.persist.impl
 
SimpleFormat.FFloat(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
SimpleFormat.FInt - Class in com.sleepycat.persist.impl
 
SimpleFormat.FInt(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FInt
 
SimpleFormat.FLong - Class in com.sleepycat.persist.impl
 
SimpleFormat.FLong(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FLong
 
SimpleFormat.FShort - Class in com.sleepycat.persist.impl
 
SimpleFormat.FShort(Catalog, boolean) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FShort
 
SimpleFormat.FString - Class in com.sleepycat.persist.impl
 
SimpleFormat.FString(Catalog) - Constructor for class com.sleepycat.persist.impl.SimpleFormat.FString
 
SingleItemEntry - Class in com.sleepycat.je.log.entry
This class embodies log entries that have a single loggable item.
SingleItemEntry(Class<?>) - Constructor for class com.sleepycat.je.log.entry.SingleItemEntry
Construct a log entry for reading.
SingleItemEntry(LogEntryType, Loggable) - Constructor for class com.sleepycat.je.log.entry.SingleItemEntry
Construct a log entry for writing.
singleKey - Variable in class com.sleepycat.util.keyrange.KeyRange
 
singlePassSetInvisible() - Method in class com.sleepycat.je.recovery.RollbackTracker
At the end of a recovery pass, write out all invisible bits, save a set of file numbers to fsync, and reinitialize the per-pass list for the next round.
SIPUSH - Static variable in interface com.sleepycat.asm.Opcodes
 
SIZE - Static variable in class com.sleepycat.asm.Frame
The stack size variation corresponding to each JVM instruction.
size() - Method in class com.sleepycat.collections.StoredCollection
 
size() - Method in class com.sleepycat.collections.StoredContainer
Returns a non-transactional count of the records in the collection or map.
size() - Method in class com.sleepycat.collections.StoredMap
 
size() - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
 
size() - Method in class com.sleepycat.je.cleaner.OffsetList.Segment
Returns the number of values in this segment.
size() - Method in class com.sleepycat.je.cleaner.OffsetList
 
size - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.AverageSize
 
size() - Method in class com.sleepycat.je.rep.util.ldiff.BlockBag
Returns the number of blocks in this bag.
size() - Method in class com.sleepycat.je.rep.util.ldiff.Window
The number of records in the window.
size() - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
size() - Method in class com.sleepycat.je.utilint.TinyHashSet
 
size() - Method in class com.sleepycat.util.FastOutputStream
 
sizeAwait(int, long, TimeUnit) - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
Causes the requesting thread to wait until the map reaches the specified size or the thread is interrupted.
SizeAwaitMap<K,V> - Class in com.sleepycat.je.rep.utilint
Creates a Map, that Threads can conveniently wait on to reach a specific size.
SizeAwaitMap(EnvironmentImpl, Map<K, V>) - Constructor for class com.sleepycat.je.rep.utilint.SizeAwaitMap
Creates the wrapped Map class.
SizeAwaitMapStatDefinition - Class in com.sleepycat.je.rep.utilint
Per-stat Metadata for each SizeAwaitMap statistics.
SizeAwaitMapStatDefinition() - Constructor for class com.sleepycat.je.rep.utilint.SizeAwaitMapStatDefinition
 
sizedOutput() - Static method in class com.sleepycat.bind.tuple.DoubleBinding
Returns a tuple output object of the exact size needed, to avoid wasting space when a single primitive is output.
sizedOutput() - Static method in class com.sleepycat.bind.tuple.FloatBinding
Returns a tuple output object of the exact size needed, to avoid wasting space when a single primitive is output.
SizeofMarker - Interface in com.sleepycat.je.utilint
Special marker interface used by Sizeof when performing memory overhead calculations.
skip(boolean, long, RangeConstraint) - Method in class com.sleepycat.je.dbi.CursorImpl
Skips over entries until a boundary condition is satisfied, either because maxCount is reached or RangeConstraint.inBounds returns false.
skip(int) - Method in class com.sleepycat.je.rep.utilint.FreePortLocator
Skip a number of ports.
skip(long) - Method in class com.sleepycat.je.util.LogVerificationInputStream
skip(long) - Method in class com.sleepycat.util.FastInputStream
 
SKIP_CODE - Static variable in class com.sleepycat.asm.ClassReader
Flag to skip method code.
SKIP_COUNT - Static variable in class com.sleepycat.je.rep.impl.networkRestore.NetworkBackupStatDefinition
 
SKIP_DEBUG - Static variable in class com.sleepycat.asm.ClassReader
Flag to skip the debug information in the class.
SKIP_FRAMES - Static variable in class com.sleepycat.asm.ClassReader
Flag to skip the stack map frames in the class.
SKIP_NODENAME_VALIDATION - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.EnumFormat
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.Format
Skips over the object's contents, as if readObject() were called, but without returning an object.
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.NonPersistentFormat
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigDec
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigInt
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDate
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
skipContents(RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FString
 
skipData(int) - Method in class com.sleepycat.je.log.FileReader
 
skipEntry(ByteBuffer) - Method in class com.sleepycat.je.log.FileReader
May be called by processEntry when it determines that the entry does not need to be read/de-serialized.
skipFast(int) - Method in class com.sleepycat.util.FastInputStream
Equivalent to skip() but takes an int parameter instead of a long, and does not check whether the count given is larger than the number of remaining bytes.
skipField(Format) - Method in interface com.sleepycat.persist.impl.EntityInput
Called via PersistKeyCreator to skip fields prior to the secondary key field.
skipField(Format) - Method in class com.sleepycat.persist.impl.RawAbstractInput
 
skipField(Format) - Method in class com.sleepycat.persist.impl.RecordInput
 
skipField(Format) - Method in class com.sleepycat.persist.impl.WidenerInput
 
skipNext(long, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Skips forward a given number of key/data pairs and returns the number by which the cursor is moved.
skipPrev(long, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Skips backward a given number of key/data pairs and returns the number by which the cursor is moved.
skipPrimitiveArray(int, RecordInput) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
skipToSecKey(RecordInput, String) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
skipToSecKey(RecordInput, String) - Method in class com.sleepycat.persist.impl.Format
When extracting a secondary key, called to skip over all fields up to the given secondary key field.
SLEEP_BEFORE_READ_PRIMARY_RETRY - Static variable in class com.sleepycat.je.Cursor
 
sleepAfterBackgroundIO() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
If the sleep backlog is non-zero (set by updateBackgroundReads or updateBackgroundWrites), sleep for the configured interval and decrement the backlog.
slideAndFill(long, long, long, boolean) - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
slideAndFill(long, long, long, boolean) - Method in class com.sleepycat.je.rep.stream.FeederReader.SwitchWindow
 
SNTP_REQUEST - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
SNTP_RESPONSE - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
SortedBigDecimalBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a sorted BigDecimal value.
SortedBigDecimalBinding() - Constructor for class com.sleepycat.bind.tuple.SortedBigDecimalBinding
 
SortedDoubleBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a sorted Double primitive wrapper or a sorted double primitive.
SortedDoubleBinding() - Constructor for class com.sleepycat.bind.tuple.SortedDoubleBinding
 
sortedDups - Variable in class com.sleepycat.persist.BasicIndex
 
SortedFloatBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a sorted Float primitive wrapper or sorted a float primitive.
SortedFloatBinding() - Constructor for class com.sleepycat.bind.tuple.SortedFloatBinding
 
SortedLSNTreeWalker - Class in com.sleepycat.je.dbi
SortedLSNTreeWalker uses ordered disk access rather than random access to iterate over a database tree.
SortedLSNTreeWalker(DatabaseImpl[], boolean, long[], SortedLSNTreeWalker.TreeNodeProcessor, List<DatabaseException>, SortedLSNTreeWalker.ExceptionPredicate) - Constructor for class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
SortedLSNTreeWalker.DeltaINEntry - Class in com.sleepycat.je.dbi
Supplements INEntry with BINDelta information.
SortedLSNTreeWalker.DeltaINEntry(IN, int, BINDelta, long) - Constructor for class com.sleepycat.je.dbi.SortedLSNTreeWalker.DeltaINEntry
 
SortedLSNTreeWalker.DeltaINEntry(SizeofMarker) - Constructor for class com.sleepycat.je.dbi.SortedLSNTreeWalker.DeltaINEntry
 
SortedLSNTreeWalker.ExceptionPredicate - Interface in com.sleepycat.je.dbi
 
SortedLSNTreeWalker.INEntry - Class in com.sleepycat.je.dbi
 
SortedLSNTreeWalker.INEntry(IN, int) - Constructor for class com.sleepycat.je.dbi.SortedLSNTreeWalker.INEntry
 
SortedLSNTreeWalker.INEntry(SizeofMarker) - Constructor for class com.sleepycat.je.dbi.SortedLSNTreeWalker.INEntry
 
SortedLSNTreeWalker.TreeNodeProcessor - Interface in com.sleepycat.je.dbi
 
sortedMap() - Method in interface com.sleepycat.persist.EntityIndex
Returns a standard Java sorted map based on this entity index.
sortedMap() - Method in class com.sleepycat.persist.KeysIndex
 
sortedMap() - Method in class com.sleepycat.persist.PrimaryIndex
 
sortedMap() - Method in class com.sleepycat.persist.SecondaryIndex
 
sortedMap() - Method in class com.sleepycat.persist.SubIndex
 
SortedPackedIntegerBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a sorted Integer primitive wrapper or a sorted int primitive, that stores the value in the smallest number of bytes possible.
SortedPackedIntegerBinding() - Constructor for class com.sleepycat.bind.tuple.SortedPackedIntegerBinding
 
SortedPackedLongBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a sorted Long primitive wrapper or a sorted long primitive, that stores the value in the smallest number of bytes possible.
SortedPackedLongBinding() - Constructor for class com.sleepycat.bind.tuple.SortedPackedLongBinding
 
SPARSE_TARGET_ENTRY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
specialEviction() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Performs special eviction (eviction other than standard IN eviction) for this environment.
specialEvictionBytes - Variable in class com.sleepycat.je.evictor.TargetSelector.SetupInfo
 
split(DatabaseEntry, DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.je.dbi.DupKeyData
Splits twoPartKey, previously set by combine, into original paramKey and paramData if they are non-null.
split(byte[], int, DatabaseEntry, DatabaseEntry) - Static method in class com.sleepycat.je.dbi.DupKeyData
Same as split method above, but with twoPartKey/twoPartKeySize byte array and array size params.
split(IN, int, int, CacheMode) - Method in class com.sleepycat.je.tree.IN
Split this into two nodes.
splitInternal(IN, int, int, int, CacheMode) - Method in class com.sleepycat.je.tree.IN
 
SplitRequiredException - Exception in com.sleepycat.je.tree
Indicates that we need to return to the top of the tree in order to do a forced splitting pass.
SplitRequiredException() - Constructor for exception com.sleepycat.je.tree.SplitRequiredException
 
splitSpecial(IN, int, int, byte[], boolean, CacheMode) - Method in class com.sleepycat.je.tree.BIN
Called when we know we are about to split on behalf of a key that is the minimum (leftSide) or maximum (!leftSide) of this node.
splitSpecial(IN, int, int, byte[], boolean, CacheMode) - Method in class com.sleepycat.je.tree.IN
Called when we know we are about to split on behalf of a key that is the minimum (leftSide) or maximum (!leftSide) of this node.
stampRepWriteTime() - Method in class com.sleepycat.je.rep.txn.MasterTxn
 
start - Variable in class com.sleepycat.asm.Handler
Beginning of the exception handler's scope (inclusive).
start(StartupTracker.Phase) - Method in class com.sleepycat.je.dbi.StartupTracker
Note that a particular phase is starting.
start(Xid, int) - Method in class com.sleepycat.je.XAEnvironment
 
start() - Method in class com.sleepycat.utilint.ActivityCounter
 
START_STREAM - Static variable in class com.sleepycat.je.rep.stream.Protocol
 
startAndFinishDelete() - Method in class com.sleepycat.je.dbi.DatabaseImpl
Perform the entire two-step database deletion.
startBackup() - Method in class com.sleepycat.je.util.DbBackup
Start backup mode in order to determine the definitive backup set needed at this point in time.
startBatch(boolean) - Method in class com.sleepycat.je.evictor.PrivateSelector
Initializes the iterator, and performs special eviction once per batch.
startBatch(boolean) - Method in class com.sleepycat.je.evictor.SharedSelector
Initializes the sizes if needed, and performs special eviction for one environment in rotatation.
startBatch(boolean) - Method in class com.sleepycat.je.evictor.TargetSelector
Must be synchronized! Perform class-specific batch pre-batch processing: Initialize iterator, and do special eviction (UtilizationTracker eviction) if suitable.
startCkptLsn - Variable in class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
startDeleteProcessing() - Method in class com.sleepycat.je.dbi.DatabaseImpl
The delete cleanup is starting.
startFeederThreads() - Method in class com.sleepycat.je.rep.impl.node.Feeder
 
startLearner() - Method in class com.sleepycat.je.rep.elections.Elections
Starts a Learner agent.
startListener(MonitorChangeListener) - Method in class com.sleepycat.je.rep.monitor.Monitor
Starts the listener so it's actively listening for election results and broadcasts of replication group changes.
startLsn - Variable in class com.sleepycat.je.log.FileReader
 
startOffset - Variable in class com.sleepycat.je.log.FileReader.ReadWindow
 
STARTUP_DUMP_THRESHOLD - Static variable in class com.sleepycat.je.config.EnvironmentParams
If environment startup exceeds this duration, startup statistics are logged and can be found in the je.info file.
STARTUP_DUMP_THRESHOLD - Static variable in class com.sleepycat.je.EnvironmentConfig
If environment startup exceeds this duration, startup statistics are logged and can be found in the je.info file.
startupTracker - Variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
StartupTracker - Class in com.sleepycat.je.dbi
Store and calculate elapsed time, counts, and other statistics about environment open.
StartupTracker(EnvironmentImpl) - Constructor for class com.sleepycat.je.dbi.StartupTracker
 
StartupTracker.Counter - Class in com.sleepycat.je.dbi
Record number of log entries processed during a given recovery phase.
StartupTracker.Counter() - Constructor for class com.sleepycat.je.dbi.StartupTracker.Counter
 
StartupTracker.Phase - Enum in com.sleepycat.je.dbi
 
stat(StatsConfig) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
Stat<T> - Class in com.sleepycat.je.utilint
Base class for all JE statistics.
Stat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.Stat
A stat registers itself with an owning group.
StatDefinition - Class in com.sleepycat.je.utilint
Per-stat Metadata for JE statistics.
StatDefinition(String, String) - Constructor for class com.sleepycat.je.utilint.StatDefinition
 
stateChange(StateChangeEvent) - Method in interface com.sleepycat.je.rep.StateChangeListener
The notification method.
StateChangeEvent - Class in com.sleepycat.je.rep
Communicates the state change at a node to the StateChangeListener.
StateChangeEvent(ReplicatedEnvironment.State, NameIdPair) - Constructor for class com.sleepycat.je.rep.StateChangeEvent
 
StateChangeException - Exception in com.sleepycat.je.rep
Provides a synchronous mechanism for informing an application about a change in the state of the replication node.
StateChangeException(Locker, StateChangeEvent) - Constructor for exception com.sleepycat.je.rep.StateChangeException
For internal use only.
StateChangeException(String, Exception) - Constructor for exception com.sleepycat.je.rep.StateChangeException
Used when no state change event is available
StateChangeException(String, StateChangeException) - Constructor for exception com.sleepycat.je.rep.StateChangeException
For internal use only.
StateChangeListener - Interface in com.sleepycat.je.rep
An asynchronous mechanism for tracking the State of the replicated environment and choosing how to route database operations.
StatGroup - Class in com.sleepycat.je.utilint
The Stats infrastructure provides context for JE statistics.
StatGroup(String, String) - Constructor for class com.sleepycat.je.utilint.StatGroup
 
statParams - Static variable in class com.sleepycat.je.jmx.JEMBean
 
statResponses - Variable in class com.sleepycat.je.rep.impl.networkRestore.FeederManager
 
stats - Variable in class com.sleepycat.je.cleaner.Cleaner
 
stats - Variable in class com.sleepycat.je.evictor.TargetSelector
 
Stats - Class in com.sleepycat.je.jmx.plugin
 
Stats(MBeanServerConnection) - Constructor for class com.sleepycat.je.jmx.plugin.Stats
 
stats - Variable in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
stats - Variable in class com.sleepycat.je.log.FileManager
 
stats - Variable in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
stats(PrintStream) - Method in class com.sleepycat.je.util.DbStat
 
Stats.StatsTableModel - Class in com.sleepycat.je.jmx.plugin
 
Stats.StatsTableModel() - Constructor for class com.sleepycat.je.jmx.plugin.Stats.StatsTableModel
 
StatsConfig - Class in com.sleepycat.je
Specifies the attributes of a statistics retrieval operation.
StatsConfig() - Constructor for class com.sleepycat.je.StatsConfig
An instance created using the default constructor is initialized with the system's default settings.
StatsConfigBeanInfo - Class in com.sleepycat.je
 
StatsConfigBeanInfo() - Constructor for class com.sleepycat.je.StatsConfigBeanInfo
 
StatsFileReader - Class in com.sleepycat.je.log
The StatsFileReader generates stats about the log entries read, such as the count of each type of entry, the number of bytes, minimum and maximum sized log entry.
StatsFileReader(EnvironmentImpl, int, long, long, long, String, String, boolean, boolean, boolean) - Constructor for class com.sleepycat.je.log.StatsFileReader
Create this reader to start at a given LSN.
StatsFileReader.CheckpointCounter - Class in com.sleepycat.je.log
 
StatsFileReader.CheckpointCounter() - Constructor for class com.sleepycat.je.log.StatsFileReader.CheckpointCounter
 
StatsFileReader.CheckpointInfoCSVFormatter - Class in com.sleepycat.je.log
 
StatsFileReader.CheckpointInfoCSVFormatter() - Constructor for class com.sleepycat.je.log.StatsFileReader.CheckpointInfoCSVFormatter
 
StatsFileReader.CheckpointInfoTextFormatter - Class in com.sleepycat.je.log
 
StatsFileReader.CheckpointInfoTextFormatter() - Constructor for class com.sleepycat.je.log.StatsFileReader.CheckpointInfoTextFormatter
 
StatsFileReader.CheckpointInfoTextFormatter(NumberFormat) - Constructor for class com.sleepycat.je.log.StatsFileReader.CheckpointInfoTextFormatter
 
StatsFileReader.EntryInfo - Class in com.sleepycat.je.log
 
StatsFileReader.EntryInfo() - Constructor for class com.sleepycat.je.log.StatsFileReader.EntryInfo
 
StatsFileReader.LogEntryTypeComparator - Class in com.sleepycat.je.log
 
StatsFileReader.LogEntryTypeComparator() - Constructor for class com.sleepycat.je.log.StatsFileReader.LogEntryTypeComparator
 
StatsPlugin - Class in com.sleepycat.je.jmx.plugin
 
StatsPlugin() - Constructor for class com.sleepycat.je.jmx.plugin.StatsPlugin
 
StatsSwingWorker - Class in com.sleepycat.je.jmx.plugin
 
StatsSwingWorker(ArrayList<Stats>) - Constructor for class com.sleepycat.je.jmx.plugin.StatsSwingWorker
 
statsTitles - Variable in class com.sleepycat.je.jmx.plugin.Stats
 
StatsTracker<T> - Class in com.sleepycat.utilint
Maintain interval and cumulative stats for a given set of operations, as well as a activityCounter that generates thread dumps if operations take too long.
StatsTracker(T[], Logger, int, long, int, int) - Constructor for class com.sleepycat.utilint.StatsTracker
The logger is used for activity stack traces.
status - Variable in class com.sleepycat.asm.Label
Flags that indicate the status of this label.
stealLock(Long, Locker, LockType, MemoryBudget) - Method in class com.sleepycat.je.txn.DummyLockManager
 
stealLock(Locker, MemoryBudget, int) - Method in interface com.sleepycat.je.txn.Lock
Removes all owners except for the given owner, and sets the Preempted property on the removed owners.
stealLock(Locker, MemoryBudget, int) - Method in class com.sleepycat.je.txn.LockImpl
 
stealLock(Long, Locker, LockType, MemoryBudget) - Method in class com.sleepycat.je.txn.LockManager
 
stealLock(Long, Locker, LockType, MemoryBudget) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
stealLock(Locker, MemoryBudget, int) - Method in class com.sleepycat.je.txn.ThinLockImpl
 
stealLockInternal(Long, Locker, LockType, MemoryBudget, int) - Method in class com.sleepycat.je.txn.LockManager
 
STIFLE_DEFAULT_ERROR_MANAGER - Static variable in class com.sleepycat.je.util.FileHandler
 
stifleExceptionChatter - Static variable in class com.sleepycat.je.utilint.DaemonThread
 
stillNeedsEviction() - Method in class com.sleepycat.je.evictor.Arbiter
Do a check on whether the cache should still be subject to eviction.
stop(StartupTracker.Phase) - Method in class com.sleepycat.je.dbi.StartupTracker
Note that a particular phase is ending.
STOP_ON_WRITE_COUNT - Static variable in class com.sleepycat.je.log.FileManager
 
stopDaemons() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
For unit testing -- shuts down daemons completely but leaves environment usable since environment references are not nulled out.
StoppableThread - Class in com.sleepycat.je.utilint
A StoppableThread is a daemon that obeys the following mandates: - it sets the daemon property for the thread - an uncaught exception handler is always registered - the thread registers with the JE exception listener mechanism.
StoppableThread(String) - Constructor for class com.sleepycat.je.utilint.StoppableThread
 
StoppableThread(EnvironmentImpl, String) - Constructor for class com.sleepycat.je.utilint.StoppableThread
 
StoppableThread(EnvironmentImpl, Thread.UncaughtExceptionHandler, String) - Constructor for class com.sleepycat.je.utilint.StoppableThread
 
StoppableThread(EnvironmentImpl, Thread.UncaughtExceptionHandler, Runnable, String) - Constructor for class com.sleepycat.je.utilint.StoppableThread
 
StoppableThreadFactory - Class in com.sleepycat.je.utilint
Create a thread factory that returns threads that are legitimate StoppableThreads.
StoppableThreadFactory(EnvironmentImpl, String, Logger) - Constructor for class com.sleepycat.je.utilint.StoppableThreadFactory
This kind of StoppableThreadFactory will cause invalidation if an unhandled exception occurs.
StoppableThreadFactory(String, Logger) - Constructor for class com.sleepycat.je.utilint.StoppableThreadFactory
This kind of StoppableThreadFactory will NOT cause invalidation if an unhandled exception occurs, because there is no environment provided.
STORE - Static variable in class com.sleepycat.asm.Label
Indicates if a stack map frame must be stored for this label.
Store - Class in com.sleepycat.persist.impl
Base implementation for EntityStore and RawStore.
Store(Environment, String, StoreConfig, boolean) - Constructor for class com.sleepycat.persist.impl.Store
 
Store.SyncHook - Interface in com.sleepycat.persist.impl
For unit testing.
StoreConfig - Class in com.sleepycat.persist
Configuration properties used with an EntityStore or RawStore.
StoreConfig() - Constructor for class com.sleepycat.persist.StoreConfig
Creates an entity store configuration object with default properties.
StoreConfigBeanInfo - Class in com.sleepycat.persist
 
StoreConfigBeanInfo() - Constructor for class com.sleepycat.persist.StoreConfigBeanInfo
 
StoredClassCatalog - Class in com.sleepycat.bind.serial
A ClassCatalog that is stored in a Database.
StoredClassCatalog(Database) - Constructor for class com.sleepycat.bind.serial.StoredClassCatalog
Creates a catalog based on a given database.
StoredCollection<E> - Class in com.sleepycat.collections
A abstract base class for all stored collections.
StoredCollection(DataView) - Constructor for class com.sleepycat.collections.StoredCollection
 
StoredCollections - Class in com.sleepycat.collections
Static methods operating on collections and maps.
StoredContainer - Class in com.sleepycat.collections
A abstract base class for all stored collections and maps.
StoredContainer(DataView) - Constructor for class com.sleepycat.collections.StoredContainer
 
StoredEntrySet<K,V> - Class in com.sleepycat.collections
The Set returned by Map.entrySet().
StoredEntrySet(DataView) - Constructor for class com.sleepycat.collections.StoredEntrySet
 
storedIterator() - Method in class com.sleepycat.collections.StoredCollection
Returns an iterator over the elements in this collection.
storedIterator(boolean) - Method in class com.sleepycat.collections.StoredCollection
Returns a read or read-write iterator over the elements in this collection.
StoredIterator<E> - Class in com.sleepycat.collections
The Iterator returned by all stored collections.
StoredIterator(StoredCollection<E>, boolean, DataCursor) - Constructor for class com.sleepycat.collections.StoredIterator
 
StoredKeySet<K> - Class in com.sleepycat.collections
The Set returned by Map.keySet() and which can also be constructed directly if a Map is not needed.
StoredKeySet(Database, EntryBinding<K>, boolean) - Constructor for class com.sleepycat.collections.StoredKeySet
Creates a key set view of a Database.
StoredKeySet(DataView) - Constructor for class com.sleepycat.collections.StoredKeySet
 
StoredList<E> - Class in com.sleepycat.collections
 
StoredList(Database, EntryBinding<E>, boolean) - Constructor for class com.sleepycat.collections.StoredList
Creates a list view of a Database.
StoredList(Database, EntityBinding<E>, boolean) - Constructor for class com.sleepycat.collections.StoredList
Creates a list entity view of a Database.
StoredList(Database, EntryBinding<E>, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.StoredList
Creates a list view of a Database with a PrimaryKeyAssigner.
StoredList(Database, EntityBinding<E>, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.StoredList
Creates a list entity view of a Database with a PrimaryKeyAssigner.
StoredMap<K,V> - Class in com.sleepycat.collections
A Map view of a Database.
StoredMap(Database, EntryBinding<K>, EntryBinding<V>, boolean) - Constructor for class com.sleepycat.collections.StoredMap
Creates a map view of a Database.
StoredMap(Database, EntryBinding<K>, EntryBinding<V>, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.StoredMap
Creates a map view of a Database with a PrimaryKeyAssigner.
StoredMap(Database, EntryBinding<K>, EntityBinding<V>, boolean) - Constructor for class com.sleepycat.collections.StoredMap
Creates a map entity view of a Database.
StoredMap(Database, EntryBinding<K>, EntityBinding<V>, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.StoredMap
Creates a map entity view of a Database with a PrimaryKeyAssigner.
StoredMap(DataView) - Constructor for class com.sleepycat.collections.StoredMap
 
StoredMapEntry - Class in com.sleepycat.collections
 
StoredMapEntry(Object, Object, StoredCollection, BaseIterator) - Constructor for class com.sleepycat.collections.StoredMapEntry
 
StoredModel - Class in com.sleepycat.persist.impl
The EntityModel used when a RawStore is opened.
StoredModel(PersistCatalog) - Constructor for class com.sleepycat.persist.impl.StoredModel
 
storedOrExternalIterator(Collection) - Method in class com.sleepycat.collections.StoredContainer
Returns a StoredIterator if the given collection is a StoredCollection, else returns a regular/external Iterator.
storedOrExternalListIterator(List) - Method in class com.sleepycat.collections.StoredList
Returns a StoredIterator if the given collection is a StoredCollection, else returns a regular/external ListIterator.
StoredSortedEntrySet<K,V> - Class in com.sleepycat.collections
The SortedSet returned by Map.entrySet().
StoredSortedEntrySet(DataView) - Constructor for class com.sleepycat.collections.StoredSortedEntrySet
 
StoredSortedKeySet<K> - Class in com.sleepycat.collections
The SortedSet returned by Map.keySet() and which can also be constructed directly if a Map is not needed.
StoredSortedKeySet(Database, EntryBinding<K>, boolean) - Constructor for class com.sleepycat.collections.StoredSortedKeySet
Creates a sorted key set view of a Database.
StoredSortedKeySet(DataView) - Constructor for class com.sleepycat.collections.StoredSortedKeySet
 
StoredSortedMap<K,V> - Class in com.sleepycat.collections
A SortedMap view of a Database.
StoredSortedMap(Database, EntryBinding<K>, EntryBinding<V>, boolean) - Constructor for class com.sleepycat.collections.StoredSortedMap
Creates a sorted map view of a Database.
StoredSortedMap(Database, EntryBinding<K>, EntryBinding<V>, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.StoredSortedMap
Creates a sorted map view of a Database with a PrimaryKeyAssigner.
StoredSortedMap(Database, EntryBinding<K>, EntityBinding<V>, boolean) - Constructor for class com.sleepycat.collections.StoredSortedMap
Creates a sorted map entity view of a Database.
StoredSortedMap(Database, EntryBinding<K>, EntityBinding<V>, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.StoredSortedMap
Creates a sorted map entity view of a Database with a PrimaryKeyAssigner.
StoredSortedMap(DataView) - Constructor for class com.sleepycat.collections.StoredSortedMap
 
StoredSortedValueSet<E> - Class in com.sleepycat.collections
The SortedSet returned by Map.values() and which can also be constructed directly if a Map is not needed.
StoredSortedValueSet(Database, EntityBinding<E>, boolean) - Constructor for class com.sleepycat.collections.StoredSortedValueSet
Creates a sorted value set entity view of a Database.
StoredSortedValueSet(DataView) - Constructor for class com.sleepycat.collections.StoredSortedValueSet
 
StoredValueSet<E> - Class in com.sleepycat.collections
The Set returned by Map.values() and Map.duplicates(), and which can also be constructed directly if a Map is not needed.
StoredValueSet(Database, EntryBinding<E>, boolean) - Constructor for class com.sleepycat.collections.StoredValueSet
Creates a value set view of a Database.
StoredValueSet(Database, EntityBinding<E>, boolean) - Constructor for class com.sleepycat.collections.StoredValueSet
Creates a value set entity view of a Database.
StoredValueSet(DataView) - Constructor for class com.sleepycat.collections.StoredValueSet
 
StoreExistsException - Exception in com.sleepycat.persist
Thrown by the EntityStore constructor when the ExclusiveCreate configuration parameter is true and the store's internal catalog database already exists.
StoreExistsException(String) - Constructor for exception com.sleepycat.persist.StoreExistsException
For internal use only.
StoreNotFoundException - Exception in com.sleepycat.persist
Thrown by the EntityStore constructor when the AllowCreate configuration parameter is false and the store's internal catalog database does not exist.
StoreNotFoundException(String) - Constructor for exception com.sleepycat.persist.StoreNotFoundException
For internal use only.
STR - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_String constant pool items.
StringBinding - Class in com.sleepycat.bind.tuple
A concrete TupleBinding for a simple String value.
StringBinding() - Constructor for class com.sleepycat.bind.tuple.StringBinding
 
stringSize(String) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
 
StringStat - Class in com.sleepycat.je.utilint
A stat that saves a string; a way to save general information for later display and access.
StringStat(StatGroup, StatDefinition) - Constructor for class com.sleepycat.je.utilint.StringStat
 
StringStat(StatGroup, StatDefinition, String) - Constructor for class com.sleepycat.je.utilint.StringStat
 
stringToBytes(String) - Static method in class com.sleepycat.util.UtfOps
Converts strings to byte arrays.
stringToEntry(String, DatabaseEntry) - Static method in class com.sleepycat.bind.tuple.StringBinding
Converts a simple String value into an entry buffer.
stringToPolicy(String) - Method in interface com.sleepycat.je.rep.utilint.RepUtils.ConsistencyPolicyFormat
 
StringUtils - Class in com.sleepycat.utilint
 
StringUtils() - Constructor for class com.sleepycat.utilint.StringUtils
 
strVal1 - Variable in class com.sleepycat.asm.Item
First part of the value of this item, for items that do not hold a primitive value.
strVal2 - Variable in class com.sleepycat.asm.Item
Second part of the value of this item, for items that do not hold a primitive value.
strVal3 - Variable in class com.sleepycat.asm.Item
Third part of the value of this item, for items that do not hold a primitive value.
subIndex(SK) - Method in class com.sleepycat.persist.SecondaryIndex
Returns an index that maps primary key to entity for the subset of entities having a given secondary key (duplicates).
SubIndex<PK,E> - Class in com.sleepycat.persist
The EntityIndex returned by SecondaryIndex.subIndex.
SubIndex(SecondaryIndex<SK, PK, E>, EntityBinding, SK) - Constructor for class com.sleepycat.persist.SubIndex
 
SubIndexCursor<V> - Class in com.sleepycat.persist
The cursor for a SubIndex treats Dup and NoDup operations specially because the SubIndex never has duplicates -- the keys are primary keys.
SubIndexCursor(RangeCursor, ValueAdapter<V>) - Constructor for class com.sleepycat.persist.SubIndexCursor
 
subList(int, int) - Method in class com.sleepycat.collections.StoredList
Returns a view of the portion of this list between the specified fromIndex, inclusive, and toIndex, exclusive.
subMap(K, K) - Method in class com.sleepycat.collections.StoredSortedMap
Returns a view of the portion of this sorted map whose elements range from fromKey, inclusive, to toKey, exclusive.
subMap(K, boolean, K, boolean) - Method in class com.sleepycat.collections.StoredSortedMap
Returns a view of the portion of this sorted map whose elements are strictly greater than fromKey and strictly less than toKey, optionally including fromKey and toKey.
subRange(KeyRange, Object) - Method in class com.sleepycat.collections.DataView
Intersects the given key and the current range.
subRange(KeyRange, Object, boolean, Object, boolean) - Method in class com.sleepycat.collections.DataView
Intersects the given range and the current range.
subRange(DatabaseEntry) - Method in class com.sleepycat.util.keyrange.KeyRange
Creates a range for a single key.
subRange(DatabaseEntry, boolean, DatabaseEntry, boolean) - Method in class com.sleepycat.util.keyrange.KeyRange
Creates a range that is the intersection of this range and the given range parameters.
SUBROUTINE - Static variable in class com.sleepycat.asm.Label
Indicates if this basic block is the start of a subroutine.
subSet(Map.Entry<K, V>, Map.Entry<K, V>) - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns a view of the portion of this sorted set whose elements range from fromMapEntry, inclusive, to toMapEntry, exclusive.
subSet(Map.Entry<K, V>, boolean, Map.Entry<K, V>, boolean) - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns a view of the portion of this sorted set whose elements are strictly greater than fromMapEntry and strictly less than toMapEntry, optionally including fromMapEntry and toMapEntry.
subSet(K, K) - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns a view of the portion of this sorted set whose elements range from fromKey, inclusive, to toKey, exclusive.
subSet(K, boolean, K, boolean) - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns a view of the portion of this sorted set whose elements are strictly greater than fromKey and strictly less than toKey, optionally including fromKey and toKey.
subSet(E, E) - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns a view of the portion of this sorted set whose elements range from fromValue, inclusive, to toValue, exclusive.
subSet(E, boolean, E, boolean) - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns a view of the portion of this sorted set whose elements are strictly greater than fromValue and strictly less than toValue, optionally including fromValue and toValue.
subtractCacheUsage() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
subtractFromMemoryBudget() - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
 
subView(Object, boolean, Object, boolean, EntryBinding) - Method in class com.sleepycat.collections.DataView
Return a new value-set view for key range, optionally changing the key binding.
SUCCESS - Static variable in class com.sleepycat.je.PreloadStatus
Database.preload was successful.
success - Variable in class com.sleepycat.je.txn.LockAttemptResult
 
successor - Variable in class com.sleepycat.asm.Edge
The successor block of the basic block from which this edge originates.
successor - Variable in class com.sleepycat.asm.Label
The successor of this label, in the order they are visited.
successors - Variable in class com.sleepycat.asm.Label
The successors of this node in the control flow graph.
suffix - Variable in class com.sleepycat.je.log.JEFileFilter
 
summarize(boolean) - Method in class com.sleepycat.je.log.DumpFileReader
 
summarize(boolean) - Method in class com.sleepycat.je.log.StatsFileReader
 
summarize(boolean) - Method in class com.sleepycat.je.log.VLSNDistributionReader
 
SUPPORTED_PARAMS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
SWAP - Static variable in interface com.sleepycat.asm.Opcodes
 
sync() - Method in class com.sleepycat.je.Database
Flushes any cached information for this database to disk; only applicable for deferred-write databases.
sync(boolean) - Method in class com.sleepycat.je.dbi.DatabaseImpl
Flush all dirty nodes for this database to disk.
sync() - Method in class com.sleepycat.je.Environment
Synchronously flushes database environment databases to stable storage.
sync() - Method in class com.sleepycat.je.rep.stream.MasterStatus
Syncs to the group master
sync() - Method in class com.sleepycat.je.rep.utilint.DbSync
Open this replication node.
sync(ExportConfig, ImportConfig, String...) - Method in class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
 
sync(ExportConfig, ImportConfig, String...) - Method in class com.sleepycat.je.sync.mobile.MobileSyncProcessor
 
sync(ExportConfig, ImportConfig, String...) - Method in class com.sleepycat.je.sync.SyncProcessor
Performs a sync operation for the specified SyncDataSets.
sync() - Method in class com.sleepycat.persist.EntityStore
Flushes each modified index to disk that was opened in deferred-write mode.
sync() - Method in class com.sleepycat.persist.impl.Store
 
syncAll(ExportConfig, ImportConfig) - Method in class com.sleepycat.je.sync.jdbc.JDBCSyncProcessor
 
syncAll(ExportConfig, ImportConfig) - Method in class com.sleepycat.je.sync.mobile.MobileSyncProcessor
 
syncAll(ExportConfig, ImportConfig) - Method in class com.sleepycat.je.sync.SyncProcessor
Performs a sync operation for all SyncDataSets managed by this processor.
SyncCanceledException - Exception in com.sleepycat.je.sync
Thrown by a sync operation when it is explicitly canceled.
SyncCanceledException(String) - Constructor for exception com.sleepycat.je.sync.SyncCanceledException
For internal use only.
SyncCleanerBarrier - Class in com.sleepycat.je.sync.impl
 
SyncCleanerBarrier(EnvironmentImpl) - Constructor for class com.sleepycat.je.sync.impl.SyncCleanerBarrier
The init() method must be called immediately after creation.
SyncCleanerBarrier.StartInfo - Class in com.sleepycat.je.sync.impl
 
SyncCleanerBarrier.StartInfo(long, boolean) - Constructor for class com.sleepycat.je.sync.impl.SyncCleanerBarrier.StartInfo
 
SyncCleanerBarrier.SyncTrigger - Class in com.sleepycat.je.sync.impl
 
SyncCleanerBarrier.SyncTrigger(String) - Constructor for class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
syncDatabase(EnvironmentImpl, DatabaseImpl, boolean) - Method in class com.sleepycat.je.recovery.Checkpointer
Flush a given database to disk.
SyncDatabase - Class in com.sleepycat.je.sync
Defines a synchronized database as a mapping between external table/view name and local JE database name, and includes a RecordConverter for converting between local and external record data.
SyncDatabase(String, String, RecordConverter) - Constructor for class com.sleepycat.je.sync.SyncDatabase
Creates a synchronized database definition.
SyncDataSet - Class in com.sleepycat.je.sync
Defines a sychronized data set as a set of local databases to be synchronized with an external system.
SyncDataSet(String, SyncProcessor, Collection<SyncDatabase>) - Constructor for class com.sleepycat.je.sync.SyncDataSet
Used by subclasses to create a SyncDataSet.
SyncDB - Class in com.sleepycat.je.sync.impl
Retrieves all pending and unprocessed changes for one or more SyncDataSets; used only by SyncProcessor implementations and custom sources of change set information.
SyncDB(EnvironmentImpl, boolean) - Constructor for class com.sleepycat.je.sync.impl.SyncDB
 
SyncDB.DataType - Enum in com.sleepycat.je.sync.impl
 
SyncDB.OpType - Enum in com.sleepycat.je.sync.impl
 
SyncedLockManager - Class in com.sleepycat.je.txn
SyncedLockManager uses the synchronized keyword to implement its critical sections.
SyncedLockManager(EnvironmentImpl) - Constructor for class com.sleepycat.je.txn.SyncedLockManager
 
SyncedLogManager - Class in com.sleepycat.je.log
The SyncedLogManager uses the synchronized keyword to implement protected regions.
SyncedLogManager(EnvironmentImpl, boolean) - Constructor for class com.sleepycat.je.log.SyncedLogManager
There is a single log manager per database environment.
syncLogEnd() - Method in class com.sleepycat.je.log.FileManager
FSync the end of the log.
syncLogEndAndFinishFile() - Method in class com.sleepycat.je.log.FileManager
Sync the end of the log, close off this log file.
SyncProcessor - Class in com.sleepycat.je.sync
Manages one or more synchronized data sets for a particular external system and processes sync operations.
SyncProcessor(Environment, String) - Constructor for class com.sleepycat.je.sync.SyncProcessor
Used by subclasses to create a SyncProcessor.
syncupEnded() - Method in class com.sleepycat.je.rep.impl.node.GlobalCBVLSN
 
syncupEnded() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
SyncupProgress - Enum in com.sleepycat.je.rep
Describes the different phases of replication stream syncup that are executed when a replica starts working with a new replication group master.
syncupStarted() - Method in class com.sleepycat.je.rep.impl.node.GlobalCBVLSN
 
syncupStarted() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Returns the group wide CBVLSN.

T

T_BOOLEAN - Static variable in interface com.sleepycat.asm.Opcodes
 
T_BYTE - Static variable in interface com.sleepycat.asm.Opcodes
 
T_CHAR - Static variable in interface com.sleepycat.asm.Opcodes
 
T_DOUBLE - Static variable in interface com.sleepycat.asm.Opcodes
 
T_FLOAT - Static variable in interface com.sleepycat.asm.Opcodes
 
T_INT - Static variable in interface com.sleepycat.asm.Opcodes
 
T_LONG - Static variable in interface com.sleepycat.asm.Opcodes
 
T_SHORT - Static variable in interface com.sleepycat.asm.Opcodes
 
TABL_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the TABLESWITCH instruction.
TABLESWITCH - Static variable in interface com.sleepycat.asm.Opcodes
 
tabs - Variable in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
tag - Variable in class com.sleepycat.asm.Handle
The kind of field or method designated by this Handle.
tailMap(K) - Method in class com.sleepycat.collections.StoredSortedMap
Returns a view of the portion of this sorted map whose elements are greater than or equal to fromKey.
tailMap(K, boolean) - Method in class com.sleepycat.collections.StoredSortedMap
Returns a view of the portion of this sorted map whose elements are strictly greater than fromKey, optionally including fromKey.
tailSet(Map.Entry<K, V>) - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns a view of the portion of this sorted set whose elements are greater than or equal to fromMapEntry.
tailSet(Map.Entry<K, V>, boolean) - Method in class com.sleepycat.collections.StoredSortedEntrySet
Returns a view of the portion of this sorted set whose elements are strictly greater than fromMapEntry, optionally including fromMapEntry.
tailSet(K) - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns a view of the portion of this sorted set whose elements are greater than or equal to fromKey.
tailSet(K, boolean) - Method in class com.sleepycat.collections.StoredSortedKeySet
Returns a view of the portion of this sorted set whose elements are strictly greater than fromKey, optionally including fromKey.
tailSet(E) - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns a view of the portion of this sorted set whose elements are greater than or equal to fromValue.
tailSet(E, boolean) - Method in class com.sleepycat.collections.StoredSortedValueSet
Returns a view of the portion of this sorted set whose elements are strictly greater than fromValue, optionally including fromValue.
take() - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher.QueuingService
 
takeChannel(String, boolean, int) - Method in class com.sleepycat.je.rep.utilint.ServiceDispatcher
Returns the next socketChannel created in response to a request for the service.
TARGET - Static variable in class com.sleepycat.asm.Label
Indicates if this label is the target of a jump instruction, or the start of an exception handler.
target - Variable in class com.sleepycat.je.evictor.TargetSelector.ScanInfo
 
target - Variable in class com.sleepycat.je.recovery.RollbackTracker.Scanner
 
target - Variable in class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
 
targetEntryMap - Variable in class com.sleepycat.je.log.LNFileReader
 
targetLogEntry - Variable in class com.sleepycat.je.log.LNFileReader
 
targets - Variable in class com.sleepycat.je.tree.INTargetRep.Sparse
 
TargetSelector - Class in com.sleepycat.je.evictor
The TargetSelect choses an IN for eviction.
TargetSelector(EnvironmentImpl) - Constructor for class com.sleepycat.je.evictor.TargetSelector
 
TargetSelector.EvictProfile - Class in com.sleepycat.je.evictor
 
TargetSelector.EvictProfile() - Constructor for class com.sleepycat.je.evictor.TargetSelector.EvictProfile
 
TargetSelector.ScanInfo - Class in com.sleepycat.je.evictor
Struct returned when selecting a single IN for eviction.
TargetSelector.ScanInfo() - Constructor for class com.sleepycat.je.evictor.TargetSelector.ScanInfo
 
TargetSelector.SetupInfo - Class in com.sleepycat.je.evictor
Struct returned when setting up an eviction batch.
TargetSelector.SetupInfo() - Constructor for class com.sleepycat.je.evictor.TargetSelector.SetupInfo
 
targetTxnIds - Variable in class com.sleepycat.je.log.DumpFileReader
 
targetTypes - Static variable in class com.sleepycat.je.sync.impl.LogChangeReader
 
terminate() - Method in class com.sleepycat.je.rep.impl.networkRestore.FeederManager.Lease
Fetches the leased DbBackup instance and terminates the lease.
terminate() - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex.VLSNAwaitLatch
 
TEST_REPLICA_DELAY - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
TestHook<T> - Interface in com.sleepycat.je.utilint
TestHook is used to induce testing behavior that can't be provoked externally.
TestHookAdapter<T> - Class in com.sleepycat.je.utilint
 
TestHookAdapter() - Constructor for class com.sleepycat.je.utilint.TestHookAdapter
 
TestHookExecute - Class in com.sleepycat.je.utilint
Execute a test hook if set.
TestHookExecute() - Constructor for class com.sleepycat.je.utilint.TestHookExecute
 
testOpenDatabase(Environment, Transaction, String, String, DatabaseConfig) - Static method in class com.sleepycat.compat.DbCompat
Fires an assertion if the database is not found (and AllowCreate is false) or already exists (and ExclusiveCreate is true).
testOpenSecondaryDatabase(Environment, Transaction, String, String, Database, SecondaryConfig) - Static method in class com.sleepycat.compat.DbCompat
Fires an assertion if the database is not found (and AllowCreate is false) or already exists (and ExclusiveCreate is true).
testProcessLN(LN, long, byte[], DatabaseId, Map<DatabaseId, DatabaseImpl>) - Method in class com.sleepycat.je.cleaner.FileProcessor
Unit testing.
testWriteQueueLock() - Method in class com.sleepycat.je.log.FileManager
For unit testing only.
testWriteQueueUnlock() - Method in class com.sleepycat.je.log.FileManager
For unit testing only.
TEXT - Static variable in class com.sleepycat.je.tree.Key.DumpType
 
TextProtocol - Class in com.sleepycat.je.rep.impl
TextProtocol provides the support for implementing simple low performance protocols involving replication nodes.
TextProtocol(String, String, NameIdPair, EnvironmentImpl) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol
Creates an instance of the Protocol.
TextProtocol.Fail - Class in com.sleepycat.je.rep.impl
 
TextProtocol.Fail(String) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.Fail
 
TextProtocol.Fail(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.Fail
 
TextProtocol.InvalidMessageException - Exception in com.sleepycat.je.rep.impl
Used to indicate a message format or invalid content exception.
TextProtocol.InvalidMessageException(TextProtocol.MessageError, String) - Constructor for exception com.sleepycat.je.rep.impl.TextProtocol.InvalidMessageException
 
TextProtocol.Message - Class in com.sleepycat.je.rep.impl
Base message class for all messages exchanged in the protocol.
TextProtocol.Message() - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.Message
The constructor used for the original non-serialized instance of the message, which does not use the line or tokens.
TextProtocol.Message(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.Message
Every message must define a constructor of this form so that it can be de-serialized.
TextProtocol.MessageError - Enum in com.sleepycat.je.rep.impl
 
TextProtocol.MessageExchange - Class in com.sleepycat.je.rep.impl
Use to parallelize message exchanges via Futures.
TextProtocol.MessageExchange(InetSocketAddress, String, TextProtocol.RequestMessage) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.MessageExchange
 
TextProtocol.MessageOp - Class in com.sleepycat.je.rep.impl
The Operations that are part of the protocol.
TextProtocol.MessageOp(String, Class<? extends TextProtocol.Message>) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.MessageOp
 
TextProtocol.OK - Class in com.sleepycat.je.rep.impl
 
TextProtocol.OK() - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.OK
 
TextProtocol.OK(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.OK
 
TextProtocol.ProtocolError - Class in com.sleepycat.je.rep.impl
 
TextProtocol.ProtocolError(TextProtocol.InvalidMessageException) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
TextProtocol.ProtocolError(TextProtocol.MessageError, String) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
TextProtocol.ProtocolError(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
TextProtocol.RequestMessage - Class in com.sleepycat.je.rep.impl
Base class for all Request messages
TextProtocol.RequestMessage() - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.RequestMessage
 
TextProtocol.RequestMessage(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.RequestMessage
 
TextProtocol.ResponseMessage - Class in com.sleepycat.je.rep.impl
Base classes for response messages.
TextProtocol.ResponseMessage() - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.ResponseMessage
 
TextProtocol.ResponseMessage(String, String[]) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.ResponseMessage
 
TextProtocol.StringFormatable - Class in com.sleepycat.je.rep.impl
 
TextProtocol.StringFormatable() - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.StringFormatable
 
TextProtocol.StringFormatable(String) - Constructor for class com.sleepycat.je.rep.impl.TextProtocol.StringFormatable
 
TextProtocol.TOKENS - Enum in com.sleepycat.je.rep.impl
Represents the tokens on a message line.
TextProtocol.WireFormatable - Interface in com.sleepycat.je.rep.impl
 
TFS_LIST_INITIAL_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
TFS_LIST_SEGMENT_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
theObject - Variable in class com.sleepycat.je.utilint.TinyHashSet.SingleElementIterator
 
theSet - Variable in class com.sleepycat.je.utilint.TinyHashSet.SingleElementIterator
 
ThinLockImpl - Class in com.sleepycat.je.txn
Implements a lightweight Lock with no waiters and only a single Owner.
ThinLockImpl() - Constructor for class com.sleepycat.je.txn.ThinLockImpl
Create a Lock.
THINLOCKIMPL_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
thisName - Variable in class com.sleepycat.asm.ClassWriter
The internal name of this class.
thread - Variable in class com.sleepycat.je.txn.Locker
The thread that created this locker.
THREAD_UNAVAILABLE - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
threadIdHashes - Static variable in class com.sleepycat.je.utilint.EventTrace
 
ThreadInterruptedException - Exception in com.sleepycat.je
Thrown when java.lang.InterruptedException (a thread interrupt) or java.nio.channels.ClosedChannelException (which also results from a thread interrupt) occurs in any JE method.
ThreadInterruptedException(EnvironmentImpl, Throwable) - Constructor for exception com.sleepycat.je.ThreadInterruptedException
For internal use only.
ThreadInterruptedException(EnvironmentImpl, String) - Constructor for exception com.sleepycat.je.ThreadInterruptedException
For internal use only.
ThreadInterruptedException(EnvironmentImpl, String, Throwable) - Constructor for exception com.sleepycat.je.ThreadInterruptedException
For internal use only.
ThreadLocker - Class in com.sleepycat.je.txn
Extends BasicLocker to share locks among all lockers for the same thread.
ThreadLocker(EnvironmentImpl) - Constructor for class com.sleepycat.je.txn.ThreadLocker
Creates a ThreadLocker.
threadSafeBufferFlip(ByteBuffer) - Static method in class com.sleepycat.je.log.FileReader
Note that we catch Exception here because it is possible that another thread is modifying the state of buffer simultaneously.
threadSafeBufferPosition(ByteBuffer) - Static method in class com.sleepycat.je.log.FileReader
 
threadSafeBufferPosition(ByteBuffer, int) - Static method in class com.sleepycat.je.log.FileReader
 
threshold - Variable in class com.sleepycat.asm.ClassWriter
The threshold of the constant pool's hash table.
threshold - Variable in exception com.sleepycat.je.rep.impl.networkRestore.NetworkBackup.LoadThresholdExceededException
 
THROW_ON_WRITE - Static variable in class com.sleepycat.je.log.FileManager
 
THROW_RRE_FOR_UNIT_TESTS - Static variable in class com.sleepycat.je.log.FileManager
 
throwIfPreempted(Locker) - Method in class com.sleepycat.je.txn.Locker
Called by checkPreempted to cause a LockPreemptedException to be thrown if a lock was preempted earlier.
tick() - Method in class com.sleepycat.je.rep.impl.node.DbCache
The tick() method forms the basis for removing stale entries from the cache.
time - Variable in class com.sleepycat.je.rep.stream.MatchpointSearchResults.PassedTxnInfo
 
time - Variable in class com.sleepycat.je.txn.TxnEnd
 
TIME_WIDTH - Static variable in class com.sleepycat.je.rep.elections.TimebasedProposalGenerator
 
TimebasedProposalGenerator - Class in com.sleepycat.je.rep.elections
Generates a unique sequence of ascending proposal numbers that is unique across all machines.
TimebasedProposalGenerator(int) - Constructor for class com.sleepycat.je.rep.elections.TimebasedProposalGenerator
Creates an instance with an application-specified locally (machine wide) unique id, e.g.
TimebasedProposalGenerator() - Constructor for class com.sleepycat.je.rep.elections.TimebasedProposalGenerator
Constructor defaulting the unique id so it's merely unique within the process.
TimeConsistencyPolicy - Class in com.sleepycat.je.rep
A consistency policy which describes the amount of time the Replica is allowed to lag the Master.
TimeConsistencyPolicy(long, TimeUnit, long, TimeUnit) - Constructor for class com.sleepycat.je.rep.TimeConsistencyPolicy
Specifies the amount of time by which the Replica is allowed to lag the master when initiating a transaction.
timeoutIsForUnknownState() - Method in class com.sleepycat.je.rep.impl.node.JoinGroupTimeouts
Returns true if the currently active timeout is the one for the transition out of the unknown state.
Timestamp - Class in com.sleepycat.je.utilint
Duplicate of java.sql.Timestamp which keeps our implementation constant in case the java.sql.Timestamp implementation changes incompatibly.
Timestamp(long) - Constructor for class com.sleepycat.je.utilint.Timestamp
 
TimingLatch - Class in com.sleepycat.je.utilint
A subclass of Latch that may be used for debugging performance issues.
TimingLatch(String, boolean) - Constructor for class com.sleepycat.je.utilint.TimingLatch
 
TimingLatch(String, boolean, int, int) - Constructor for class com.sleepycat.je.utilint.TimingLatch
 
TimingLatch.AcquireCompleteEvent - Class in com.sleepycat.je.utilint
 
TimingLatch.AcquireCompleteEvent(long, long) - Constructor for class com.sleepycat.je.utilint.TimingLatch.AcquireCompleteEvent
 
TimingLatch.AcquireRequestEvent - Class in com.sleepycat.je.utilint
 
TimingLatch.AcquireRequestEvent() - Constructor for class com.sleepycat.je.utilint.TimingLatch.AcquireRequestEvent
 
TimingLatch.ReleaseEvent - Class in com.sleepycat.je.utilint
 
TimingLatch.ReleaseEvent(long) - Constructor for class com.sleepycat.je.utilint.TimingLatch.ReleaseEvent
 
TinyHashSet<T> - Class in com.sleepycat.je.utilint
TinyHashSet is used to optimize (for speed, not space) the case where a HashSet generally holds a single element.
TinyHashSet() - Constructor for class com.sleepycat.je.utilint.TinyHashSet
Creates an empty set.
TinyHashSet(T) - Constructor for class com.sleepycat.je.utilint.TinyHashSet
Creates a set with one element.
TinyHashSet.SingleElementIterator<T> - Class in com.sleepycat.je.utilint
 
TinyHashSet.SingleElementIterator(T, TinyHashSet<T>) - Constructor for class com.sleepycat.je.utilint.TinyHashSet.SingleElementIterator
 
tips - Variable in class com.sleepycat.je.jmx.plugin.Stats
 
TMP_SUFFIX - Static variable in class com.sleepycat.je.log.FileManager
 
toArray() - Method in class com.sleepycat.collections.StoredCollection
Returns an array of all the elements in this collection.
toArray(T[]) - Method in class com.sleepycat.collections.StoredCollection
Returns an array of all the elements in this collection whose runtime type is that of the specified array.
toArray() - Method in class com.sleepycat.je.cleaner.OffsetList
Returns an array of all values as longs.
toArray() - Method in class com.sleepycat.je.cleaner.PackedOffsets
Returns the unpacked offsets.
toASCII(String) - Static method in class com.sleepycat.utilint.StringUtils
 
toByteArray() - Method in class com.sleepycat.asm.ClassWriter
Returns the bytecode of the class that was build with this class writer.
toByteArray() - Method in class com.sleepycat.util.FastOutputStream
 
toList() - Method in class com.sleepycat.collections.StoredCollection
Returns a copy of this collection as an ArrayList.
TOO_BIG_FOR_SELF_CHECK - Static variable in class com.sleepycat.je.cleaner.OffsetList
 
TOP - Static variable in class com.sleepycat.asm.Frame
The TOP type.
TOP - Static variable in interface com.sleepycat.asm.Opcodes
 
TOP_IF_LONG_OR_DOUBLE - Static variable in class com.sleepycat.asm.Frame
Flag used for LOCAL and STACK types.
toString() - Method in class com.sleepycat.asm.Handle
Returns the textual representation of this handle.
toString() - Method in class com.sleepycat.asm.Label
Returns a string representation of this label.
toString() - Method in class com.sleepycat.asm.Type
Returns a string representation of this type.
toString() - Method in class com.sleepycat.collections.MapEntryParameter
Converts the entry to a string representation for debugging.
toString() - Method in class com.sleepycat.collections.StoredCollection
Converts the collection to a string representation for debugging.
toString() - Method in class com.sleepycat.collections.StoredEntrySet
 
toString() - Method in class com.sleepycat.collections.StoredMap
Converts the map to a string representation for debugging.
toString() - Method in class com.sleepycat.je.BtreeStats
For convenience, the BtreeStats class has a toString method that lists all the data fields.
toString() - Method in class com.sleepycat.je.CheckpointConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
toString() - Method in class com.sleepycat.je.cleaner.DbFileSummary
 
toString() - Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
 
toString() - Method in class com.sleepycat.je.cleaner.FileSelector
 
toString() - Method in class com.sleepycat.je.cleaner.FileSummary
 
toString() - Method in class com.sleepycat.je.cleaner.INSummary
 
toString() - Method in class com.sleepycat.je.cleaner.PackedOffsets
 
toString() - Method in class com.sleepycat.je.cleaner.UtilizationCalculator.AverageSize
 
toString() - Method in class com.sleepycat.je.CommitToken
 
toString() - Method in class com.sleepycat.je.config.ConfigParam
 
toString() - Method in class com.sleepycat.je.CursorConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.DatabaseConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.DatabaseEntry
Returns all the attributes of the database entry in text form, including the underlying data.
toString() - Method in enum com.sleepycat.je.dbi.CursorImpl.SearchMode
 
toString() - Method in class com.sleepycat.je.dbi.DatabaseId
 
toString() - Method in class com.sleepycat.je.dbi.DbEnvState
 
toString() - Method in class com.sleepycat.je.dbi.DbTree
 
toString() - Method in enum com.sleepycat.je.dbi.EnvironmentFailureReason
 
toString() - Method in enum com.sleepycat.je.dbi.GetMode
 
toString() - Method in class com.sleepycat.je.dbi.MemoryBudget
 
toString() - Method in class com.sleepycat.je.dbi.Operation
 
toString() - Method in class com.sleepycat.je.dbi.StartupTracker.Counter
 
toString() - Method in class com.sleepycat.je.DiskOrderedCursorConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.Durability
Returns the string representation of durability in the format defined by string form of the Durability constructor.
toString() - Method in class com.sleepycat.je.EnvironmentConfig
Display configuration values.
toString() - Method in class com.sleepycat.je.EnvironmentMutableConfig
Display configuration values.
toString() - Method in class com.sleepycat.je.EnvironmentStats
Returns a String representation of the stats in the form of <stat>=<value>
toString() - Method in class com.sleepycat.je.ExceptionEvent
 
toString() - Method in enum com.sleepycat.je.ForeignKeyDeleteAction
 
toString() - Method in class com.sleepycat.je.jca.ra.JERequestInfo
 
toString() - Method in class com.sleepycat.je.JEVersion
 
toString() - Method in class com.sleepycat.je.JoinConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.latch.Latch
Formats a latch owner and waiters.
toString() - Method in enum com.sleepycat.je.LockMode
 
toString() - Method in class com.sleepycat.je.LockStats
Deprecated.
For convenience, LockTable.toString will display all stats in an easily readable format.
toString() - Method in class com.sleepycat.je.log.DbOpReplicationContext
 
toString() - Method in class com.sleepycat.je.log.entry.BaseEntry
 
toString() - Method in class com.sleepycat.je.log.FileHeader
Print in xml format
toString() - Method in class com.sleepycat.je.log.FileReader.ReadWindow
 
toString() - Method in class com.sleepycat.je.log.LogEntryHeader
 
toString() - Method in class com.sleepycat.je.log.LogEntryType
 
toString() - Method in class com.sleepycat.je.log.LogUtils.XidImpl
 
toString() - Method in class com.sleepycat.je.log.ReplicationContext
 
toString() - Method in class com.sleepycat.je.log.Trace
 
toString() - Method in enum com.sleepycat.je.OperationStatus
toString() - Method in class com.sleepycat.je.PreloadConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.PreloadStats
Returns a String representation of the stats in the form of <stat>=<value>
toString() - Method in class com.sleepycat.je.PreloadStatus
 
toString() - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
toString() - Method in class com.sleepycat.je.recovery.Checkpointer.CheckpointReference
 
toString() - Method in class com.sleepycat.je.recovery.RecoveryInfo
 
toString() - Method in class com.sleepycat.je.recovery.RollbackTracker.RollbackPeriod
 
toString() - Method in class com.sleepycat.je.recovery.RollbackTracker
 
toString() - Method in class com.sleepycat.je.rep.CommitPointConsistencyPolicy
 
toString() - Method in class com.sleepycat.je.rep.elections.Protocol.MasterQuery
 
toString() - Method in class com.sleepycat.je.rep.elections.Protocol.StringValue
 
toString() - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
 
toString() - Method in class com.sleepycat.je.rep.impl.node.Replay.TxnInfo
 
toString() - Method in class com.sleepycat.je.rep.impl.PointConsistencyPolicy
 
toString() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl.BarrierState
 
toString() - Method in class com.sleepycat.je.rep.impl.RepGroupImpl
Return information to the user, format nicely for ease of reading.
toString() - Method in class com.sleepycat.je.rep.impl.RepNodeImpl
 
toString() - Method in class com.sleepycat.je.rep.impl.TextProtocol.MessageOp
 
toString() - Method in class com.sleepycat.je.rep.NodeState
 
toString() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
Returns a string representation of the statistics.
toString() - Method in class com.sleepycat.je.rep.ReplicationGroup
Returns a formatted version of the information held in a ReplicationGroup.
toString() - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
List the configuration parameters and values that have been set in this configuration object.
toString() - Method in class com.sleepycat.je.rep.stream.InputWireRecord
 
toString() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults.PassedTxnInfo
 
toString() - Method in class com.sleepycat.je.rep.stream.MatchpointSearchResults
 
toString() - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
 
toString() - Method in class com.sleepycat.je.rep.stream.Protocol.Ack
 
toString() - Method in class com.sleepycat.je.rep.stream.Protocol.Entry
 
toString() - Method in class com.sleepycat.je.rep.stream.Protocol.Heartbeat
 
toString() - Method in class com.sleepycat.je.rep.stream.Protocol.HeartbeatResponse
 
toString() - Method in class com.sleepycat.je.rep.stream.Protocol.VLSNMessage
 
toString() - Method in class com.sleepycat.je.rep.TimeConsistencyPolicy
 
toString() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
 
toString() - Method in class com.sleepycat.je.rep.util.ldiff.Block
 
toString() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.Message
 
toString() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.MessageOp
 
toString() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.RejectMessage
 
toString() - Method in class com.sleepycat.je.rep.utilint.NamedChannel
 
toString() - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
 
toString() - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
toString() - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
toString() - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
toString() - Method in class com.sleepycat.je.SecondaryConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.SequenceConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.SequenceStats
 
toString() - Method in class com.sleepycat.je.StatsConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.Transaction
 
toString() - Method in class com.sleepycat.je.TransactionConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.je.TransactionStats.Active
 
toString() - Method in class com.sleepycat.je.TransactionStats
toString() - Method in class com.sleepycat.je.tree.BINReference
 
toString() - Method in class com.sleepycat.je.tree.ChildReference
 
toString() - Method in class com.sleepycat.je.tree.CountEstimator.KeyRatios
 
toString() - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
toString() - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
toString() - Method in class com.sleepycat.je.tree.FileSummaryLN
 
toString() - Method in class com.sleepycat.je.tree.IN
 
toString() - Method in class com.sleepycat.je.tree.Key.DumpType
 
toString() - Method in class com.sleepycat.je.tree.MapLN
 
toString() - Method in class com.sleepycat.je.tree.NameLN
 
toString() - Method in class com.sleepycat.je.tree.Node
Default toString method at the root of the tree.
toString() - Method in class com.sleepycat.je.tree.SearchResult
 
toString() - Method in class com.sleepycat.je.tree.TrackingInfo
 
toString() - Method in class com.sleepycat.je.tree.TreeLocation
 
toString() - Method in interface com.sleepycat.je.txn.Lock
Debug dumper.
toString() - Method in class com.sleepycat.je.txn.Locker
 
toString() - Method in class com.sleepycat.je.txn.LockImpl
Debug dumper.
toString() - Method in class com.sleepycat.je.txn.LockInfo
 
toString() - Method in class com.sleepycat.je.txn.LockType
 
toString() - Method in class com.sleepycat.je.txn.RollbackEnd
 
toString() - Method in class com.sleepycat.je.txn.RollbackStart
 
toString() - Method in class com.sleepycat.je.txn.ThinLockImpl
 
toString() - Method in class com.sleepycat.je.txn.TxnChain.RevertInfo
 
toString() - Method in class com.sleepycat.je.txn.TxnChain
 
toString() - Method in class com.sleepycat.je.txn.UndoReader
 
toString() - Method in class com.sleepycat.je.txn.WriteLockInfo
 
toString() - Method in class com.sleepycat.je.utilint.DaemonThread
 
toString(long) - Static method in class com.sleepycat.je.utilint.DbLsn
 
toString() - Method in class com.sleepycat.je.utilint.EventTrace.ExceptionEventTrace
 
toString() - Method in class com.sleepycat.je.utilint.EventTrace
 
toString() - Method in class com.sleepycat.je.utilint.Stat
 
toString() - Method in class com.sleepycat.je.utilint.StatDefinition
 
toString() - Method in class com.sleepycat.je.utilint.StatGroup
 
toString() - Method in class com.sleepycat.je.utilint.Timestamp
 
toString() - Method in class com.sleepycat.je.utilint.TimingLatch.AcquireCompleteEvent
 
toString() - Method in class com.sleepycat.je.utilint.TimingLatch.AcquireRequestEvent
 
toString() - Method in class com.sleepycat.je.utilint.TimingLatch.ReleaseEvent
 
toString() - Method in class com.sleepycat.je.utilint.VLSN
 
toString() - Method in class com.sleepycat.je.VerifyConfig
Returns the values for each configuration attribute.
toString() - Method in class com.sleepycat.persist.evolve.Converter
 
toString() - Method in class com.sleepycat.persist.evolve.Deleter
 
toString() - Method in class com.sleepycat.persist.evolve.EntityConverter
 
toString() - Method in class com.sleepycat.persist.evolve.Mutation
 
toString() - Method in class com.sleepycat.persist.evolve.Mutations
 
toString() - Method in class com.sleepycat.persist.evolve.Renamer
 
toString() - Method in class com.sleepycat.persist.impl.FieldInfo
 
toString() - Method in class com.sleepycat.persist.impl.Format
 
toString() - Method in class com.sleepycat.persist.impl.PersistComparator
 
toString() - Method in class com.sleepycat.persist.model.FieldMetadata
 
toString() - Method in class com.sleepycat.persist.raw.RawObject
Returns an XML representation of the raw object.
toString() - Method in interface com.sleepycat.persist.raw.RawType
Returns an XML representation of the raw type.
toString() - Method in class com.sleepycat.util.FastOutputStream
 
toString(String) - Method in class com.sleepycat.util.FastOutputStream
 
toString() - Method in class com.sleepycat.util.keyrange.KeyRange
Formats this range as a string for debugging.
toString(DatabaseEntry) - Static method in class com.sleepycat.util.keyrange.KeyRange
Converts the byte array of this thang to space-separated integers, and suffixed by the record number if applicable.
toString() - Method in class com.sleepycat.utilint.Latency
 
toString() - Method in class com.sleepycat.utilint.LatencyStat
 
toStringConcise() - Method in class com.sleepycat.je.utilint.StatGroup
Only print values that are not null or zero.
toStringNoVersion() - Method in class com.sleepycat.je.log.LogEntryType
 
toStringVerbose() - Method in class com.sleepycat.je.BtreeStats
 
toStringVerbose() - Method in class com.sleepycat.je.EnvironmentStats
Returns a String representation of the stats which includes stats descriptions in addition to <stat>=<value>
toStringVerbose() - Method in class com.sleepycat.je.LockStats
Deprecated.
Like #toString, display all stats.
toStringVerbose() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
 
toStringVerbose() - Method in class com.sleepycat.je.SequenceStats
 
toStringVerbose() - Method in class com.sleepycat.je.TransactionStats
 
toStringVerbose() - Method in class com.sleepycat.je.utilint.Stat
Includes the per-stat description in the output string.
toStringVerbose() - Method in class com.sleepycat.je.utilint.StatGroup
Includes the per-stat description in the output string.
TOTAL_COMMIT_PROCESSING_NANOS - Static variable in class com.sleepycat.je.rep.impl.node.ReplayStatDefinition
 
TOTAL_LOCKIMPL_OVERHEAD - Static variable in class com.sleepycat.je.txn.LockManager
 
TOTAL_THINLOCKIMPL_OVERHEAD - Static variable in class com.sleepycat.je.txn.LockManager
 
TOTAL_TXN_MS - Static variable in class com.sleepycat.je.rep.stream.FeederTxnStatDefinition
 
totalBINDeltaCount - Variable in class com.sleepycat.je.cleaner.INSummary
 
totalBINDeltaSize - Variable in class com.sleepycat.je.cleaner.INSummary
 
totalBytes - Variable in class com.sleepycat.je.log.StatsFileReader.EntryInfo
 
totalCount - Variable in class com.sleepycat.je.cleaner.FileSummary
 
totalINCount - Variable in class com.sleepycat.je.cleaner.DbFileSummary
 
totalINCount - Variable in class com.sleepycat.je.cleaner.FileSummary
 
totalINCount - Variable in class com.sleepycat.je.cleaner.INSummary
 
totalINSize - Variable in class com.sleepycat.je.cleaner.DbFileSummary
 
totalINSize - Variable in class com.sleepycat.je.cleaner.FileSummary
 
totalINSize - Variable in class com.sleepycat.je.cleaner.INSummary
 
totalLNCount - Variable in class com.sleepycat.je.cleaner.DbFileSummary
 
totalLNCount - Variable in class com.sleepycat.je.cleaner.FileSummary
 
totalLNSize - Variable in class com.sleepycat.je.cleaner.DbFileSummary
 
totalLNSize - Variable in class com.sleepycat.je.cleaner.FileSummary
 
totalLogSize - Variable in class com.sleepycat.je.cleaner.Cleaner
 
totalNewSize - Variable in class com.sleepycat.je.log.LogContext
 
totalRuns - Variable in class com.sleepycat.je.cleaner.Cleaner
 
totalSize - Variable in class com.sleepycat.je.cleaner.FileSummary
 
toUTF8(String) - Static method in class com.sleepycat.utilint.StringUtils
In all src and test code, the String(byte[], ...) constructor and String.getBytes method must always be passed a charset name, to avoid portability issues.
trace(Level, String, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Cursor
Sends trace messages to the java.util.logger.
trace(Level, String, LockMode) - Method in class com.sleepycat.je.Cursor
Sends trace messages to the java.util.logger.
trace(Level, String, Transaction, DatabaseEntry, DatabaseEntry, LockMode) - Method in class com.sleepycat.je.Database
Sends trace messages to the java.util.logger.
trace(Level, String, Transaction, Object) - Method in class com.sleepycat.je.Database
Sends trace messages to the java.util.logger.
Trace - Class in com.sleepycat.je.log
Trace logs event tracing messages into .jdb files.
Trace(String) - Constructor for class com.sleepycat.je.log.Trace
Create a new debug record.
Trace() - Constructor for class com.sleepycat.je.log.Trace
Create a trace record that will be filled in from the log.
trace(EnvironmentImpl, String) - Static method in class com.sleepycat.je.log.Trace
Convenience method to create a log entry containing this trace msg.
trace(EnvironmentImpl, Trace) - Static method in class com.sleepycat.je.log.Trace
Trace a trace object, unit tests only.
trace(Level, String) - Method in class com.sleepycat.je.SecondaryDatabase
Send trace messages to the java.util.logger.
TRACE_CONSOLE - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
in favor of CONSOLE_LOGGING_LEVEL As of JE 4.0, use the standard java.util.logging configuration methodologies. To enable console output, set com.sleepycat.je.util.ConsoleHandler.level = <LEVEL> through the java.util.logging configuration file, or through the java.util.logging.LogManager. To set the handler level programmatically, set "com.sleepycat.je.util.ConsoleHandler.level" in the EnvironmentConfig object.
TRACE_DB - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
As of JE 4.0, event tracing to the .jdb files has been separated from the java.util.logging mechanism. This parameter has no effect.
TRACE_EVENTS - Static variable in class com.sleepycat.je.utilint.EventTrace
 
TRACE_FILE - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
in favor of FILE_LOGGING_LEVEL As of JE 4.0, use the standard java.util.logging configuration methodologies. To enable logging output to the je.info files, set com.sleepycat.je.util.FileHandler.level = <LEVEL> through the java.util.logging configuration file, or through the java.util.logging.LogManager. To set the handler level programmatically, set "com.sleepycat.je.util.FileHandler.level" in the EnvironmentConfig object.
TRACE_FILE_COUNT - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
As of JE 4.0, use the standard java.util.logging configuration methodologies. To set the FileHandler output file count, set com.sleepycat.je.util.FileHandler.count = <NUMBER> through the java.util.logging configuration file, or through the java.util.logging.LogManager.
TRACE_FILE_LIMIT - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
As of JE 4.0, use the standard java.util.logging configuration methodologies. To set the FileHandler output file size, set com.sleepycat.je.util.FileHandler.limit = <NUMBER> through the java.util.logging configuration file, or through the java.util.logging.LogManager.
TRACE_LEVEL - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
As of JE 4.0, use the standard java.util.logging configuration methodologies. Set logging levels using class names through the java.util.logging configuration file, or through the java.util.logging.LogManager.
TRACE_LEVEL_CLEANER - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
As of JE 4.0, use the standard java.util.logging configuration methodologies. To see cleaner logging, set com.sleepycat.je.cleaner.level = <LEVEL> through the java.util.logging configuration file, or through the java.util.logging.LogManager.
TRACE_LEVEL_EVICTOR - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
As of JE 4.0, use the standard java.util.logging configuration methodologies. To see evictor logging, set com.sleepycat.je.evictor.level = <LEVEL> through the java.util.logging configuration file, or through the java.util.logging.LogManager.
TRACE_LEVEL_LOCK_MANAGER - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
As of JE 4.0, use the standard java.util.logging configuration methodologies. To see locking logging, set com.sleepycat.je.txn.level = <LEVEL> through the java.util.logging configuration file, or through the java.util.logging.LogManager.
TRACE_LEVEL_RECOVERY - Static variable in class com.sleepycat.je.EnvironmentConfig
Deprecated.
As of JE 4.0, use the standard java.util.logging configuration methodologies. To see recovery logging, set com.sleepycat.je.recovery.level = <LEVEL> through the java.util.logging configuration file, or through the java.util.logging.LogManager.
traceAndLog(Logger, EnvironmentImpl, Level, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Records a message both to the java.util.logging loggers and through the trace system which writes to the .jdb files.
traceAndLogException(EnvironmentImpl, String, String, String, Throwable) - Static method in class com.sleepycat.je.utilint.LoggerUtils
Logger method for recording an exception and stacktrace to both the java.util.logging system and the .jdb files.
traceLazily(EnvironmentImpl, String) - Static method in class com.sleepycat.je.log.Trace
Convenience method to create a log entry (lazily) containing this trace msg.
TracerFormatter - Class in com.sleepycat.je.utilint
Formatter for java.util.logging output.
TracerFormatter() - Constructor for class com.sleepycat.je.utilint.TracerFormatter
 
TracerFormatter(String) - Constructor for class com.sleepycat.je.utilint.TracerFormatter
 
traceRootDeletion(Logger, DatabaseImpl) - Static method in class com.sleepycat.je.recovery.RecoveryManager
Log trace information about root deletions, called by INCompressor and recovery.
track(VLSN, long) - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNTracker
Tracks barrier VLSNs, updating the local CBVLSN if the associated log file has changed.
track(VLSN, long, byte) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
Record a new VLSN->LSN mapping.
trackDetail - Variable in class com.sleepycat.je.cleaner.Cleaner
 
TrackedFileSummary - Class in com.sleepycat.je.cleaner
Delta file summary info for a tracked file.
TrackedFileSummary(BaseUtilizationTracker, long, boolean) - Constructor for class com.sleepycat.je.cleaner.TrackedFileSummary
Creates an empty tracked summary.
trackHeartbeat(Protocol.Heartbeat) - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
 
TrackingInfo - Class in com.sleepycat.je.tree
Tracking info packages some tree tracing info.
TrackingInfo(long, long, int) - Constructor for class com.sleepycat.je.tree.TrackingInfo
 
trackMapping(long, LogEntryHeader, LogEntry) - Method in interface com.sleepycat.je.dbi.VLSNProxy
 
trackMapping(long, LogEntryHeader, LogEntry) - Method in interface com.sleepycat.je.recovery.VLSNRecoveryProxy
 
trackMapping(long, LogEntryHeader, LogEntry) - Method in class com.sleepycat.je.rep.vlsn.VLSNRecoveryTracker
 
trackObsolete(long, boolean) - Method in class com.sleepycat.je.cleaner.TrackedFileSummary
Tracks the given offset as obsolete or non-obsolete.
trackObsoleteInfo(LogEntryType) - Static method in class com.sleepycat.je.cleaner.BaseUtilizationTracker
Returns whether obsoleteness is tracked for the given type.
trackProvisionalObsolete(IN, long, boolean, int) - Method in class com.sleepycat.je.tree.IN
Adds the given obsolete LSN and any tracked obsolete LSNs for the given child IN to this IN's tracking list.
trackSyncableVLSN(VLSN, long) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Should be called whenever a new VLSN is associated with a log entry suitable for Replica/Feeder syncup.
trackTxnEnd() - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
 
trackVLSN() - Method in class com.sleepycat.je.rep.impl.node.Replica.ConsistencyTracker
 
Transaction - Class in com.sleepycat.je
The Transaction object is the handle for a transaction.
Transaction(Environment, Txn) - Constructor for class com.sleepycat.je.Transaction
For internal use.
Transaction.State - Enum in com.sleepycat.je
The current state of the transaction.
TRANSACTION_RUNNER_PRINT_STACK_TRACES - Static variable in class com.sleepycat.compat.DbCompat
 
transactional - Variable in class com.sleepycat.collections.DataView
 
transactional - Variable in class com.sleepycat.persist.BasicIndex
 
TransactionConfig - Class in com.sleepycat.je
Specifies the attributes of a database environment transaction.
TransactionConfig() - Constructor for class com.sleepycat.je.TransactionConfig
An instance created using the default constructor is initialized with the system's default settings.
TransactionConfigBeanInfo - Class in com.sleepycat.je
 
TransactionConfigBeanInfo() - Constructor for class com.sleepycat.je.TransactionConfigBeanInfo
 
TransactionRunner - Class in com.sleepycat.collections
Starts a transaction, calls TransactionWorker.doWork(), and handles transaction retry and exceptions.
TransactionRunner(Environment) - Constructor for class com.sleepycat.collections.TransactionRunner
Creates a transaction runner for a given Berkeley DB environment.
TransactionRunner(Environment, int, TransactionConfig) - Constructor for class com.sleepycat.collections.TransactionRunner
Creates a transaction runner for a given Berkeley DB environment and with a given number of maximum retries.
TransactionStats - Class in com.sleepycat.je
Transaction statistics for a database environment.
TransactionStats(StatGroup) - Constructor for class com.sleepycat.je.TransactionStats
 
TransactionStats.Active - Class in com.sleepycat.je
The Active class represents an active transaction.
TransactionStats.Active(String, long, long) - Constructor for class com.sleepycat.je.TransactionStats.Active
 
TransactionTimeoutException - Exception in com.sleepycat.je
Thrown when multiple threads are competing for a lock and the transaction timeout interval is exceeded for the current thread.
TransactionTimeoutException(Locker, String) - Constructor for exception com.sleepycat.je.TransactionTimeoutException
For internal use only.
TransactionTrigger - Interface in com.sleepycat.je.trigger
TransactionTrigger defines the methods that track a transaction through its lifecycle.
TransactionWorker - Interface in com.sleepycat.collections
The interface implemented to perform the work within a transaction.
transfer() - Method in class com.sleepycat.je.rep.impl.node.MasterTransfer
Performs the core processing of a Master Transfer operation.
TRANSFER_BYTES - Static variable in class com.sleepycat.je.rep.impl.networkRestore.LogFileFeeder
 
TRANSFER_LOGGING_THRESHOLD - Static variable in class com.sleepycat.je.rep.impl.RepParams
Used to log an info message when a commit log record exceeds this time interval from the time it was created, to the time it was written out to the network.
TRANSFER_MASTER - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
TRANSFER_OK - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
transferMaster(Set<String>, long, boolean) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Transfer the master role to one of the specified replicas.
transferMaster(Set<String>, long, boolean) - Method in class com.sleepycat.je.rep.impl.RepImpl
 
transferMaster(Set<String>, int, TimeUnit) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
 
transferMaster(Set<String>, int, TimeUnit, boolean) - Method in class com.sleepycat.je.rep.ReplicatedEnvironment
 
transferMaster(String, String) - Method in class com.sleepycat.je.rep.util.DbGroupAdmin
Transfers the master role from the current master to one of the replicas specified in the argument list.
transferMaster(Set<String>, int, TimeUnit, boolean) - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Transfers the master state from the current master to one of the replicas supplied in the argument list.
transferToUtilizationTracker(UtilizationTracker) - Method in class com.sleepycat.je.cleaner.BaseLocalUtilizationTracker
Transfers counts and offsets from this local tracker to the given (global) UtilizationTracker and to the live DatabaseImpl objects.
transferToUtilizationTracker(LocalUtilizationTracker) - Method in class com.sleepycat.je.log.LogManager
 
transferToUtilizationTracker(LocalUtilizationTracker) - Method in class com.sleepycat.je.log.SyncedLogManager
 
transferToUtilizationTrackerInternal(LocalUtilizationTracker) - Method in class com.sleepycat.je.log.LogManager
 
transform(ClassLoader, String, Class<?>, ProtectionDomain, byte[]) - Method in class com.sleepycat.persist.model.ClassEnhancer
 
traverseDbWithCursor(DatabaseImpl, LockType, boolean, CursorImpl.WithCursor) - Static method in class com.sleepycat.je.dbi.CursorImpl
Enumerates all records in a databaseImpl non-transactionally and calls the withCursor method for each record.
Tree - Class in com.sleepycat.je.tree
Tree implements the JE B+Tree.
Tree(DatabaseImpl) - Constructor for class com.sleepycat.je.tree.Tree
Create a new tree.
Tree() - Constructor for class com.sleepycat.je.tree.Tree
Create a tree that's being read in from the log.
Tree.SearchType - Class in com.sleepycat.je.tree
Embodies an enum for the type of search being performed.
TREE_BIN_DELTA - Static variable in class com.sleepycat.je.EnvironmentConfig
If more than this percentage of entries are changed on a BIN, log a a full version instead of a delta.
TREE_COMPACT_MAX_KEY_LENGTH - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
TREE_COMPACT_MAX_KEY_LENGTH - Static variable in class com.sleepycat.je.EnvironmentConfig
Specifies the maximum unprefixed key length for use in the compact in-memory key representation.
TREE_MAX_DELTA - Static variable in class com.sleepycat.je.EnvironmentConfig
After this many deltas, log a full version.
TREE_MIN_MEMORY - Static variable in class com.sleepycat.je.EnvironmentConfig
The minimum bytes allocated out of the memory cache to hold Btree data including internal nodes and record keys and data.
treeKey - Variable in class com.sleepycat.je.recovery.Checkpointer.CheckpointReference
 
TreeLocation - Class in com.sleepycat.je.tree
 
TreeLocation() - Constructor for class com.sleepycat.je.tree.TreeLocation
 
TREEMAP_ENTRY_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
TREEMAP_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
TreeUtils - Class in com.sleepycat.je.tree
Miscellaneous Tree utilities.
TreeUtils() - Constructor for class com.sleepycat.je.tree.TreeUtils
 
TreeWalkerStatsAccumulator - Interface in com.sleepycat.je.tree
Accumulates stats about a tree during tree walking.
Trigger - Interface in com.sleepycat.je.trigger
Trigger defines the trigger methods associated with a database.
triggerAdded(Database) - Method in interface com.sleepycat.je.DatabaseTrigger
Notifies the trigger that it has been added and will start receiving update notifications.
triggerAdded(Database) - Method in class com.sleepycat.je.ForeignKeyTrigger
 
triggerAdded(Database) - Method in class com.sleepycat.je.SecondaryTrigger
 
TriggerManager - Class in com.sleepycat.je.dbi
Class that invokes the triggers associated with a database.
TriggerManager() - Constructor for class com.sleepycat.je.dbi.TriggerManager
 
TriggerManager.MapOver<R,E> - Class in com.sleepycat.je.dbi
Lisp inspired Map function.
TriggerManager.MapOver(Collection<E>) - Constructor for class com.sleepycat.je.dbi.TriggerManager.MapOver
 
triggerRemoved(Database) - Method in interface com.sleepycat.je.DatabaseTrigger
Notifies the trigger that it has been removed and will stop receiving update notifications.
triggerRemoved(Database) - Method in class com.sleepycat.je.ForeignKeyTrigger
 
triggerRemoved(Database) - Method in class com.sleepycat.je.SecondaryTrigger
 
TriggerUtils - Class in com.sleepycat.je.dbi
Utility functions used by the trigger implementation.
TriggerUtils() - Constructor for class com.sleepycat.je.dbi.TriggerUtils
 
trueAvgSize - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.TestAdjustment
 
trueFileSummary - Variable in class com.sleepycat.je.cleaner.UtilizationCalculator.TestAdjustment
 
truncate(Locker, String, boolean) - Method in class com.sleepycat.je.dbi.DbTree
 
truncate(Transaction) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier.SyncTrigger
 
truncate(Transaction) - Method in interface com.sleepycat.je.trigger.PersistentTrigger
The trigger method invoked after the successful truncation of a Database.
truncateClass(Class) - Method in class com.sleepycat.persist.EntityStore
Deletes all instances of this entity class and its (non-entity) subclasses.
truncateClass(Transaction, Class) - Method in class com.sleepycat.persist.EntityStore
Deletes all instances of this entity class and its (non-entity) subclasses.
truncateClass(Class) - Method in class com.sleepycat.persist.impl.Store
 
truncateClass(Transaction, Class) - Method in class com.sleepycat.persist.impl.Store
 
truncateDatabase(Environment, Transaction, String, String) - Static method in class com.sleepycat.compat.DbCompat
Returns false if the database is not found.
truncateDatabase(Transaction, String, boolean) - Method in class com.sleepycat.je.Environment
Empties the database, discarding all the records it contains, without removing the database name.
truncateDatabase(String, boolean) - Method in class com.sleepycat.je.jca.ra.JEConnection
 
truncateDatabase(String, boolean) - Method in class com.sleepycat.je.jca.ra.JEManagedConnection
 
truncateFromHead(VLSN, long) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Remove all information from the VLSNIndex for VLSNs <= deleteEndpoint.
truncateFromHead(VLSN, long) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
truncateFromTail(VLSN, long) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Remove all information from the VLSNIndex for VLSNs >= deleteStart Used by replica side syncup, when the log is truncated.
truncateFromTail(VLSN, long) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
Remove the mappings for VLSNs >= deleteStart.
truncateLog(long, long) - Method in class com.sleepycat.je.log.FileManager
 
truncateLog(File, long, long) - Method in class com.sleepycat.je.util.DbTruncateLog
 
truncateReplicaDb(Locker, String, boolean, NameLN, DbOpReplicationContext) - Method in class com.sleepycat.je.dbi.DbTree
 
TruncateResult - Class in com.sleepycat.je.dbi
Holds the result of a database truncate operation.
TruncateResult(DatabaseImpl, int) - Constructor for class com.sleepycat.je.dbi.TruncateResult
 
truncateSingleFile(long, long) - Method in class com.sleepycat.je.log.FileManager
Truncate a log at this position.
tryActivatePrimary() - Method in class com.sleepycat.je.rep.impl.node.RepNode
Tries to activate this node as a Primary, if it has been configured as such and if the group size is two.
TUPLE_OUTPUT_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
TupleBase<E> - Class in com.sleepycat.bind.tuple
A base class for tuple bindings and tuple key creators that provides control over the allocation of the output buffer.
TupleBase() - Constructor for class com.sleepycat.bind.tuple.TupleBase
Initializes the initial output buffer size to zero.
TupleBinding<E> - Class in com.sleepycat.bind.tuple
An abstract EntryBinding that treats a key or data entry as a tuple; it includes predefined bindings for Java primitive types.
TupleBinding() - Constructor for class com.sleepycat.bind.tuple.TupleBinding
Creates a tuple binding.
TupleInput - Class in com.sleepycat.bind.tuple
An InputStream with DataInput-like methods for reading tuple fields.
TupleInput(byte[]) - Constructor for class com.sleepycat.bind.tuple.TupleInput
Creates a tuple input object for reading a byte array of tuple data.
TupleInput(byte[], int, int) - Constructor for class com.sleepycat.bind.tuple.TupleInput
Creates a tuple input object for reading a byte array of tuple data at a given offset for a given length.
TupleInput(TupleOutput) - Constructor for class com.sleepycat.bind.tuple.TupleInput
Creates a tuple input object from the data contained in a tuple output object.
TupleInputBinding - Class in com.sleepycat.bind.tuple
A concrete EntryBinding that uses the TupleInput object as the key or data object.
TupleInputBinding() - Constructor for class com.sleepycat.bind.tuple.TupleInputBinding
Creates a tuple input binding.
TupleMarshalledBinding<E extends MarshalledTupleEntry> - Class in com.sleepycat.bind.tuple
A concrete TupleBinding that delegates to the MarshalledTupleEntry interface of the data or key object.
TupleMarshalledBinding(Class<E>) - Constructor for class com.sleepycat.bind.tuple.TupleMarshalledBinding
Creates a tuple marshalled binding object.
TupleOutput - Class in com.sleepycat.bind.tuple
An OutputStream with DataOutput-like methods for writing tuple fields.
TupleOutput() - Constructor for class com.sleepycat.bind.tuple.TupleOutput
Creates a tuple output object for writing a byte array of tuple data.
TupleOutput(byte[]) - Constructor for class com.sleepycat.bind.tuple.TupleOutput
Creates a tuple output object for writing a byte array of tuple data, using a given buffer.
tupleOutputSize(TupleOutput) - Static method in class com.sleepycat.je.dbi.MemoryBudget
 
TupleSerialBinding<D,E> - Class in com.sleepycat.bind.serial
An abstract EntityBinding that treats an entity's key entry as a tuple and its data entry as a serialized object.
TupleSerialBinding(ClassCatalog, Class<D>) - Constructor for class com.sleepycat.bind.serial.TupleSerialBinding
Creates a tuple-serial entity binding.
TupleSerialBinding(SerialBinding<D>) - Constructor for class com.sleepycat.bind.serial.TupleSerialBinding
Creates a tuple-serial entity binding.
TupleSerialFactory - Class in com.sleepycat.collections
Creates stored collections having tuple keys and serialized entity values.
TupleSerialFactory(ClassCatalog) - Constructor for class com.sleepycat.collections.TupleSerialFactory
Creates a tuple-serial factory for given environment and class catalog.
TupleSerialKeyCreator<D> - Class in com.sleepycat.bind.serial
A abstract key creator that uses a tuple key and a serial data entry.
TupleSerialKeyCreator(ClassCatalog, Class<D>) - Constructor for class com.sleepycat.bind.serial.TupleSerialKeyCreator
Creates a tuple-serial key creator.
TupleSerialKeyCreator(SerialBinding<D>) - Constructor for class com.sleepycat.bind.serial.TupleSerialKeyCreator
Creates a tuple-serial key creator.
TupleSerialMarshalledBinding<E extends MarshalledTupleKeyEntity> - Class in com.sleepycat.bind.serial
A concrete TupleSerialBinding that delegates to the MarshalledTupleKeyEntity interface of the entity class.
TupleSerialMarshalledBinding(ClassCatalog, Class<E>) - Constructor for class com.sleepycat.bind.serial.TupleSerialMarshalledBinding
Creates a tuple-serial marshalled binding object.
TupleSerialMarshalledBinding(SerialBinding<E>) - Constructor for class com.sleepycat.bind.serial.TupleSerialMarshalledBinding
Creates a tuple-serial marshalled binding object.
TupleSerialMarshalledKeyCreator<D extends MarshalledTupleKeyEntity> - Class in com.sleepycat.bind.serial
A concrete key creator that works in conjunction with a TupleSerialMarshalledBinding.
TupleSerialMarshalledKeyCreator(TupleSerialMarshalledBinding<D>, String) - Constructor for class com.sleepycat.bind.serial.TupleSerialMarshalledKeyCreator
Creates a tuple-serial marshalled key creator.
TupleTupleBinding<E> - Class in com.sleepycat.bind.tuple
An abstract EntityBinding that treats an entity's key entry and data entry as tuples.
TupleTupleBinding() - Constructor for class com.sleepycat.bind.tuple.TupleTupleBinding
Creates a tuple-tuple entity binding.
TupleTupleKeyCreator<E> - Class in com.sleepycat.bind.tuple
An abstract key creator that uses a tuple key and a tuple data entry.
TupleTupleKeyCreator() - Constructor for class com.sleepycat.bind.tuple.TupleTupleKeyCreator
Creates a tuple-tuple key creator.
TupleTupleMarshalledBinding<E extends MarshalledTupleEntry & MarshalledTupleKeyEntity> - Class in com.sleepycat.bind.tuple
A concrete TupleTupleBinding that delegates to the MarshalledTupleEntry and MarshalledTupleKeyEntity interfaces of the entity class.
TupleTupleMarshalledBinding(Class<E>) - Constructor for class com.sleepycat.bind.tuple.TupleTupleMarshalledBinding
Creates a tuple-tuple marshalled binding object.
TupleTupleMarshalledKeyCreator<E extends MarshalledTupleEntry & MarshalledTupleKeyEntity> - Class in com.sleepycat.bind.tuple
A concrete key creator that works in conjunction with a TupleTupleMarshalledBinding.
TupleTupleMarshalledKeyCreator(TupleTupleMarshalledBinding<E>, String) - Constructor for class com.sleepycat.bind.tuple.TupleTupleMarshalledKeyCreator
Creates a tuple-tuple marshalled key creator.
turnOffInvisible(ByteBuffer, int) - Static method in class com.sleepycat.je.log.LogEntryHeader
Turn off the invisible bit in the byte buffer which backs this log entry header.
TWOHASHMAPS_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
Txn - Class in com.sleepycat.je.txn
A Txn is the internal representation of a transaction created by a call to Environment.txnBegin.
Txn() - Constructor for class com.sleepycat.je.txn.Txn
Constructor for reading from log.
Txn(EnvironmentImpl, TransactionConfig, ReplicationContext) - Constructor for class com.sleepycat.je.txn.Txn
 
Txn(EnvironmentImpl, TransactionConfig, ReplicationContext, long) - Constructor for class com.sleepycat.je.txn.Txn
A non-zero mandatedId is specified only by subtypes which arbitrarily impose a transaction id value onto the transaction.
TXN_ABORTS - Static variable in class com.sleepycat.je.dbi.TxnStatDefinition
 
TXN_ACTIVE - Static variable in class com.sleepycat.je.dbi.TxnStatDefinition
 
TXN_ACTIVE_TXNS - Static variable in class com.sleepycat.je.dbi.TxnStatDefinition
 
TXN_BEGINS - Static variable in class com.sleepycat.je.dbi.TxnStatDefinition
 
TXN_COMMITS - Static variable in class com.sleepycat.je.dbi.TxnStatDefinition
 
TXN_DEADLOCK_STACK_TRACE - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
TXN_DEADLOCK_STACK_TRACE - Static variable in class com.sleepycat.je.EnvironmentConfig
Set this parameter to true to add stacktrace information to deadlock (lock timeout) exception messages.
TXN_DUMP_LOCKS - Static variable in class com.sleepycat.je.EnvironmentConfig
Dump the lock table when a lock timeout is encountered, for debugging assistance.
TXN_DUMPLOCKS - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
TXN_DURABILITY - Static variable in class com.sleepycat.je.EnvironmentConfig
 
TXN_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
TXN_ROLLBACK_LIMIT - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
TXN_ROLLBACK_LIMIT - Static variable in class com.sleepycat.je.rep.ReplicationConfig
In rare cases, a node may need to rollback committed transactions in order to rejoin a replication group.
TXN_SERIALIZABLE_ISOLATION - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
TXN_SERIALIZABLE_ISOLATION - Static variable in class com.sleepycat.je.EnvironmentConfig
TXN_TIMEOUT - Static variable in class com.sleepycat.je.config.EnvironmentParams
 
TXN_TIMEOUT - Static variable in class com.sleepycat.je.EnvironmentConfig
The TxnTimeout property.
TXN_XAABORTS - Static variable in class com.sleepycat.je.dbi.TxnStatDefinition
 
TXN_XACOMMITS - Static variable in class com.sleepycat.je.dbi.TxnStatDefinition
 
TXN_XAPREPARES - Static variable in class com.sleepycat.je.dbi.TxnStatDefinition
 
TxnAbort - Class in com.sleepycat.je.txn
This class writes out a transaction commit or transaction end record.
TxnAbort(long, long, int) - Constructor for class com.sleepycat.je.txn.TxnAbort
 
TxnAbort() - Constructor for class com.sleepycat.je.txn.TxnAbort
For constructing from the log.
txnBegin(Transaction, TransactionConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Transactional services.
txnBegin(Transaction, TransactionConfig) - Method in class com.sleepycat.je.txn.TxnManager
Create a new transaction.
txnBeginHook(MasterTxn) - Method in class com.sleepycat.je.rep.impl.RepImpl
Ensure that a sufficient number of feeders are available before proceeding with a master transaction begin.
txnBeginHook(TransactionConfig) - Method in class com.sleepycat.je.rep.txn.MasterTxn
Causes the transaction to wait until we have sufficient replicas to acknowledge the commit.
txnBeginHook(TransactionConfig) - Method in class com.sleepycat.je.rep.txn.ReadonlyTxn
Verifies that consistency requirements are met before allowing the transaction to proceed.
txnBeginHook(TransactionConfig) - Method in class com.sleepycat.je.txn.Txn
A replicated environment introduces some new considerations when entering a transaction scope via an Environment.transactionBegin() operation.
TxnChain - Class in com.sleepycat.je.txn
TxnChain supports Txn.rollback(), which undoes the write operations for a given transaction to an arbitrary point.
TxnChain(long, long, long, EnvironmentImpl) - Constructor for class com.sleepycat.je.txn.TxnChain
 
TxnChain(long, long, long, Map<DatabaseId, DatabaseImpl>, EnvironmentImpl) - Constructor for class com.sleepycat.je.txn.TxnChain
 
TxnChain.CompareSlot - Class in com.sleepycat.je.txn
Compare two keys using the appropriate comparator.
TxnChain.CompareSlot(DatabaseImpl, LNLogEntry) - Constructor for class com.sleepycat.je.txn.TxnChain.CompareSlot
 
TxnChain.RevertInfo - Class in com.sleepycat.je.txn
 
TxnChain.RevertInfo(long, boolean) - Constructor for class com.sleepycat.je.txn.TxnChain.RevertInfo
 
TxnCommit - Class in com.sleepycat.je.txn
This class writes out a transaction commit or transaction end record.
TxnCommit(long, long, int) - Constructor for class com.sleepycat.je.txn.TxnCommit
 
TxnCommit() - Constructor for class com.sleepycat.je.txn.TxnCommit
For constructing from the log.
TxnEnd - Class in com.sleepycat.je.txn
This class writes out a transaction commit or transaction end record.
TxnEnd(long, long, int) - Constructor for class com.sleepycat.je.txn.TxnEnd
 
TxnEnd() - Constructor for class com.sleepycat.je.txn.TxnEnd
For constructing from the log
TxnManager - Class in com.sleepycat.je.txn
Class to manage transactions.
TxnManager(EnvironmentImpl) - Constructor for class com.sleepycat.je.txn.TxnManager
 
TxnPrepare - Class in com.sleepycat.je.txn
This class writes out a transaction prepare record.
TxnPrepare(long, Xid) - Constructor for class com.sleepycat.je.txn.TxnPrepare
 
TxnPrepare() - Constructor for class com.sleepycat.je.txn.TxnPrepare
For constructing from the log.
TXNS_ACKED - Static variable in class com.sleepycat.je.rep.stream.FeederTxnStatDefinition
 
TXNS_NOT_ACKED - Static variable in class com.sleepycat.je.rep.stream.FeederTxnStatDefinition
 
txnStat(StatsConfig) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Retrieve txn statistics
txnStat(StatsConfig) - Method in class com.sleepycat.je.txn.TxnManager
Collect transaction related stats.
TxnStatDefinition - Class in com.sleepycat.je.dbi
Per-stat Metadata for JE transaction statistics.
TxnStatDefinition() - Constructor for class com.sleepycat.je.dbi.TxnStatDefinition
 
txnVLSN - Variable in class com.sleepycat.je.rep.impl.node.Replay.TxnInfo
 
type - Variable in class com.sleepycat.asm.Attribute
The type of this attribute.
TYPE - Static variable in class com.sleepycat.asm.ClassWriter
The instruction types of all JVM opcodes.
type - Variable in class com.sleepycat.asm.Handler
Constant pool index of the internal name of the type of exceptions handled by this handler, or 0 to catch any exceptions.
type - Variable in class com.sleepycat.asm.Item
Type of this constant pool item.
Type - Class in com.sleepycat.asm
A Java field or method type.
TYPE_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of instructions with a type descriptor argument.
TYPE_MERGED - Static variable in class com.sleepycat.asm.ClassWriter
Merged type Item stored in the ClassWriter ClassWriter.typeTable, instead of the constant pool, in order to avoid clashes with normal constant pool items in the ClassWriter constant pool's hash table.
TYPE_NORMAL - Static variable in class com.sleepycat.asm.ClassWriter
Normal type Item stored in the ClassWriter ClassWriter.typeTable, instead of the constant pool, in order to avoid clashes with normal constant pool items in the ClassWriter constant pool's hash table.
TYPE_UNINIT - Static variable in class com.sleepycat.asm.ClassWriter
Uninitialized type Item stored in the ClassWriter ClassWriter.typeTable, instead of the constant pool, in order to avoid clashes with normal constant pool items in the ClassWriter constant pool's hash table.
typeForDbName(String) - Static method in class com.sleepycat.je.dbi.DbTree
Returns the DbType for a given DB name.
typeTable - Variable in class com.sleepycat.asm.ClassWriter
A type table used to temporarily store internal names that will not necessarily be stored in the constant pool.

U

UID_WIDTH - Static variable in class com.sleepycat.je.rep.elections.TimebasedProposalGenerator
 
unblockTxnCompletion() - Method in class com.sleepycat.je.rep.impl.RepImpl
Releases the transaction block latch.
undo() - Method in class com.sleepycat.je.txn.Txn
Undo write operations and release all resources held by the transaction.
undoDatabases - Variable in class com.sleepycat.je.txn.Txn
 
UndoReader - Class in com.sleepycat.je.txn
Convenience class to package together the different steps and fields needed for reading a log entry for undoing.
UndoReader(EnvironmentImpl, long, Map<DatabaseId, DatabaseImpl>) - Constructor for class com.sleepycat.je.txn.UndoReader
 
UndoReader(LNFileReader, DbTree) - Constructor for class com.sleepycat.je.txn.UndoReader
 
unevolvedFormatsEncountered - Static variable in class com.sleepycat.persist.impl.PersistCatalog
 
unexpectedException(Exception) - Static method in class com.sleepycat.compat.DbCompat
 
unexpectedException(String, Exception) - Static method in class com.sleepycat.compat.DbCompat
 
unexpectedException(Exception) - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
unexpectedException(EnvironmentImpl, Exception) - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
unexpectedException(String, Exception) - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
unexpectedException(EnvironmentImpl, String, Exception) - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
unexpectedState(String) - Static method in class com.sleepycat.compat.DbCompat
 
unexpectedState() - Static method in class com.sleepycat.compat.DbCompat
 
unexpectedState() - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
unexpectedState(EnvironmentImpl) - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
unexpectedState(String) - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
unexpectedState(EnvironmentImpl, String) - Static method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
unfreezeLocalCBVLSN() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
unfreezeLocalCBVLSN() - Method in class com.sleepycat.je.rep.impl.node.RepNode
 
unfreezeLocalCBVLSN() - Method in class com.sleepycat.je.rep.impl.RepImpl
 
UNINITIALIZED - Static variable in class com.sleepycat.asm.Frame
Base kind of the uninitialized base types.
UNINITIALIZED_THIS - Static variable in class com.sleepycat.asm.Frame
The UNINITIALIZED_THIS type.
UNINITIALIZED_THIS - Static variable in interface com.sleepycat.asm.Opcodes
 
UniqueConstraintException - Exception in com.sleepycat.je
Thrown when an attempt to write a primary database record would insert a secondary record with a duplicate key, for secondaries that represent one-to-one and one-to-many relationships.
UniqueConstraintException(Locker, String, String, DatabaseEntry, DatabaseEntry) - Constructor for exception com.sleepycat.je.UniqueConstraintException
For internal use only.
uniqueIdGenerator - Static variable in class com.sleepycat.je.rep.elections.TimebasedProposalGenerator
 
UNKNOWN_FILE_HEADER_VERSION - Static variable in class com.sleepycat.je.log.LogEntryType
Should be used for reading the entry header of the file header, since the actual version is not known until the FileHeader item is read.
UnknownMasterException - Exception in com.sleepycat.je.rep
Indicates that the underlying operation requires communication with a Master, but that a Master was not available.
UnknownMasterException(Locker, StateChangeEvent) - Constructor for exception com.sleepycat.je.rep.UnknownMasterException
 
UnknownMasterException(String) - Constructor for exception com.sleepycat.je.rep.UnknownMasterException
Used when the inability to determine a master is not related to a state change.
UnknownMasterException(String, Exception) - Constructor for exception com.sleepycat.je.rep.UnknownMasterException
Used when the inability to determine a master is not related to a state change but some inability to communicate with a node identified as a master.
unknownReplicated() - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
unlockOnce() - Method in class com.sleepycat.je.rep.txn.MasterTxn
Determines whether we should unlock the block-latch lock.
unmarshalEntry(TupleInput) - Method in interface com.sleepycat.bind.tuple.MarshalledTupleEntry
Construct the key or data object from the key or data tuple entry.
unmarshallTriggers(String, byte[][], ClassLoader) - Static method in class com.sleepycat.je.dbi.TriggerUtils
Deserializes the trigger representation to yield the trigger object instance.
unmarshalPrimaryKey(TupleInput) - Method in interface com.sleepycat.bind.tuple.MarshalledTupleKeyEntity
Completes construction of the entity by setting its primary key from the stored primary key.
unNoteLatch(Object, String) - Method in class com.sleepycat.je.latch.LatchTable
Only call under the assert system.
unRegisterCursor(CursorImpl) - Method in class com.sleepycat.je.txn.BasicLocker
This txn doesn't store cursors.
unRegisterCursor(CursorImpl) - Method in class com.sleepycat.je.txn.Locker
Remove a cursor from this txn.
unRegisterCursor(CursorImpl) - Method in class com.sleepycat.je.txn.ReadCommittedLocker
Forwards this method to the transactional buddy.
unRegisterCursor(CursorImpl) - Method in class com.sleepycat.je.txn.Txn
Decrease the counter if a Cursor is closed under this transaction.
unregisterDataSet(String) - Method in class com.sleepycat.je.sync.SyncProcessor
Called internally by the SyncProcessor during a call to SyncProcessor.removeDataSet(java.lang.String).
unregisterExceptionListenerUser(ExceptionListenerUser) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
unregisterThreadLocker(ThreadLocker) - Method in class com.sleepycat.je.txn.LockManager
Called when a ThreadLocker is closed.
unRegisterTxn(Txn, boolean) - Method in class com.sleepycat.je.txn.TxnManager
Called when txn ends.
unRegisterXATxn(Xid, boolean) - Method in class com.sleepycat.je.txn.TxnManager
Called when txn ends.
unsetTxnForThread() - Method in class com.sleepycat.je.txn.TxnManager
Called when txn is assoc'd with this thread.
UNSIGNED_INT_BYTES - Static variable in class com.sleepycat.je.log.LogUtils
 
unSync() - Method in class com.sleepycat.je.rep.stream.MasterStatus
 
unwrap(Exception) - Static method in class com.sleepycat.util.ExceptionUnwrapper
Unwraps an Exception and returns the underlying Exception, or throws an Error if the underlying Throwable is an Error.
unwrapAny(Throwable) - Static method in class com.sleepycat.util.ExceptionUnwrapper
Unwraps an Exception and returns the underlying Throwable.
update(ByteBuffer, int) - Method in class com.sleepycat.je.log.ChecksumValidator
Add this byte buffer to the checksum.
update(byte[], int, int) - Method in class com.sleepycat.je.log.ChecksumValidator
 
update() - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNUpdater
Update the database, with the local CBVLSN associated with the node ID if required.
update(NameIdPair) - Method in class com.sleepycat.je.rep.impl.node.NameIdPair
 
update(byte[], int, int) - Method in class com.sleepycat.je.utilint.Adler32.ChunkingAdler32
 
update(int) - Method in class com.sleepycat.je.utilint.Adler32
Update current Adler-32 checksum given the specified byte.
update(byte[], int, int) - Method in class com.sleepycat.je.utilint.Adler32
Update current Adler-32 checksum given the specified byte array.
update(V) - Method in class com.sleepycat.persist.BasicCursor
 
update(V) - Method in interface com.sleepycat.persist.EntityCursor
Replaces the entity at the cursor position with the given entity.
update(String) - Method in class com.sleepycat.persist.evolve.EvolveEvent
 
UPDATE_ADDRESS - Variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
UPDATE_GENERATION - Static variable in class com.sleepycat.je.cleaner.Cleaner
Whether to update the IN generation count during searches.
updateAddress(String, String, int) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Update the network address of a node.
updateAddress(String, String, int) - Method in class com.sleepycat.je.rep.util.DbGroupAdmin
Update the network address for a specified node.
updateAddress(String, String, int) - Method in class com.sleepycat.je.rep.util.ReplicationGroupAdmin
Update the network address for a specified member of the replication group.
updateAdminMemoryUsage(long) - Method in class com.sleepycat.je.dbi.MemoryBudget
Update the environment wide admin memory count, wake up the evictor if necessary.
updateAllowed - Variable in class com.sleepycat.persist.BasicCursor
 
updateBackgroundReads(int) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
If a background read limit has been configured and that limit is exceeded when the cumulative total is incremented by the given number of reads, increment the sleep backlog to cause a sleep to occur.
updateBackgroundWrites(int, int) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
If a background write limit has been configured and that limit is exceeded when the given amount written is added to the cumulative total, increment the sleep backlog to cause a sleep to occur.
updateBin(int) - Method in class com.sleepycat.je.dbi.CursorImpl
 
updateCacheStats(boolean, Evictor) - Method in class com.sleepycat.je.tree.INArrayRep
Update the cache statistics for this representation.
updateCacheStats(boolean, IN) - Method in class com.sleepycat.je.tree.INArrayRep
Updates the cache statistics associated with this representation.
updateCacheStats(boolean, Evictor) - Method in class com.sleepycat.je.tree.INKeyRep.Default
 
updateCacheStats(boolean, Evictor) - Method in class com.sleepycat.je.tree.INKeyRep.MaxKeySize
 
updateCacheStats(boolean, Evictor) - Method in class com.sleepycat.je.tree.INTargetRep.Default
 
updateCacheStats(boolean, Evictor) - Method in class com.sleepycat.je.tree.INTargetRep.None
 
updateCacheStats(boolean, Evictor) - Method in class com.sleepycat.je.tree.INTargetRep.Sparse
 
updateCacheUsage(long) - Method in class com.sleepycat.je.dbi.MemoryBudget.Totals
 
updateCBVLSN(LocalCBVLSNUpdater) - Method in class com.sleepycat.je.rep.impl.RepImpl
Updates the CBVLSN on behalf of a Feeder input thread (or FeederManager running in the RepNode thread), while avoiding the possibility that the resulting GroupDB update may get blocked behind the final phase of a master transfer.
updateEntry(int, Node, long, byte[]) - Method in class com.sleepycat.je.tree.IN
Update the idx'th entry of this node.
updateEntry(int, long) - Method in class com.sleepycat.je.tree.IN
Update the idx'th entry of this node.
updateEntry(int, long, byte) - Method in class com.sleepycat.je.tree.IN
Update the idx'th entry of this node.
updateEvent(EvolveEvent, String, int, int) - Static method in class com.sleepycat.persist.evolve.EvolveInternal
Internal access method that should not be used by applications.
updateFilesAtCheckpointEnd(FileSelector.CheckpointStartCleanerState) - Method in class com.sleepycat.je.cleaner.Cleaner
When a checkpoint is complete, update the files that were returned at the beginning of the checkpoint.
updateFilesAtCheckpointEnd(FileSelector.CheckpointStartCleanerState) - Method in class com.sleepycat.je.cleaner.FileSelector
When a checkpoint is complete, move the previously CLEANED and FULLY_PROCESSED files to the CHECKPOINTED and SAFE_TO_DELETE status.
updateForMaster(LocalCBVLSNTracker) - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNUpdater
As a master, update the database with the local CBVLSN for this node.
updateForReplica(VLSN) - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNUpdater
Exercise caution when using this method.
updateForReplica(Protocol.HeartbeatResponse) - Method in class com.sleepycat.je.rep.impl.node.LocalCBVLSNUpdater
Sets the current CBVLSN for this node.
updateFromReplay(DatabaseId) - Method in class com.sleepycat.je.dbi.DbTree
 
updateFromReplay(long) - Method in class com.sleepycat.je.dbi.NodeSequence
 
updateFromReplay(long) - Method in class com.sleepycat.je.txn.TxnManager
 
updateGroupInfo(NameIdPair, RepGroupImpl.BarrierState) - Method in class com.sleepycat.je.rep.impl.node.RepNode
Updates the cached group info for the node, avoiding a database read.
updateLocalCBVLSN(NameIdPair, VLSN) - Method in class com.sleepycat.je.rep.impl.RepGroupDB
Updates the database entry associated with the node with the new local CBVLSN, if it can do so without encountering lock contention.
updateLockMemoryUsage(long, int) - Method in class com.sleepycat.je.dbi.MemoryBudget
 
updateLoggedForTxn() - Method in class com.sleepycat.je.rep.txn.ReplayTxn
Always return true in order to ensure that the VLSN is logged.
updateLoggedForTxn() - Method in class com.sleepycat.je.txn.Txn
 
updateLsnAfterOptionalLog(DatabaseImpl, long) - Method in class com.sleepycat.je.tree.ChildReference
Do deferredWrite optional logging check.
updateMember(RepNodeImpl) - Method in class com.sleepycat.je.rep.impl.RepGroupDB
 
updateMemorySize(long, long) - Method in class com.sleepycat.je.tree.IN
 
updateMemorySize(Node, Node) - Method in class com.sleepycat.je.tree.IN
 
updateNameLN(Locker, String, DbOpReplicationContext) - Method in class com.sleepycat.je.dbi.DbTree
Update the NameLN for the DatabaseImpl when the DatabaseConfig changes.
updateNode(int, long, long, byte[], Node) - Method in class com.sleepycat.je.tree.IN
Update the idx'th entry of this node.
updateNode(int, Node, byte[]) - Method in class com.sleepycat.je.tree.IN
Update the idx'th entry, replacing the node and, if appropriate, the LN slot key.
updateNode(int, Node, long, byte[]) - Method in class com.sleepycat.je.tree.IN
Update the idx'th entry, replacing the node and, if appropriate, the LN slot key.
updateNodeIds(Set<Integer>) - Method in class com.sleepycat.je.rep.impl.TextProtocol
Updates the current set of nodes that constitutes the group.
updateReadOnlyFileCollections() - Method in class com.sleepycat.je.cleaner.Cleaner
Update the lowUtilizationFiles and toBeCleanedFiles fields with new read-only collections.
updateRepGroup(RepGroupImpl) - Method in class com.sleepycat.je.rep.elections.Elections
Updates elections notion of the rep group, so that acceptors are aware of the current state of the group, even in the absence of an election conducted by the node itself.
updateSecondary(Locker, Cursor, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.je.SecondaryDatabase
Updates a single secondary when a put() or delete() is performed on the primary.
updateSyncStart(String, SyncCleanerBarrier.StartInfo) - Method in class com.sleepycat.je.sync.impl.SyncCleanerBarrier
 
updateTips() - Method in class com.sleepycat.je.jmx.plugin.Stats
 
updateTreeAdminMemoryUsage(long) - Method in class com.sleepycat.je.dbi.MemoryBudget
Update the treeAdmin memory count, wake up the evictor if necessary.
updateTreeMemoryUsage(long) - Method in class com.sleepycat.je.dbi.MemoryBudget
Update the environment wide tree memory count, wake up the evictor if necessary.
updateTxnMemoryUsage(long) - Method in class com.sleepycat.je.dbi.MemoryBudget
Update the environment wide txn memory count, wake up the evictor if necessary.
UPPER_IN_EVICTION_TYPE_DESC - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
UPPER_IN_FETCH - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
UPPER_IN_FETCH_MISS - Static variable in class com.sleepycat.je.evictor.EvictorStatDefinition
 
us - Variable in class com.sleepycat.je.utilint.TimingLatch.AcquireCompleteEvent
 
us - Variable in class com.sleepycat.je.utilint.TimingLatch.AcquireRequestEvent
 
us - Variable in class com.sleepycat.je.utilint.TimingLatch.ReleaseEvent
 
USE_JAVA5_ADLER32 - Static variable in class com.sleepycat.je.dbi.EnvironmentImpl
 
useEvolvedFormat(Format, Reader, Format) - Method in class com.sleepycat.persist.impl.Evolver
Install an evolver Reader in the old format.
useExistingFormat(Format) - Method in class com.sleepycat.persist.impl.PersistCatalog
Installs an existing format when no evolution is needed, i.e, when the new and old formats are identical.
useKey(Object, Object, DatabaseEntry, KeyRange) - Method in class com.sleepycat.collections.DataView
Populates the key entry and returns whether the key is within range.
useLock - Variable in class com.sleepycat.je.txn.LockAttemptResult
 
useMaxDbId - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
useMaxNodeId - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
useMaxTxnId - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
useMinReplicatedDbId - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
useMinReplicatedNodeId - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
useMinReplicatedTxnId - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
useOldFormat(Format, Format) - Method in class com.sleepycat.persist.impl.Evolver
Use the old format and discard the new format.
USER_HALT_REQUEST - Static variable in class com.sleepycat.je.PreloadStatus
The user requested that preload stop during a call to ProgressListener.progress().
useRangeKey() - Method in class com.sleepycat.collections.DataCursor
Sets the key entry to the begin key of a single key range, so the next time a putXxx() method is called that key will be used.
useRootLsn - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
useSubRange() - Method in class com.sleepycat.collections.DataView
Returns the range to use for sub-ranges.
useTransaction() - Method in class com.sleepycat.collections.DataView
Returns the current transaction if the database is transaction, or null if the database is not transactional or there is no current transaction.
useValue(Object, DatabaseEntry, DatabaseEntry) - Method in class com.sleepycat.collections.DataView
Populates the value entry and throws an exception if the primary key would be changed via an entity binding.
UTF8 - Static variable in class com.sleepycat.asm.ClassWriter
The type of CONSTANT_Utf8 constant pool items.
UtfOps - Class in com.sleepycat.util
UTF operations with more flexibility than is provided by DataInput and DataOutput.
UtfOps() - Constructor for class com.sleepycat.util.UtfOps
 
utilization() - Method in class com.sleepycat.je.cleaner.FileSummary
Calculates utilization percentage using average LN sizes.
utilization(float) - Method in class com.sleepycat.je.cleaner.FileSummary
Calculates utilization percentage using average LN sizes, using a given correction factor for LN sizes that were not counted.
utilization(long, long) - Static method in class com.sleepycat.je.cleaner.FileSummary
Calculates a utilization percentage.
UTILIZATION_PROFILE_ENTRY - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
UtilizationCalculator - Class in com.sleepycat.je.cleaner
Contains methods for calculating utilization and for selecting files to clean.
UtilizationCalculator(EnvironmentImpl, Cleaner) - Constructor for class com.sleepycat.je.cleaner.UtilizationCalculator
 
UtilizationCalculator.AverageSize - Class in com.sleepycat.je.cleaner
Bundles a count of LNs and their total size, for use in calculating a running average.
UtilizationCalculator.AverageSize(int, int, int, int) - Constructor for class com.sleepycat.je.cleaner.UtilizationCalculator.AverageSize
 
UtilizationCalculator.TestAdjustment - Class in com.sleepycat.je.cleaner
For passing adjustment information to a test hook.
UtilizationCalculator.TestAdjustment(long, long, FileSummary, FileSummary, float, float, float) - Constructor for class com.sleepycat.je.cleaner.UtilizationCalculator.TestAdjustment
 
UtilizationFileReader - Class in com.sleepycat.je.log
Summarizes the utilized and unutilized portion of each log file by examining each log entry.
UtilizationProfile - Class in com.sleepycat.je.cleaner
The UP tracks utilization summary information for all log files.
UtilizationProfile(EnvironmentImpl, UtilizationTracker) - Constructor for class com.sleepycat.je.cleaner.UtilizationProfile
Creates an empty UP.
UtilizationTracker - Class in com.sleepycat.je.cleaner
Tracks changes to the utilization profile since the last checkpoint.
UtilizationTracker(EnvironmentImpl) - Constructor for class com.sleepycat.je.cleaner.UtilizationTracker
Creates an empty tracker.
UtilizationTracker(EnvironmentImpl, Cleaner) - Constructor for class com.sleepycat.je.cleaner.UtilizationTracker
Constructor used by the cleaner constructor, prior to setting the cleaner field of the environment.
Utils - Class in com.sleepycat.je.rep.elections
 
Utils() - Constructor for class com.sleepycat.je.rep.elections.Utils
 
Utils.WithFutureExceptionHandler - Class in com.sleepycat.je.rep.elections
 
Utils.WithFutureExceptionHandler() - Constructor for class com.sleepycat.je.rep.elections.Utils.WithFutureExceptionHandler
 

V

V1_1 - Static variable in interface com.sleepycat.asm.Opcodes
 
V1_2 - Static variable in interface com.sleepycat.asm.Opcodes
 
V1_3 - Static variable in interface com.sleepycat.asm.Opcodes
 
V1_4 - Static variable in interface com.sleepycat.asm.Opcodes
 
V1_5 - Static variable in interface com.sleepycat.asm.Opcodes
 
V1_6 - Static variable in interface com.sleepycat.asm.Opcodes
 
V1_7 - Static variable in interface com.sleepycat.asm.Opcodes
 
VALID_FOR_CLOSE - Static variable in class com.sleepycat.je.dbi.DbEnvState
 
validate(DatabaseConfig) - Method in class com.sleepycat.je.DatabaseConfig
For JCA Database handle caching.
validate(DatabaseConfig, DatabaseConfig) - Static method in class com.sleepycat.je.DbInternal
Proxy to DatabaseConfig.validate(DatabaseConfig()
validate(long, long) - Method in class com.sleepycat.je.log.ChecksumValidator
 
validate(long, long, long) - Method in class com.sleepycat.je.log.ChecksumValidator
 
validate(EnvironmentImpl, String, long) - Method in class com.sleepycat.je.log.FileHeader
 
validate(DatabaseConfig) - Method in class com.sleepycat.je.SecondaryConfig
For JCA Database handle caching.
validateDelete(int) - Method in class com.sleepycat.je.tree.Tree
Unit test support to validate subtree pruning.
validateForNewDb() - Method in class com.sleepycat.je.DatabaseConfig
Checks that this database configuration is valid for a new, non-existant database.
validateINList(IN) - Method in class com.sleepycat.je.tree.Tree
Debugging check that all resident nodes are on the INList and no stray nodes are present in the unused portion of the IN arrays.
validateOnDbOpen(String, boolean) - Method in class com.sleepycat.je.DatabaseConfig
Perform validations at database open time on the completed DbConfig object.
validateOwnership(Long, Locker, LockType, boolean, MemoryBudget) - Method in class com.sleepycat.je.txn.DummyLockManager
 
validateOwnership(Long, Locker, LockType, boolean, MemoryBudget) - Method in class com.sleepycat.je.txn.LockManager
 
validateOwnership(Long, Locker, LockType, boolean, MemoryBudget) - Method in class com.sleepycat.je.txn.SyncedLockManager
 
validateOwnershipInternal(Long, Locker, LockType, boolean, MemoryBudget, int) - Method in class com.sleepycat.je.txn.LockManager
 
validateParams - Variable in class com.sleepycat.je.EnvironmentMutableConfig
Internal boolean that says whether or not to validate params.
validateParams - Variable in class com.sleepycat.je.rep.ReplicationMutableConfig
 
validateProperties(Properties, boolean, String) - Static method in class com.sleepycat.je.dbi.DbConfigManager
Validate a collection of configurations, checking that - the name and value are valid - a replication param is not being set through an EnvironmentConfig class, and a non-rep param is not set through a ReplicationConfig instance.
validateProperties(Properties) - Method in class com.sleepycat.je.rep.ReplicationMutableConfig
Validate a property bag passed in a construction time.
validateSubtreeBeforeDelete(int) - Method in class com.sleepycat.je.tree.BIN
 
validateSubtreeBeforeDelete(int) - Method in class com.sleepycat.je.tree.IN
 
validateValue(String) - Method in class com.sleepycat.je.config.BooleanConfigParam
Make sure that value is a valid string for booleans.
validateValue(String) - Method in class com.sleepycat.je.config.ConfigParam
Validate your value.
validateValue(String) - Method in class com.sleepycat.je.config.DurationConfigParam
 
validateValue(String) - Method in class com.sleepycat.je.config.IntConfigParam
 
validateValue(String) - Method in class com.sleepycat.je.config.LongConfigParam
 
validateValue(String) - Method in class com.sleepycat.je.config.ShortConfigParam
 
validateValue(String) - Method in class com.sleepycat.je.rep.impl.EnumConfigParam
 
validateValue(String) - Method in class com.sleepycat.je.rep.impl.RepParams.IdentifierConfigParam
 
value - Variable in class com.sleepycat.asm.Attribute
The raw value of this attribute, used only for unknown attributes.
VALUE - Static variable in class com.sleepycat.asm.Frame
Mask to get the value of a frame type.
ValueAdapter<V> - Interface in com.sleepycat.persist
An adapter that translates between database entries (key, primary key, data) and a "value", which may be either the key, primary key, or entity.
valueBinding - Variable in class com.sleepycat.collections.DataView
 
valueOf(String) - Static method in enum com.sleepycat.je.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.Database.DbState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.dbi.CursorImpl.SearchMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.dbi.DbType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.dbi.EnvironmentFailureReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.dbi.GetMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.dbi.PutMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.dbi.StartupTracker.Phase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.Durability.ReplicaAckPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.Durability.SyncPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.evictor.Evictor.EvictionSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.ForeignKeyDeleteAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.LockMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.log.entry.DbOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.log.entry.LNLogEntry.DupStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.log.FileManager.FileMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.log.LogEntryType.Marshall
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.log.LogEntryType.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.log.LogEntryType.Replicable
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.log.LogEntryType.Txnal
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.log.Provisional
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.OperationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.PreloadConfig.Phases
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.recovery.DirtyINMap.CkptState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.RecoveryProgress
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.impl.node.ReplicaFactory.ReplicaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.impl.RepGroupProtocol.FailReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.impl.TextProtocol.MessageError
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.impl.TextProtocol.TOKENS
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.monitor.GroupChangeEvent.GroupChangeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.monitor.LeaveGroupEvent.LeaveReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.QuorumPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.ReplicatedEnvironment.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.SyncupProgress
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.util.DbGroupAdmin.Command
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.rep.utilint.ServiceDispatcher.Response
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.sync.ChangeReader.ChangeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.sync.impl.SyncDB.DataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.sync.impl.SyncDB.OpType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.Transaction.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.tree.INKeyRep.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.tree.INTargetRep.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.je.txn.LockGrantType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.persist.model.DeleteAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sleepycat.persist.model.Relationship
Returns the enum constant of this type with the specified name.
values() - Method in class com.sleepycat.collections.StoredMap
Returns a collection view of the values contained in this map.
values() - Static method in enum com.sleepycat.je.CacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.Database.DbState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.dbi.CursorImpl.SearchMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.dbi.DbType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.dbi.EnvironmentFailureReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.dbi.GetMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.dbi.PutMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.dbi.StartupTracker.Phase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.Durability.ReplicaAckPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.Durability.SyncPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.evictor.Evictor.EvictionSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.ForeignKeyDeleteAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.LockMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.log.entry.DbOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.log.entry.LNLogEntry.DupStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.log.FileManager.FileMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.log.LogEntryType.Marshall
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.log.LogEntryType.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.log.LogEntryType.Replicable
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.log.LogEntryType.Txnal
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.log.Provisional
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.OperationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.PreloadConfig.Phases
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.recovery.DirtyINMap.CkptState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.RecoveryProgress
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.impl.node.ReplicaFactory.ReplicaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.impl.RepGroupProtocol.FailReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.impl.TextProtocol.MessageError
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.impl.TextProtocol.TOKENS
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.monitor.GroupChangeEvent.GroupChangeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.monitor.LeaveGroupEvent.LeaveReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.QuorumPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.ReplicatedEnvironment.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.SyncupProgress
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.util.DbGroupAdmin.Command
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.rep.utilint.ServiceDispatcher.Response
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.sleepycat.je.rep.utilint.SizeAwaitMap
 
values() - Static method in enum com.sleepycat.je.sync.ChangeReader.ChangeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.sync.impl.SyncDB.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.sync.impl.SyncDB.OpType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.Transaction.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.tree.INKeyRep.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.tree.INTargetRep.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.je.txn.LockGrantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.persist.model.DeleteAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sleepycat.persist.model.Relationship
Returns an array containing the constants of this enum type, in the order they are declared.
valueSetView() - Method in class com.sleepycat.collections.DataView
Return a new value-set view derived from this view by setting the key binding to null.
valueSetView(Object) - Method in class com.sleepycat.collections.DataView
Return a new value-set view for single key range.
valueToData(V, DatabaseEntry) - Method in class com.sleepycat.persist.DataValueAdapter
 
valueToData(V, DatabaseEntry) - Method in class com.sleepycat.persist.EntityValueAdapter
 
valueToData(V, DatabaseEntry) - Method in class com.sleepycat.persist.KeyValueAdapter
 
valueToData(V, DatabaseEntry) - Method in class com.sleepycat.persist.PrimaryKeyValueAdapter
 
valueToData(V, DatabaseEntry) - Method in interface com.sleepycat.persist.ValueAdapter
Converts an entity value to a data entry using an entity binding, or throws UnsupportedOperationException if this is not appropriate.
VAR_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of instructions with a local variable index argument.
verbose - Variable in class com.sleepycat.je.log.DumpFileReader
 
verbose - Variable in class com.sleepycat.je.rep.util.ldiff.LDiffConfig
 
verbose - Variable in class com.sleepycat.je.util.DbDump
 
verify(VerifyConfig) - Method in class com.sleepycat.je.Database
Verifies the integrity of the database.
verify(VerifyConfig, DatabaseStats) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
verify(VerifyConfig, PrintStream) - Method in class com.sleepycat.je.dbi.DbTree
 
verify(VerifyConfig, PrintStream) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
verify(VerifyConfig, PrintStream) - Method in class com.sleepycat.je.Environment
Returns if the database environment is consistent and correct.
verify() - Method in class com.sleepycat.je.rep.ReplicationConfig
 
verify(boolean) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
 
verify(boolean) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
verify(boolean) - Method in class com.sleepycat.je.rep.vlsn.VLSNTracker
For unit test support.
verify(byte[]) - Method in class com.sleepycat.je.tree.IN
Check that the IN is in a valid state.
verify(byte[]) - Method in class com.sleepycat.je.tree.Node
 
verify(PrintStream) - Method in class com.sleepycat.je.util.DbVerify
Verifies a database and write errors found to a stream.
verify(long, long) - Method in class com.sleepycat.je.util.DbVerifyLog
Verifies the given range of log files in the environment.
VERIFY_CHECKSUMS - Variable in class com.sleepycat.je.log.FileManager
 
verifyAll() - Method in class com.sleepycat.je.util.DbVerifyLog
Verifies all log files in the environment.
verifyBucketBoundaries(ArrayList<VLSN>, ArrayList<VLSN>) - Static method in class com.sleepycat.je.rep.vlsn.VLSNTracker
 
VerifyConfig - Class in com.sleepycat.je
Specifies the attributes of a verification operation.
VerifyConfig() - Constructor for class com.sleepycat.je.VerifyConfig
An instance created using the default constructor is initialized with the system's default settings.
VerifyConfigBeanInfo - Class in com.sleepycat.je
 
VerifyConfigBeanInfo() - Constructor for class com.sleepycat.je.VerifyConfigBeanInfo
 
verifyCursors() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
 
verifyCursors() - Method in class com.sleepycat.je.incomp.INCompressor
 
verifyCursors() - Method in class com.sleepycat.je.tree.BIN
For each cursor in this BIN's cursor set, ensure that the cursor is actually referring to this BIN.
verifyDb(Environment, PrintStream, boolean) - Static method in class com.sleepycat.je.rep.vlsn.VLSNIndex
For DbStreamVerify utility.
verifyFileSummaryDatabase() - Method in class com.sleepycat.je.cleaner.UtilizationProfile
Checks that all FSLN offsets are indeed obsolete.
verifyKeyPrefix() - Method in class com.sleepycat.je.tree.IN
 
verifyMemorySize() - Method in class com.sleepycat.je.tree.IN
 
verifyNegativeSequences(String) - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
 
verifyNode(Node) - Method in class com.sleepycat.je.dbi.DatabaseImpl.StatsAccumulator
 
verifySubset(boolean, VLSNRange) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
 
verifyUtilization(EnvironmentImpl, boolean, boolean, boolean) - Static method in class com.sleepycat.je.cleaner.VerifyUtils
Compare utilization as calculated by UtilizationProfile to utilization as calculated by UtilizationFileReader.
VerifyUtils - Class in com.sleepycat.je.cleaner
Verify cleaner data structures
VerifyUtils() - Constructor for class com.sleepycat.je.cleaner.VerifyUtils
 
version - Variable in class com.sleepycat.asm.ClassWriter
Minor and major version numbers of the class to be generated.
VERSION - Static variable in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol
 
VERSION - Static variable in class com.sleepycat.je.rep.impl.networkRestore.Protocol
 
VERSION - Static variable in class com.sleepycat.je.rep.impl.NodeStateProtocol
 
VERSION - Static variable in class com.sleepycat.je.rep.impl.RepGroupProtocol
 
VERSION - Static variable in class com.sleepycat.je.rep.monitor.Protocol
 
VERSION - Static variable in class com.sleepycat.je.rep.util.ldiff.Protocol
 
VersionedLN - Class in com.sleepycat.je.tree
VersionedLN is used to provide an in-memory representation of an LN that makes its VLSN available through btree access.
VersionedLN() - Constructor for class com.sleepycat.je.tree.VersionedLN
 
VersionedLN(byte[]) - Constructor for class com.sleepycat.je.tree.VersionedLN
 
VersionedLN(DatabaseEntry) - Constructor for class com.sleepycat.je.tree.VersionedLN
 
VersionedLN(SizeofMarker, DatabaseEntry) - Constructor for class com.sleepycat.je.tree.VersionedLN
For Sizeof.
VERSIONEDLN_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
VersionMismatchException - Exception in com.sleepycat.je
Thrown by the Environment constructor when an environment cannot be opened because the version of the existing log is not compatible with the version of JE that is running.
VersionMismatchException(EnvironmentImpl, String) - Constructor for exception com.sleepycat.je.VersionMismatchException
For internal use only.
view - Variable in class com.sleepycat.collections.StoredContainer
 
visit(String, Object) - Method in class com.sleepycat.asm.AnnotationVisitor
Visits a primitive value of the annotation.
visit(String, Object) - Method in class com.sleepycat.asm.AnnotationWriter
 
visit(int, int, String, String, String, String[]) - Method in class com.sleepycat.asm.ClassVisitor
Visits the header of the class.
visit(int, int, String, String, String, String[]) - Method in class com.sleepycat.asm.ClassWriter
 
visit(int, int, String, String, String, String[]) - Method in class com.sleepycat.persist.model.BytecodeEnhancer
 
visitAnnotation(String, String) - Method in class com.sleepycat.asm.AnnotationVisitor
Visits a nested annotation value of the annotation.
visitAnnotation(String, String) - Method in class com.sleepycat.asm.AnnotationWriter
 
visitAnnotation(String, boolean) - Method in class com.sleepycat.asm.ClassVisitor
Visits an annotation of the class.
visitAnnotation(String, boolean) - Method in class com.sleepycat.asm.ClassWriter
 
visitAnnotation(String, boolean) - Method in class com.sleepycat.asm.FieldVisitor
Visits an annotation of the field.
visitAnnotation(String, boolean) - Method in class com.sleepycat.asm.FieldWriter
 
visitAnnotation(String, boolean) - Method in class com.sleepycat.asm.MethodVisitor
Visits an annotation of this method.
visitAnnotation(String, boolean) - Method in class com.sleepycat.asm.MethodWriter
 
visitAnnotation(String, boolean) - Method in class com.sleepycat.persist.model.BytecodeEnhancer
 
visitAnnotationDefault() - Method in class com.sleepycat.asm.MethodVisitor
Visits the default value of this annotation interface method.
visitAnnotationDefault() - Method in class com.sleepycat.asm.MethodWriter
 
visitArray(String) - Method in class com.sleepycat.asm.AnnotationVisitor
Visits an array value of the annotation.
visitArray(String) - Method in class com.sleepycat.asm.AnnotationWriter
 
visitAttribute(Attribute) - Method in class com.sleepycat.asm.ClassVisitor
Visits a non standard attribute of the class.
visitAttribute(Attribute) - Method in class com.sleepycat.asm.ClassWriter
 
visitAttribute(Attribute) - Method in class com.sleepycat.asm.FieldVisitor
Visits a non standard attribute of the field.
visitAttribute(Attribute) - Method in class com.sleepycat.asm.FieldWriter
 
visitAttribute(Attribute) - Method in class com.sleepycat.asm.MethodVisitor
Visits a non standard attribute of this method.
visitAttribute(Attribute) - Method in class com.sleepycat.asm.MethodWriter
 
visitCode() - Method in class com.sleepycat.asm.MethodVisitor
Starts the visit of the method's code, if any (i.e.
visitCode() - Method in class com.sleepycat.asm.MethodWriter
 
VISITED - Static variable in class com.sleepycat.asm.Label
Indicates if this subroutine basic block has been visited by a visitSubroutine(null, ...) call.
VISITED2 - Static variable in class com.sleepycat.asm.Label
Indicates if this subroutine basic block has been visited by a visitSubroutine(!null, ...) call.
VISITED_INIT_SIZE - Static variable in class com.sleepycat.persist.impl.RecordInput
 
visitEnd() - Method in class com.sleepycat.asm.AnnotationVisitor
Visits the end of the annotation.
visitEnd() - Method in class com.sleepycat.asm.AnnotationWriter
 
visitEnd() - Method in class com.sleepycat.asm.ClassVisitor
Visits the end of the class.
visitEnd() - Method in class com.sleepycat.asm.ClassWriter
 
visitEnd() - Method in class com.sleepycat.asm.FieldVisitor
Visits the end of the field.
visitEnd() - Method in class com.sleepycat.asm.FieldWriter
 
visitEnd() - Method in class com.sleepycat.asm.MethodVisitor
Visits the end of the method.
visitEnd() - Method in class com.sleepycat.asm.MethodWriter
 
visitEnd() - Method in class com.sleepycat.persist.model.BytecodeEnhancer
 
visitEnum(String, String, String) - Method in class com.sleepycat.asm.AnnotationVisitor
Visits an enumeration value of the annotation.
visitEnum(String, String, String) - Method in class com.sleepycat.asm.AnnotationWriter
 
visitField(int, String, String, String, Object) - Method in class com.sleepycat.asm.ClassVisitor
Visits a field of the class.
visitField(int, String, String, String, Object) - Method in class com.sleepycat.asm.ClassWriter
 
visitField(int, String, String, String, Object) - Method in class com.sleepycat.persist.model.BytecodeEnhancer
 
visitFieldInsn(int, String, String, String) - Method in class com.sleepycat.asm.MethodVisitor
Visits a field instruction.
visitFieldInsn(int, String, String, String) - Method in class com.sleepycat.asm.MethodWriter
 
visitFrame(int, int, Object[], int, Object[]) - Method in class com.sleepycat.asm.MethodVisitor
Visits the current state of the local variables and operand stack elements.
visitFrame(int, int, Object[], int, Object[]) - Method in class com.sleepycat.asm.MethodWriter
 
visitIincInsn(int, int) - Method in class com.sleepycat.asm.MethodVisitor
Visits an IINC instruction.
visitIincInsn(int, int) - Method in class com.sleepycat.asm.MethodWriter
 
visitInnerClass(String, String, String, int) - Method in class com.sleepycat.asm.ClassVisitor
Visits information about an inner class.
visitInnerClass(String, String, String, int) - Method in class com.sleepycat.asm.ClassWriter
 
visitInsn(int) - Method in class com.sleepycat.asm.MethodVisitor
Visits a zero operand instruction.
visitInsn(int) - Method in class com.sleepycat.asm.MethodWriter
 
visitIntInsn(int, int) - Method in class com.sleepycat.asm.MethodVisitor
Visits an instruction with a single int operand.
visitIntInsn(int, int) - Method in class com.sleepycat.asm.MethodWriter
 
visitInvokeDynamicInsn(String, String, Handle, Object...) - Method in class com.sleepycat.asm.MethodVisitor
Visits an invokedynamic instruction.
visitInvokeDynamicInsn(String, String, Handle, Object...) - Method in class com.sleepycat.asm.MethodWriter
 
visitJumpInsn(int, Label) - Method in class com.sleepycat.asm.MethodVisitor
Visits a jump instruction.
visitJumpInsn(int, Label) - Method in class com.sleepycat.asm.MethodWriter
 
visitLabel(Label) - Method in class com.sleepycat.asm.MethodVisitor
Visits a label.
visitLabel(Label) - Method in class com.sleepycat.asm.MethodWriter
 
visitLdcInsn(Object) - Method in class com.sleepycat.asm.MethodVisitor
Visits a LDC instruction.
visitLdcInsn(Object) - Method in class com.sleepycat.asm.MethodWriter
 
visitLineNumber(int, Label) - Method in class com.sleepycat.asm.MethodVisitor
Visits a line number declaration.
visitLineNumber(int, Label) - Method in class com.sleepycat.asm.MethodWriter
 
visitLocalVariable(String, String, String, Label, Label, int) - Method in class com.sleepycat.asm.MethodVisitor
Visits a local variable declaration.
visitLocalVariable(String, String, String, Label, Label, int) - Method in class com.sleepycat.asm.MethodWriter
 
visitLookupSwitchInsn(Label, int[], Label[]) - Method in class com.sleepycat.asm.MethodVisitor
Visits a LOOKUPSWITCH instruction.
visitLookupSwitchInsn(Label, int[], Label[]) - Method in class com.sleepycat.asm.MethodWriter
 
visitMaxs(int, int) - Method in class com.sleepycat.asm.MethodVisitor
Visits the maximum stack size and the maximum number of local variables of the method.
visitMaxs(int, int) - Method in class com.sleepycat.asm.MethodWriter
 
visitMethod(int, String, String, String, String[]) - Method in class com.sleepycat.asm.ClassVisitor
Visits a method of the class.
visitMethod(int, String, String, String, String[]) - Method in class com.sleepycat.asm.ClassWriter
 
visitMethod(int, String, String, String, String[]) - Method in class com.sleepycat.persist.model.BytecodeEnhancer
 
visitMethodInsn(int, String, String, String) - Method in class com.sleepycat.asm.MethodVisitor
Visits a method instruction.
visitMethodInsn(int, String, String, String) - Method in class com.sleepycat.asm.MethodWriter
 
visitMultiANewArrayInsn(String, int) - Method in class com.sleepycat.asm.MethodVisitor
Visits a MULTIANEWARRAY instruction.
visitMultiANewArrayInsn(String, int) - Method in class com.sleepycat.asm.MethodWriter
 
visitOuterClass(String, String, String) - Method in class com.sleepycat.asm.ClassVisitor
Visits the enclosing class of the class.
visitOuterClass(String, String, String) - Method in class com.sleepycat.asm.ClassWriter
 
visitParameterAnnotation(int, String, boolean) - Method in class com.sleepycat.asm.MethodVisitor
Visits an annotation of a parameter this method.
visitParameterAnnotation(int, String, boolean) - Method in class com.sleepycat.asm.MethodWriter
 
visitSource(String, String) - Method in class com.sleepycat.asm.ClassVisitor
Visits the source of the class.
visitSource(String, String) - Method in class com.sleepycat.asm.ClassWriter
 
visitSource(String, String) - Method in class com.sleepycat.persist.model.BytecodeEnhancer
 
visitSubroutine(Label, long, int) - Method in class com.sleepycat.asm.Label
Finds the basic blocks that belong to a given subroutine, and marks these blocks as belonging to this subroutine.
visitTableSwitchInsn(int, int, Label, Label...) - Method in class com.sleepycat.asm.MethodVisitor
Visits a TABLESWITCH instruction.
visitTableSwitchInsn(int, int, Label, Label...) - Method in class com.sleepycat.asm.MethodWriter
 
visitTryCatchBlock(Label, Label, Label, String) - Method in class com.sleepycat.asm.MethodVisitor
Visits a try catch block.
visitTryCatchBlock(Label, Label, Label, String) - Method in class com.sleepycat.asm.MethodWriter
 
visitTypeInsn(int, String) - Method in class com.sleepycat.asm.MethodVisitor
Visits a type instruction.
visitTypeInsn(int, String) - Method in class com.sleepycat.asm.MethodWriter
 
visitVarInsn(int, int) - Method in class com.sleepycat.asm.MethodVisitor
Visits a local variable instruction.
visitVarInsn(int, int) - Method in class com.sleepycat.asm.MethodWriter
 
vlsn - Variable in class com.sleepycat.je.rep.impl.node.MasterTransfer.VLSNProgress
 
vlsn - Variable in class com.sleepycat.je.rep.stream.MatchpointSearchResults.PassedTxnInfo
 
vlsn - Variable in class com.sleepycat.je.rep.stream.Protocol.VLSNMessage
 
vlsn - Variable in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
VLSN - Class in com.sleepycat.je.utilint
 
VLSN(long) - Constructor for class com.sleepycat.je.utilint.VLSN
 
VLSN() - Constructor for class com.sleepycat.je.utilint.VLSN
Constructor for VLSNs that are read from disk.
VLSN_LOG_CACHE_SIZE - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
VLSN_MAX_DIST - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
VLSN_MAX_MAP - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
VLSN_OFFSET - Static variable in class com.sleepycat.je.log.LogEntryHeader
 
VLSN_STRIDE - Static variable in class com.sleepycat.je.rep.impl.RepParams
 
VLSNBucket - Class in com.sleepycat.je.rep.vlsn
A VLSNBucket instance represents a set of VLSN->LSN mappings.
VLSNBucket(long, int, int, int, VLSN) - Constructor for class com.sleepycat.je.rep.vlsn.VLSNBucket
 
VLSNCache - Class in com.sleepycat.je.tree
Caches the VLSN sequence for the LN entries in a BIN, when VLSN preservation and caching are configured.
VLSNCache() - Constructor for class com.sleepycat.je.tree.VLSNCache
 
VLSNCache.DefaultCache - Class in com.sleepycat.je.tree
 
VLSNCache.DefaultCache(int, int) - Constructor for class com.sleepycat.je.tree.VLSNCache.DefaultCache
 
VLSNCache.DefaultCache(SizeofMarker) - Constructor for class com.sleepycat.je.tree.VLSNCache.DefaultCache
 
VLSNDistributionReader - Class in com.sleepycat.je.log
This is a debugging utility which implements the unadvertised DbPrintLog -vd option, which displays VLSN distribution in a log.
VLSNDistributionReader(EnvironmentImpl, int, long, long, long, boolean, boolean) - Constructor for class com.sleepycat.je.log.VLSNDistributionReader
Create this reader to start at a given LSN.
vlsnEvent(Proposer.Proposal) - Method in class com.sleepycat.je.rep.impl.node.CommitFreezeLatch
Invoked by the Learner thread whenever it receives an election result.
vlsnHeadTruncate(VLSN, long) - Method in class com.sleepycat.je.dbi.EnvironmentImpl
Adjust the vlsn index after cleaning.
vlsnHeadTruncate(VLSN, long) - Method in class com.sleepycat.je.rep.impl.RepImpl
Delete from the first VLSN in the range to lastVLSN, inclusive.
vlsnIndex - Variable in class com.sleepycat.je.rep.stream.VLSNReader
 
VLSNIndex - Class in com.sleepycat.je.rep.vlsn
A VLSN (Virtual LSN) is used to identify every log entry shared between members of the replication group.
VLSNIndex(EnvironmentImpl, String, NameIdPair, int, int, int, RecoveryInfo) - Constructor for class com.sleepycat.je.rep.vlsn.VLSNIndex
The mapping db's name is passed in as a parameter instead of the more intuitive approach of defining it within the class to facilitate unit testing of the VLSNIndex.
VLSNIndex.BackwardVLSNScanner - Class in com.sleepycat.je.rep.vlsn
Assumes that VLSNs are scanned backwards.
VLSNIndex.BackwardVLSNScanner(VLSNIndex) - Constructor for class com.sleepycat.je.rep.vlsn.VLSNIndex.BackwardVLSNScanner
 
VLSNIndex.ForwardVLSNScanner - Class in com.sleepycat.je.rep.vlsn
Scans VLSNs in a forward direction, used by feeders.
VLSNIndex.ForwardVLSNScanner(VLSNIndex) - Constructor for class com.sleepycat.je.rep.vlsn.VLSNIndex.ForwardVLSNScanner
 
VLSNIndex.VLSNAwaitLatch - Class in com.sleepycat.je.rep.vlsn
Associates the logItem with the latch, so that it's readily available when the latch is released.
VLSNIndex.VLSNAwaitLatch() - Constructor for class com.sleepycat.je.rep.vlsn.VLSNIndex.VLSNAwaitLatch
 
VLSNIndex.WaitTimeOutException - Exception in com.sleepycat.je.rep.vlsn
 
VLSNIndex.WaitTimeOutException() - Constructor for exception com.sleepycat.je.rep.vlsn.VLSNIndex.WaitTimeOutException
 
VLSNIndexStatDefinition - Class in com.sleepycat.je.rep.vlsn
Statistics associated with the VLSN Index used by HA.
VLSNIndexStatDefinition() - Constructor for class com.sleepycat.je.rep.vlsn.VLSNIndexStatDefinition
 
VLSNProxy - Interface in com.sleepycat.je.dbi
The VLSNProxy is a handle for invoking VLSN tracking at recovery time.
vlsnProxy - Variable in class com.sleepycat.je.recovery.RecoveryInfo
 
VLSNRange - Class in com.sleepycat.je.rep.vlsn
 
VLSNRange.VLSNRangeBinding - Class in com.sleepycat.je.rep.vlsn
Marshals a VLSNRange to a byte buffer to store in the database.
VLSNRange.VLSNRangeBinding() - Constructor for class com.sleepycat.je.rep.vlsn.VLSNRange.VLSNRangeBinding
 
VLSNReader - Class in com.sleepycat.je.rep.stream
The VLSNReader returns picks out replicated log entries from the log.
VLSNReader(EnvironmentImpl, VLSNIndex, boolean, long, int, NameIdPair, long) - Constructor for class com.sleepycat.je.rep.stream.VLSNReader
 
VLSNRecoveryProxy - Interface in com.sleepycat.je.recovery
The VLSNRecoveryProxy is a handle for invoking VLSN tracking at recovery time.
VLSNRecoveryTracker - Class in com.sleepycat.je.rep.vlsn
The VLSNRecoveryTracker is used to as a transient tracker at recovery time.
VLSNRecoveryTracker(EnvironmentImpl, int, int, int) - Constructor for class com.sleepycat.je.rep.vlsn.VLSNRecoveryTracker
 
VLSNTracker - Class in com.sleepycat.je.rep.vlsn
See @link{VLSNIndex} for an overview of the mapping system.
VLSNTracker(EnvironmentImpl, DatabaseImpl, int, int, int, StatGroup) - Constructor for class com.sleepycat.je.rep.vlsn.VLSNTracker
 
VLSNTracker(EnvironmentImpl, int, int, int) - Constructor for class com.sleepycat.je.rep.vlsn.VLSNTracker
 
VOID - Static variable in class com.sleepycat.asm.Type
The sort of the void type.
VOID_TYPE - Static variable in class com.sleepycat.asm.Type
The void type.

W

waitForElection() - Method in class com.sleepycat.je.rep.elections.Elections
For INTERNAL TESTING ONLY.
waitForFsync() - Method in class com.sleepycat.je.log.FSyncManager.FSyncGroup
Wait for either a turn to execute a fsync, or to find out that a fsync was done on your behalf.
waitForVLSN(VLSN, int) - Method in class com.sleepycat.je.rep.vlsn.VLSNIndex
Wait for the vlsn, or a higher numbered vlsn, to make its appearance in the VLSN index.
wakeup() - Method in class com.sleepycat.je.cleaner.Cleaner
 
wakeup() - Method in class com.sleepycat.je.utilint.DaemonThread
 
wakeupAfterWrite() - Method in class com.sleepycat.je.recovery.Checkpointer
Wakes up the checkpointer if a checkpoint log interval is configured and the number of bytes written since the last checkpoint exeeds the size of the interval.
wakeupAll() - Method in class com.sleepycat.je.log.FSyncManager.FSyncGroup
 
wakeupCleaner - Variable in class com.sleepycat.je.log.LogContext
 
wakeupOne() - Method in class com.sleepycat.je.log.FSyncManager.FSyncGroup
 
walk() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
Find all non-resident nodes, and execute the callback.
walkInternal() - Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
 
warning(Logger, EnvironmentImpl, String) - Static method in class com.sleepycat.je.utilint.LoggerUtils
 
wasCacheEverFull() - Method in class com.sleepycat.je.dbi.EnvironmentImpl
See Evictor.wasCacheEverFull
wasCacheEverFull() - Method in class com.sleepycat.je.evictor.Arbiter
Returns whether eviction has ever occurred, i.e., whether the cache has ever filled.
wasCacheEverFull() - Method in class com.sleepycat.je.evictor.Evictor
 
WholeEntry - Class in com.sleepycat.je.log
This class packages the log entry header and the log entry "contents" together for the use of components that need information from both parts.
WholeEntry(LogEntryHeader, LogEntry) - Constructor for class com.sleepycat.je.log.WholeEntry
 
WIDE_INSN - Static variable in class com.sleepycat.asm.ClassWriter
The type of the WIDE instruction.
WidenerInput - Class in com.sleepycat.persist.impl
Widens a value returned by another input when any readXxx method is called.
WidenerInput(EntityInput, int, int) - Constructor for class com.sleepycat.persist.impl.WidenerInput
 
window - Variable in class com.sleepycat.je.log.FileReader
 
Window - Class in com.sleepycat.je.rep.util.ldiff
A rolling window of key/data pairs used by the ldiff algorithm.
Window(Cursor, int) - Constructor for class com.sleepycat.je.rep.util.ldiff.Window
Create a window of the given size, starting at the next record pointed at by the Cursor.
wireFormat() - Method in interface com.sleepycat.je.rep.elections.Proposer.Proposal
The string representation of the proposal.
wireFormat() - Method in class com.sleepycat.je.rep.elections.Protocol.Accept
 
wireFormat() - Method in class com.sleepycat.je.rep.elections.Protocol.Accepted
 
wireFormat() - Method in class com.sleepycat.je.rep.elections.Protocol.MasterQuery
 
wireFormat() - Method in class com.sleepycat.je.rep.elections.Protocol.Promise
 
wireFormat() - Method in class com.sleepycat.je.rep.elections.Protocol.Propose
 
wireFormat() - Method in class com.sleepycat.je.rep.elections.Protocol.Reject
 
wireFormat() - Method in class com.sleepycat.je.rep.elections.Protocol.Shutdown
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateRequest
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.BinaryNodeStateProtocol.BinaryNodeStateResponse
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FeederInfoResp
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileEnd
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoReq
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileInfoResp
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileListResp
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileReq
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.networkRestore.Protocol.FileStart
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateRequest
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.NodeStateProtocol.NodeStateResponse
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureNode
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.EnsureOK
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.Fail
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupRequest
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.GroupResponse
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferMaster
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.TransferOK
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.RepGroupProtocol.UpdateAddress
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.TextProtocol.Fail
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.TextProtocol.OK
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.TextProtocol.ProtocolError
 
wireFormat() - Method in class com.sleepycat.je.rep.impl.TextProtocol.StringFormatable
 
wireFormat() - Method in interface com.sleepycat.je.rep.impl.TextProtocol.WireFormatable
 
wireFormat() - Method in class com.sleepycat.je.rep.monitor.Protocol.GroupChange
 
wireFormat() - Method in class com.sleepycat.je.rep.monitor.Protocol.LeaveGroup
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.Ack
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.AlternateMatchpoint
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.Commit
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.Entry
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.Heartbeat
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.HeartbeatResponse
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.JEVersions
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfo
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoOK
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.NodeGroupInfoReject
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.ProtocolVersion
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.RestoreResponse
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.ShutdownRequest
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPRequest
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.SNTPResponse
 
wireFormat() - Method in class com.sleepycat.je.rep.stream.Protocol.VLSNMessage
 
wireFormat() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.BlockInfo
 
wireFormat() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.DbBlocks
 
wireFormat() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.EnvInfo
 
wireFormat() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteDiffRequest
 
wireFormat() - Method in class com.sleepycat.je.rep.util.ldiff.Protocol.RemoteRecord
 
wireFormat() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.Message
The default message consists of the operation enum and just a 0 length size.
wireFormat() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.ProtocolVersion
 
wireFormat() - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.RejectMessage
 
wireFormat(Object...) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol.SimpleMessage
Assembles a sequence of arguments into its byte based wire format.
wireFormat() - Method in interface com.sleepycat.je.rep.utilint.BinaryProtocol.WireFormatable
 
wireFormatPrefix() - Method in class com.sleepycat.je.rep.impl.TextProtocol.RequestMessage
Returns the version id and Op concatenation that form the prefix for every message.
wireFormatPrefix() - Method in class com.sleepycat.je.rep.impl.TextProtocol.ResponseMessage
Returns the version id and Op concatenation that starts every message.
WireRecord - Class in com.sleepycat.je.rep.stream
Format for log entries sent across the wire for replication.
WireRecord() - Constructor for class com.sleepycat.je.rep.stream.WireRecord
 
withCursor(CursorImpl, DatabaseEntry, DatabaseEntry) - Method in interface com.sleepycat.je.dbi.CursorImpl.WithCursor
Called for each record in the databaseImpl.
WithRootLatched - Interface in com.sleepycat.je.tree
 
withRootLatchedExclusive(WithRootLatched) - Method in class com.sleepycat.je.tree.Tree
 
withRootLatchedShared(WithRootLatched) - Method in class com.sleepycat.je.tree.Tree
 
worker - Variable in class com.sleepycat.je.jmx.plugin.StatsPlugin
 
wrapIfNeeded(Throwable) - Static method in exception com.sleepycat.util.RuntimeExceptionWrapper
Wraps the given exception if it is not a RuntimeException.
wrapSelf(String) - Method in exception com.sleepycat.je.DatabaseExistsException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.DatabaseNotFoundException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.DeadlockException
Deprecated.
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.DeleteConstraintException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.DiskOrderedCursorProducerException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.DuplicateDataException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.EnvironmentFailureException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.EnvironmentLockedException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.EnvironmentNotFoundException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.ForeignConstraintException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.LockNotAvailableException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.LockNotGrantedException
Deprecated.
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.LockTimeoutException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.LogWriteException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.OperationFailureException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.DatabasePreemptedException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.GroupShutdownException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.InsufficientAcksException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.InsufficientLogException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.InsufficientReplicasException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.LockPreemptedException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.LogOverwriteException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.MasterReplicaTransitionException
 
wrapSelf(String) - Method in exception com.sleepycat.je.rep.MasterStateException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.MasterTransferFailureException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.MemberNotFoundException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.ReplicaConsistencyException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.ReplicaStateException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.ReplicaWriteException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.RestartRequiredException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.RollbackException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.RollbackProhibitedException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.UnknownMasterException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.rep.util.ldiff.LDiffRecordRequestException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.SecondaryIntegrityException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.SequenceExistsException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.SequenceIntegrityException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.SequenceNotFoundException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.SequenceOverflowException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.sync.SyncCanceledException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.ThreadInterruptedException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.TransactionTimeoutException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.tree.LN.LNWriteFailureException
 
wrapSelf(String) - Method in exception com.sleepycat.je.UniqueConstraintException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.VersionMismatchException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.je.XAFailureException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.persist.evolve.DeletedClassException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.persist.evolve.IncompatibleClassException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.persist.IndexNotAvailableException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.persist.StoreExistsException
For internal use only.
wrapSelf(String) - Method in exception com.sleepycat.persist.StoreNotFoundException
For internal use only.
write(ClassWriter, byte[], int, int, int) - Method in class com.sleepycat.asm.Attribute
Returns the byte array form of this attribute.
write(BinaryProtocol.Message, NamedChannel) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
Write a message out to a channel.
write(BinaryProtocol.Message, WritableByteChannel) - Method in class com.sleepycat.je.rep.utilint.BinaryProtocol
Write a message out to a channel.
write(ByteBuffer) - Method in class com.sleepycat.je.rep.utilint.NamedChannel
 
WRITE - Static variable in class com.sleepycat.je.txn.LockType
 
write(int) - Method in class com.sleepycat.util.FastOutputStream
 
write(byte[]) - Method in class com.sleepycat.util.FastOutputStream
 
write(byte[], int, int) - Method in class com.sleepycat.util.FastOutputStream
 
WRITE_COUNT - Static variable in class com.sleepycat.je.log.FileManager
 
WRITE_LOCKINFO_OVERHEAD - Static variable in class com.sleepycat.je.dbi.MemoryBudget
 
WRITE_PROMOTE - Static variable in class com.sleepycat.je.txn.LockUpgrade
 
writeAllowed - Variable in class com.sleepycat.collections.DataView
 
writeArrayLength(int) - Method in interface com.sleepycat.persist.impl.EntityOutput
Called by ObjectArrayFormat and PrimitiveArrayFormat to write the array length.
writeArrayLength(int) - Method in class com.sleepycat.persist.impl.RecordOutput
 
writeBaseLNEntry(LogEntryHeader, ByteBuffer, boolean) - Method in class com.sleepycat.je.log.entry.LNLogEntry
Method shared by LNLogEntry subclasses.
writeBigDecimal(BigDecimal) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an unsorted BigDecimal.
writeBigInteger(BigInteger) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes a BigInteger.
writeBigInteger(BigInteger) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeBoolean(boolean) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes a boolean (one byte) unsigned value to the buffer, writing one if the value is true and zero if it is false.
writeBoolean(ByteBuffer, boolean) - Static method in class com.sleepycat.je.log.LogUtils
Write a boolean into the log.
writeBoolean(boolean) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeBufferToFile(int, boolean) - Method in class com.sleepycat.je.log.LogBufferPool
Write the contents of the currentWriteBuffer to disk.
writeByte(int) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an signed byte (one byte) value to the buffer.
writeByte(int) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeByteArray(ByteBuffer, byte[]) - Static method in class com.sleepycat.je.log.LogUtils
Write a byte array into the log.
writeBytes(String) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes the specified bytes to the buffer, converting each character to an unsigned byte value.
writeBytes(char[]) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes the specified bytes to the buffer, converting each character to an unsigned byte value.
writeBytesNoLength(ByteBuffer, byte[]) - Static method in class com.sleepycat.je.log.LogUtils
Write a byte array into the log.
writeChangeSetData(Environment, Transaction, String, String, DatabaseEntry, SyncDB.OpType) - Method in class com.sleepycat.je.sync.impl.SyncDB
 
writeChangeSetData(Transaction, String, DatabaseEntry) - Method in class com.sleepycat.je.sync.SyncProcessor
Called internally by the SyncProcessor to write change set data.
writeChar(int) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes a char (two byte) unsigned value to the buffer.
writeChar(int) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeChars(String) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes the specified characters to the buffer, converting each character to a two byte unsigned value.
writeChars(char[]) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes the specified characters to the buffer, converting each character to a two byte unsigned value.
writeClassDescriptor(ObjectStreamClass) - Method in class com.sleepycat.bind.serial.SerialOutput
 
writeCompleted(long, boolean, boolean) - Method in class com.sleepycat.je.log.LogBufferPool
A loggable object has been freshly marshalled into the write log buffer.
writeCompositeKeyFields(Object, EntityOutput) - Method in interface com.sleepycat.persist.impl.Accessor
Writes all composite key field values to the given EntityOutput, writing in declared field number order.
writeCompositeKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
writeCompositeKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.RawAccessor
 
writeCompositeKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
writeCursors - Variable in class com.sleepycat.collections.CurrentTransaction.CdbCursors
 
writeDouble(double) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an unsorted double (eight byte) value to the buffer.
writeEntity(Format, Catalog, Object, DatabaseEntry, boolean) - Static method in class com.sleepycat.persist.impl.PersistEntityBinding
Writes the formatId and object, and returns the bytes.
writeEntry(LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.DeletedDupLNLogEntry
 
writeEntry(LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.INLogEntry
 
writeEntry(LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.LNLogEntry
 
writeEntry(LogEntryHeader, ByteBuffer) - Method in interface com.sleepycat.je.log.entry.LogEntry
Serialize this object into the buffer.
writeEntry(LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.NameLNLogEntry
Extends its super class to add in database operation information.
writeEntry(LogEntryHeader, ByteBuffer) - Method in class com.sleepycat.je.log.entry.SingleItemEntry
 
writeEnumConstant(String[], int) - Method in interface com.sleepycat.persist.impl.EntityOutput
Called by EnumFormat to write the given index of the enum constant.
writeEnumConstant(String[], int) - Method in class com.sleepycat.persist.impl.RecordOutput
 
writeFast(int) - Method in class com.sleepycat.util.FastOutputStream
Equivalent to write(int) but does not throw IOException.
writeFast(byte[]) - Method in class com.sleepycat.util.FastOutputStream
Equivalent to write(byte[]) but does not throw IOException.
writeFast(byte[], int, int) - Method in class com.sleepycat.util.FastOutputStream
Equivalent to write(byte[],int,int) but does not throw IOException.
writeFloat(float) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an unsorted float (four byte) value to the buffer.
writeInt(int) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an signed int (four byte) value to the buffer.
writeInt(ByteBuffer, int) - Static method in class com.sleepycat.je.log.LogUtils
Write an int into the log.
writeInt(int) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeInt(byte[], int, int) - Static method in class com.sleepycat.util.PackedInteger
Writes a packed integer starting at the given buffer offset and returns the next offset to be written.
writeIntMSB(ByteBuffer, int) - Static method in class com.sleepycat.je.log.LogUtils
Write an int into the log in MSB order.
writeKeyObject(Object, Format) - Method in interface com.sleepycat.persist.impl.EntityOutput
Called for a primary key field or composite key field with a reference type.
writeKeyObject(Object, Format) - Method in class com.sleepycat.persist.impl.RecordOutput
 
WriteLockInfo - Class in com.sleepycat.je.txn
 
WriteLockInfo() - Constructor for class com.sleepycat.je.txn.WriteLockInfo
 
writeLogBuffer(LogBuffer, boolean) - Method in class com.sleepycat.je.log.FileManager
Write out a log buffer to the file.
writeLong(long) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an signed long (eight byte) value to the buffer.
writeLong(ByteBuffer, long) - Static method in class com.sleepycat.je.log.LogUtils
Write a long into the log.
writeLong(long) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeLong(byte[], int, long) - Static method in class com.sleepycat.util.PackedInteger
Writes a packed long integer starting at the given buffer offset and returns the next offset to be written.
writeNonKeyFields(Object, EntityOutput) - Method in interface com.sleepycat.persist.impl.Accessor
Writes all non-key field values to the given EntityOutput, writing fields in super classes first and in name order within class.
writeNonKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
writeNonKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.RawAccessor
 
writeNonKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.CompositeKeyFormat
 
writeObject(Object, Format) - Method in interface com.sleepycat.persist.impl.EntityOutput
Called via Accessor to write all fields with reference types, except for the primary key field and composite key fields (see writeKeyObject below).
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.EnumFormat
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.Format
Writes a given instance of the target class to the output data bytes.
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.NonPersistentFormat
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.ObjectArrayFormat
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.PrimitiveArrayFormat
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.ProxiedFormat
 
writeObject(Object, Format) - Method in class com.sleepycat.persist.impl.RecordOutput
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigDec
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBigInt
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDate
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
writeObject(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.SimpleFormat.FString
 
writePackedInt(int) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an unsorted packed integer.
writePackedInt(ByteBuffer, int) - Static method in class com.sleepycat.je.log.LogUtils
Write a packed int into the log.
writePackedLong(long) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an unsorted packed long integer.
writePackedLong(ByteBuffer, long) - Static method in class com.sleepycat.je.log.LogUtils
Write a packed long into the log.
writePriKey(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.ComplexFormat
 
writePriKey(Object, EntityOutput, boolean) - Method in class com.sleepycat.persist.impl.Format
Gets the primary key field from the given object and writes it to the given output data bytes.
writePriKeyField(Object, EntityOutput) - Method in interface com.sleepycat.persist.impl.Accessor
Writes the primary key field value to the given EntityOutput.
writePriKeyField(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
writePriKeyField(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.RawAccessor
 
writePriKeyField(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
writePrimitiveArray(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FBool
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FByte
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FChar
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FDouble
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FFloat
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FInt
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FLong
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat.FShort
 
writePrimitiveField(Object, EntityOutput, Field) - Method in class com.sleepycat.persist.impl.SimpleFormat
 
writeProcessorMetadata(Environment, Transaction, String, ProcessorMetadata) - Method in class com.sleepycat.je.sync.impl.SyncDB
 
writeProcessorMetadata(Transaction, M) - Method in class com.sleepycat.je.sync.SyncProcessor
Called internally by the SyncProcessor to write processor-specific metadata, including a collection of SyncDataSet objects and processor connection properties.
writeProcessorTxnData(Environment, Transaction, String, String, DatabaseEntry) - Method in class com.sleepycat.je.sync.impl.SyncDB
 
writeProcessorTxnData(Transaction, String, DatabaseEntry) - Method in class com.sleepycat.je.sync.SyncProcessor
Called internally by the SyncProcessor to write processor-specific transaction data.
WRITER - Static variable in class com.sleepycat.asm.ClassReader
True to enable bytecode writing support.
writeReverseInt(byte[], int, int) - Static method in class com.sleepycat.util.PackedInteger
 
writeSecKeyFields(Object, EntityOutput) - Method in interface com.sleepycat.persist.impl.Accessor
Writes all secondary key field values to the given EntityOutput, writing fields in super classes first and in name order within class.
writeSecKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.EnhancedAccessor
 
writeSecKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.RawAccessor
 
writeSecKeyFields(Object, EntityOutput) - Method in class com.sleepycat.persist.impl.ReflectionAccessor
 
writeShort(byte[], int, int) - Static method in class com.sleepycat.asm.MethodWriter
Writes a short value in the given byte array.
writeShort(int) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an signed short (two byte) value to the buffer.
writeShort(ByteBuffer, short) - Static method in class com.sleepycat.je.log.LogUtils
Write a short into the log.
writeShort(int) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeSortedBigDecimal(BigDecimal) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes a sorted BigDecimal.
writeSortedBigDecimal(BigDecimal) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeSortedDouble(double) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes a sorted double (eight byte) value to the buffer.
writeSortedDouble(double) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeSortedFloat(float) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes a sorted float (four byte) value to the buffer.
writeSortedFloat(float) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeSortedInt(byte[], int, int) - Static method in class com.sleepycat.util.PackedInteger
Writes a packed sorted integer starting at the given buffer offset and returns the next offset to be written.
writeSortedLong(byte[], int, long) - Static method in class com.sleepycat.util.PackedInteger
Writes a packed sorted long integer starting at the given buffer offset and returns the next offset to be written.
writeSortedPackedInt(int) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes a sorted packed integer.
writeSortedPackedLong(long) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes a sorted packed long integer.
writeString(String) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes the specified characters to the buffer, converting each character to UTF format, and adding a null terminator byte.
writeString(char[]) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes the specified characters to the buffer, converting each character to UTF format.
writeString(ByteBuffer, String) - Static method in class com.sleepycat.je.log.LogUtils
Write a string into the log.
writeString(String) - Method in interface com.sleepycat.persist.impl.EntityOutput
 
writeTimesString(StatGroup) - Static method in class com.sleepycat.je.rep.utilint.RepUtils
 
writeTimestamp(ByteBuffer, Timestamp) - Static method in class com.sleepycat.je.log.LogUtils
Write a timestamp into the log.
writeTo(OutputStream) - Method in class com.sleepycat.util.FastOutputStream
 
writeToBuffer(ByteBuffer) - Method in class com.sleepycat.je.dbi.Operation
Serialize this object into the buffer.
writeToDatabase(EnvironmentImpl, DatabaseImpl, Txn) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Write this bucket to the mapping database.
writeToDatabase(EnvironmentImpl, Cursor) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
Write this bucket to the mapping database using a cursor.
writeToDatabase(EnvironmentImpl, DatabaseImpl, Txn) - Method in class com.sleepycat.je.rep.vlsn.VLSNRange
When the range is written out by the VLSNTracker, we must always be sure to update the tracker's lastVSLNOnDisk field.
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.cleaner.CleanerLogSummary
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.cleaner.DbFileSummary
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.cleaner.FileSummary
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.cleaner.PackedOffsets
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.dbi.DatabaseId
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.dbi.DatabaseImpl
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.dbi.DbTree
This log entry type is configured to perform marshaling (getLogSize and writeToLog) under the write log mutex.
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
 
writeToLog(ByteBuffer) - Method in enum com.sleepycat.je.log.entry.DbOperationType
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.log.FileHeader
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.log.LogEntryHeader
Serialize this object into the buffer and leave the buffer positioned in the right place to write the following item.
writeToLog(ByteBuffer) - Method in interface com.sleepycat.je.log.Loggable
Serialize this object into the buffer.
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.log.Trace
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.recovery.CheckpointEnd
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.recovery.CheckpointStart
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.BINDelta
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.ChildReference
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.DeltaInfo
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.dupConvert.DBIN
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.dupConvert.DIN
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.dupConvert.DupCountLN
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.dupConvert.INDeleteInfo
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.dupConvert.INDupDeleteInfo
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.FileSummaryLN
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.IN
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.LN
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.MapLN
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.NameLN
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.Node
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.tree.Tree
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.txn.RollbackEnd
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.txn.RollbackStart
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.txn.Txn
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.txn.TxnEnd
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.txn.TxnPrepare
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.utilint.Matchpoint
 
writeToLog(ByteBuffer) - Method in class com.sleepycat.je.utilint.VLSN
 
writeToTupleOutput(TupleOutput) - Method in class com.sleepycat.je.rep.vlsn.GhostBucket
 
writeToTupleOutput(TupleOutput) - Method in class com.sleepycat.je.rep.vlsn.VLSNBucket
 
writeToWire(ByteBuffer) - Method in class com.sleepycat.je.rep.stream.OutputWireRecord
 
writeTriggers(ByteBuffer, byte[][]) - Static method in class com.sleepycat.je.dbi.TriggerUtils
Writes the triggers out to the log buffer.
writeUnsignedByte(int) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an unsigned byte (one byte) value to the buffer.
writeUnsignedInt(long) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an unsigned int (four byte) value to the buffer.
writeUnsignedInt(ByteBuffer, long) - Static method in class com.sleepycat.je.log.LogUtils
Marshall a long into the next 4 bytes in this buffer.
writeUnsignedShort(int) - Method in class com.sleepycat.bind.tuple.TupleOutput
Writes an unsigned short (two byte) value to the buffer.
writeXid(ByteBuffer, Xid) - Static method in class com.sleepycat.je.log.LogUtils
 

X

XAEnvironment - Class in com.sleepycat.je
An Environment that implements XAResource.
XAEnvironment(File, EnvironmentConfig) - Constructor for class com.sleepycat.je.XAEnvironment
Create a database environment handle.
XAFailureException - Exception in com.sleepycat.je
Thrown if an attempt is made to use a Transaction after it has been invalidated as the result of an XA failure.
XAFailureException(Locker) - Constructor for exception com.sleepycat.je.XAFailureException
For internal use only.
XARecover() - Method in class com.sleepycat.je.txn.TxnManager
 

Z

ZERO_LENGTH_BYTE_ARRAY - Static variable in class com.sleepycat.je.log.LogUtils
 
ZERO_LENGTH_BYTE_ARRAY - Static variable in class com.sleepycat.util.keyrange.KeyRange
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

Copyright (c) 2004-2012 Oracle. All rights reserved.