|
|||||||||
PREV NEXT | FRAMES NO FRAMES |
DatabaseException
.
ClassReader
.
ClassReader
.
TupleBinding
for a BigInteger
value.BigInteger
value into an entry buffer.
TupleBinding
for a Boolean
primitive
wrapper or a boolean
primitive.boolean
value into an entry buffer.
EntryBinding
that uses the entry's byte array as
the key or data object.TupleBinding
for a Byte
primitive
wrapper or a byte
primitive.byte
value into an entry buffer.
ByteVector
with a default initial
size.
ByteVector
with the given initial
size.
TupleBinding
for a Character
primitive
wrapper or a char
primitive.char
value into an entry buffer.
Environment.checkpoint
.ClassVisitor
that delegates to another ClassVisitor
.ClassAdapter
object.
ant
task for running the ClassEnhancer
.EntityModel
to construct persistent class metadata.
EntityModel
to construct persistent class metadata.
ClassVisitor
visit an existing class.ClassReader
object.
ClassReader
object.
ClassReader
object.
ClassReader
object.
ClassVisitor
that generates classes in bytecode form.ClassWriter
object.
ClassWriter
object.
ClassWriter
object and enables optimizations for
"mostly add" bytecode transformations.
StoredIterator.close()
if it is a StoredIterator
.
ClassVisitor
to which this adapter delegates calls.
DbDump
.Environment.checkpoint
.
Database.join
.
null
for
the lock mode parameter.
CursorConfig.READ_UNCOMMITTED
to
conform to ANSI database isolation terminology.
LockMode.READ_UNCOMMITTED
to
conform to ANSI database isolation terminology.
StoredCollections.configuredCollection(java.util.Collection, com.sleepycat.je.CursorConfig)
in order to conform to ANSI database isolation
terminology. To obtain a dirty-read collection, pass
CursorConfig.READ_UNCOMMITTED
StoredCollections.configuredList(java.util.List, com.sleepycat.je.CursorConfig)
in
order to conform to ANSI database isolation terminology. To obtain a
dirty-read list, pass CursorConfig.READ_UNCOMMITTED
StoredCollections.configuredMap(java.util.Map, com.sleepycat.je.CursorConfig)
in
order to conform to ANSI database isolation terminology. To obtain a
dirty-read map, pass CursorConfig.READ_UNCOMMITTED
StoredCollections.configuredSet(java.util.Set, com.sleepycat.je.CursorConfig)
in
order to conform to ANSI database isolation terminology. To obtain a
dirty-read set, pass CursorConfig.READ_UNCOMMITTED
StoredCollections.configuredSortedMap(java.util.SortedMap, com.sleepycat.je.CursorConfig)
in order to conform to ANSI database isolation
terminology. To obtain a dirty-read map, pass
CursorConfig.READ_UNCOMMITTED
StoredCollections.configuredSortedSet(java.util.SortedSet, com.sleepycat.je.CursorConfig)
in order to conform to ANSI database isolation
terminology. To obtain a dirty-read set, pass
CursorConfig.READ_UNCOMMITTED
TupleBinding
for a Double
primitive
wrapper or a double
primitive.double
value into an entry buffer.
double
value into an entry buffer.
SecondaryCursor
for the same transaction as
the original cursor.
SecondaryCursor
.
Entity
or Persistent
.
EntityModel
to construct entity metadata.
BigInteger
value.
boolean
value.
byte
value.
char
value.
double
value.
double
value.
float
value.
float
value.
int
value.
long
value.
TupleInput
key entry and
deserialized data entry objects.
TupleInput
entry.
TupleInput
key and data
entries.
short
value.
String
value.
EnvironmentConfig.ENV_BACKGROUND_WRITE_LIMIT
or EnvironmentConfig.ENV_BACKGROUND_WRITE_LIMIT
is reached.
Map.Entry.equals(java.lang.Object)
.
equals
method that must be implemented by
conversion class.
Mutation.equals(java.lang.Object)
superclass method
returns true.
Converter.equals(java.lang.Object)
superclass method
returns true.
Mutation.equals(java.lang.Object)
method returns true.
EnvironmentConfig.MAX_MEMORY
.
Database.preload
took more than maxMillisecs.
ExceptionWrapper.getCause()
method for exceptions that implement the
ExceptionWrapper
interface.EntityModel
to construct field metadata.
Database.preload
filled maxBytes of the cache.
TupleBinding
for a Float
primitive
wrapper or a float
primitive.float
value into an entry buffer.
float
value into an entry buffer.
delta
.
Environment.verify
and Database.verify
are configured to perform fine granularity consistency
checking that includes verifying in memory constructs.
Environment.openDatabase
method is configured to create the database
if it does not already exist.
Database.openSequence
method is configured to create the sequence if it
does not already exist.
run()
is called when a transaction is already active for
the current thread.
BigInteger
.
BigInteger
value.
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()
).
CacheMode
used for operations performed using this
cursor.
CacheMode
used for operations performed using this
cursor.
Class.getName()
.
ExceptionWrapper.getCause()
.
IOExceptionWrapper.getCause()
.
RuntimeExceptionWrapper.getCause()
.
CursorConfig.getReadUncommitted()
to
conform to ANSI database isolation terminology.
TransactionConfig.getReadUncommitted()
to
conform to ANSI database isolation terminology.
ONE_TO_MANY
or MANY_TO_MANY
relationship, or null for a
Relationship#ONE_TO_ONE ONE_TO_ONE} or MANY_TO_ONE
relationship.
Environment
handle for
the database environment underlying the Database
.
Environment.openDatabase
method is configured to fail if the database
already exists.
Database.openSequence
method is configured to fail if the database
already exists.
Environment.scanLog(long, long, com.sleepycat.je.LogScanConfig, com.sleepycat.je.LogScanner)
is configured to scan
forwards.
b
, plus
one.
StoredCollection.iterator()
method.
SecondaryKeyCreator
object for use in configuring
a SecondaryDatabase
.
SecondaryIndex.keysIndex
.
Database
associated with this cursor.
Environment.verify
and Database.verify
are configured to print basic verification information
to System.out.
Environment.verify
and Database.verify
are configured to propagate exceptions found during
verification.
PersistentProxy
, or null otherwise.
PackedInteger.readInt(byte[], int)
.
PackedInteger.readLong(byte[], int)
.
SecondaryKey.relatedEntity()
annotation.
SecondaryDatabase
objects associated with a primary database.
Object
or Enum
.
Environment.beginTransaction(com.sleepycat.je.Transaction, com.sleepycat.je.TransactionConfig)
.
PackedInteger.writeInt(byte[], int, int)
.
PackedInteger.writeLong(byte[], int, long)
.
Map.Entry.hashCode()
.
b
.
TupleBinding
for a Integer
primitive
wrapper or an int
primitive.int
value into an entry buffer.
StoredContainer.getCursorConfig()
.
CursorConfig.isReadUncommitted
may be called to determine
whether dirty-read is enabled.
DatabaseConfig.getReadUncommitted
may be
called.
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.
JEConnection
in this manner:JoinCursor
.Comparable
interface is not implemented.LockTimeout
property.
TupleBinding
for a Long
primitive
wrapper or a long
primitive.long
value into an entry buffer.
Map.Entry
implementation that can be used as in
input parameter.CacheSize
property.
CachePercent
property.
TupleBase.getTupleOutput(E)
TupleBase.getTupleOutput(E)
transient
keyword.transient
keyword.Database
.
SecondaryCursor
.
SecondaryDatabase
.
Entity
class or a
simple type.Database.preload(PreloadConfig)
.
Database.preload(PreloadConfig)
.
Database.preload
.
Database.preload
Database.preload
operation.EntityStore
.
EntityModel
to construct primary key metadata.
RawType
.RawStore
or Conversion
.type
attribute.
BigInteger
.
b
.
b
.
b
.
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 a signed 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.utilint.FileMapper
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.cleaner.DbFileSummary
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.cleaner.FileSummary
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.cleaner.PackedOffsets
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.dbi.DatabaseId
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.dbi.DatabaseImpl
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.dbi.DbTree
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.dbi.ReplicatedDatabaseConfig
-
- readFromLog(ByteBuffer, byte) -
Method in enum com.sleepycat.je.log.entry.DbOperationType
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.log.FileHeader
-
- readFromLog(ByteBuffer, byte) -
Method in interface com.sleepycat.je.log.Loggable
- Initialize this object from the data in itemBuf.
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.recovery.CheckpointEnd
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.recovery.CheckpointStart
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.BINDelta
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.ChildReference
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.DBIN
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.DeltaInfo
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.DIN
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.DupCountLN
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.FileSummaryLN
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.IN
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.INDeleteInfo
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.INDupDeleteInfo
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.LN
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.MapLN
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.NameLN
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.Node
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.tree.Tree
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.txn.Txn
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.txn.TxnEnd
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.txn.TxnPrepare
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.utilint.Tracer
-
- readFromLog(ByteBuffer, byte) -
Method in class com.sleepycat.je.utilint.VLSN
-
- readHeaderAndEntry(ByteBuffer, EnvironmentImpl, boolean, boolean) -
Static method in class com.sleepycat.je.log.LogUtils
- Convenience method for marshalling a header and log entry
out of a byte buffer read directly out of the log.
- readInt(int) -
Method in class com.sleepycat.asm.ClassReader
- Reads a signed int value in
b
.
- 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(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.
- 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.
- 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(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.
- readMapTreeFromLog(long, boolean) -
Method in class com.sleepycat.je.dbi.EnvironmentImpl
- Set the mapping tree from the log.
- readNextEntry() -
Method in class com.sleepycat.je.log.FileReader
- readNextEntry scans the log files until either it's 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
-
- readNonKeyFields(Object, EntityInput, int, int, int) -
Method in class com.sleepycat.persist.impl.EnhancedAccessor
-
- 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.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(Object, EntityInput, boolean) -
Method in class com.sleepycat.persist.impl.SimpleFormat
-
- readPackedInt() -
Method in class com.sleepycat.bind.tuple.TupleInput
- Reads a 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 a 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.
- readPriKeyField(Object, EntityInput) -
Method in class com.sleepycat.persist.impl.EnhancedAccessor
-
- readSecKeyFields(Object, EntityInput, int, int, int) -
Method in class com.sleepycat.persist.impl.EnhancedAccessor
-
- readShort(int) -
Method in class com.sleepycat.asm.ClassReader
- Reads a signed short value in
b
.
- 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
-
- readSortedDouble() -
Method in class com.sleepycat.bind.tuple.TupleInput
- Reads a signed double (eight byte) value from the buffer, with support
for correct default sorting of all values.
- readSortedDouble() -
Method in interface com.sleepycat.persist.impl.EntityInput
-
- readSortedFloat() -
Method in class com.sleepycat.bind.tuple.TupleInput
- Reads a signed float (four byte) value from the buffer, with support
for correct default sorting of all values.
- readSortedFloat() -
Method in interface com.sleepycat.persist.impl.EntityInput
-
- 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) -
Static method in class com.sleepycat.je.log.LogUtils
- Read a string from the log.
- readString() -
Method in interface com.sleepycat.persist.impl.EntityInput
-
- readTimestamp(ByteBuffer, boolean) -
Static method in class com.sleepycat.je.log.LogUtils
- Read a timestamp from the log.
- readTypeFromLog(ByteBuffer, byte) -
Static method in enum com.sleepycat.je.log.entry.DbOperationType
-
- 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() -
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
-
- 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.
- RECNO_METHOD -
Static variable in class com.sleepycat.compat.DbCompat
-
- reconstituteBIN(EnvironmentImpl) -
Method in class com.sleepycat.je.tree.BINDelta
- Create a BIN by starting with the full version and applying the deltas.
- 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.
- recover(boolean, 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
-
- RecoveryException - Exception in com.sleepycat.je.recovery
- Recovery related exceptions
- RecoveryException(EnvironmentImpl, String, Throwable) -
Constructor for exception com.sleepycat.je.recovery.RecoveryException
-
- RecoveryException(EnvironmentImpl, String) -
Constructor for exception com.sleepycat.je.recovery.RecoveryException
-
- 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
- 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
-
- 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.
- 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
- Cursors operating under this transaction are added to the collection.
- 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.
- registerVLSN(long, LogEntryHeader) -
Method in interface com.sleepycat.je.dbi.ReplicatorInstance
- Record the vlsn->lsn mapping for this just-logged log entry.
- registerXATxn(Xid, Txn, boolean) -
Method in class com.sleepycat.je.txn.TxnManager
- Called when txn is created.
- reinit(boolean) -
Method in class com.sleepycat.je.dbi.EnvironmentImpl
- Reinitialize after an Internal Init copies new *.jdb files into envhome.
- 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 interface com.sleepycat.je.log.LogSource
- We're done with this log source.
- 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
-
- releaseAndFindNotifyTargets(long, Locker) -
Method in class com.sleepycat.je.txn.DummyLockManager
-
- releaseAndFindNotifyTargets(long, Locker) -
Method in class com.sleepycat.je.txn.LatchedLockManager
-
- 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
- releaseAPIReadLock(Locker) -
Method in class com.sleepycat.je.dbi.EnvironmentImpl
-
- releaseAPIWriteLock() -
Method in class com.sleepycat.je.dbi.EnvironmentImpl
-
- releaseBIN() -
Method in class com.sleepycat.je.dbi.CursorImpl
-
- releaseBINs() -
Method in class com.sleepycat.je.dbi.CursorImpl
-
- 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.
- releaseDBIN() -
Method in class com.sleepycat.je.dbi.CursorImpl
-
- 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.
- 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.
- releaseRootIN(IN) -
Method in class com.sleepycat.je.dbi.SortedLSNTreeWalker
-
- 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.
- 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(T) -
Method in class com.sleepycat.je.utilint.TinyHashSet
-
- remove() -
Method in class com.sleepycat.je.utilint.TinyHashSet.SingleElementIterator
-
- 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).
- 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(CursorImpl) -
Method in class com.sleepycat.je.tree.BIN
- Unregister a cursor with this bin.
- removeDatabase(Environment, Transaction, String, String) -
Static method in class com.sleepycat.compat.DbCompat
-
- removeDatabase(Transaction, String) -
Method in class com.sleepycat.je.Environment
- Removes a database.
- removeDatabase(String) -
Method in class com.sleepycat.je.jca.ra.JEConnection
-
- removeDbFileSummary(Long) -
Method in class com.sleepycat.je.dbi.DatabaseImpl
- Removes the DbFileSummary for the given file.
- removeDbFileSummary(DatabaseImpl, Long) -
Method in class com.sleepycat.je.log.LatchedLogManager
-
- removeDbFileSummary(DatabaseImpl, Long) -
Method in class com.sleepycat.je.log.LogManager
-
- removeDbFileSummary(DatabaseImpl, Long) -
Method in class com.sleepycat.je.log.SyncedLogManager
-
- removeDeletedKey(Key) -
Method in class com.sleepycat.je.tree.BINReference
-
- removeEnvironment(EnvironmentImpl) -
Method in class com.sleepycat.je.evictor.Evictor
- Only supported by SharedEvictor.
- removeEnvironment(EnvironmentImpl) -
Method in class com.sleepycat.je.evictor.PrivateEvictor
- Only supported by SharedEvictor.
- removeEnvironment(EnvironmentImpl) -
Method in class com.sleepycat.je.evictor.SharedEvictor
- Synchronized so that the set of environments cannot be changed in the
middle of an eviction (which is also synchronized).
- removeFiles(File) -
Static method in class com.sleepycat.je.log.FileManager
- Remove files from the environment home directory.
- removeInternalDatabase(Environment, Transaction, String, boolean) -
Static method in class com.sleepycat.je.DbInternal
-
- removeLSN(long) -
Method in class com.sleepycat.je.utilint.FileMapper
- Individual mappings are removed if this VLSN is written more than
once to the log, as might happen on some kind of replay.
- removeReferringHandle(Database) -
Method in class com.sleepycat.je.dbi.DatabaseImpl
- Decrement the reference count.
- 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.LatchedLogManager
-
- 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
-
- renameDatabase(Environment, Transaction, String, String, String, String) -
Static method in class com.sleepycat.compat.DbCompat
-
- renameDatabase(Transaction, String, String) -
Method in class com.sleepycat.je.Environment
- Renames a database.
- 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.
- REP_OPERATIONS_NAME -
Static variable in class com.sleepycat.je.dbi.DbTree
-
- 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.
- 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
-
- 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.
- ReplicaConsistencyPolicy - Interface in com.sleepycat.je
-
- 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
- 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.
- ReplicatorInstance - Interface in com.sleepycat.je.dbi
- The ReplicatorInstance is the sole conduit of replication functionality
available to the core JE code.
- 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
-
- requiredNodes(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.
- reset() -
Method in class com.sleepycat.je.cleaner.DbFileSummary
- Reset all totals to zero.
- 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() -
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
-
- resetDbInfo(DatabaseId) -
Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
- Clears all accmulated utilization info for the given database.
- resetFileInfo(long) -
Method in class com.sleepycat.je.cleaner.RecoveryUtilizationTracker
- Clears all accmulated utilization info for the given file.
- resetPool(DbConfigManager) -
Method in class com.sleepycat.je.log.LogManager
- Reset the pool when the cache is resized.
- resolveClass(ObjectStreamClass) -
Method in class com.sleepycat.bind.serial.SerialInput
-
- 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.
- 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 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).
- retrieveNext(Cursor, DatabaseEntry, DatabaseEntry, LockMode, GetMode) -
Static method in class com.sleepycat.je.DbInternal
- Proxy to Cursor.retrieveNext().
- RETURN -
Static variable in interface com.sleepycat.asm.Opcodes
-
- rewriteMapTreeRoot(long) -
Method in class com.sleepycat.je.dbi.EnvironmentImpl
- Force a rewrite of the map tree root if required.
- RIGHT -
Static variable in class com.sleepycat.je.tree.Tree.SearchType
-
- RMW -
Static variable in class com.sleepycat.je.LockMode
- Acquire write locks instead of read locks when doing the retrieval.
- rollback() -
Method in class com.sleepycat.je.jca.ra.JELocalTransaction
-
- rollback(Xid) -
Method in class com.sleepycat.je.XAEnvironment
-
- 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.utilint.DaemonThread
-
- 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.
- RUNRECOVERY_EXCEPTION_TESTING -
Static variable in class com.sleepycat.je.log.FileManager
-
- RunRecoveryException - Exception in com.sleepycat.je
- Thrown when the JE environment has encountered an exception or a
resource shortfall and cannot continue on safely.
- RunRecoveryException(EnvironmentImpl) -
Constructor for exception com.sleepycat.je.RunRecoveryException
-
- RunRecoveryException(EnvironmentImpl, Throwable) -
Constructor for exception com.sleepycat.je.RunRecoveryException
-
- RunRecoveryException(EnvironmentImpl, String) -
Constructor for exception com.sleepycat.je.RunRecoveryException
-
- RunRecoveryException(EnvironmentImpl, String, Throwable) -
Constructor for exception com.sleepycat.je.RunRecoveryException
-
- RuntimeExceptionWrapper - Exception in com.sleepycat.util
- A RuntimeException that can contain nested exceptions.
- RuntimeExceptionWrapper(Throwable) -
Constructor for exception com.sleepycat.util.RuntimeExceptionWrapper
-
SecondaryDatabase
extend
those of a primary Database
.EntityStore
.
EntityModel
to construct secondary key metadata.
EntryBinding
that treats a key or data entry as
a serialized object.ObjectInputStream
that gets class description
information from a ClassCatalog
.ObjectOutputStream
that stores class description
information in a ClassCatalog
.EntityBinding
that treats an entity's key entry and
data entry as serialized objects.Environment.verify
and Database.verify
to perform fine granularity consistency checking that
includes verifying in memory constructs.
Environment.openDatabase
method to create the database if it does not
already exist.
Database.openSequence
method to create the sequence if it does not
already exist.
run()
is called when a transaction is already active for
the current thread.
CacheMode
used for operations performed using this
cursor.
CacheMode
used for operations performed using this
cursor.
CursorConfig.setReadUncommitted(boolean)
to
conform to ANSI database isolation terminology.
TransactionConfig.setReadUncommitted(boolean)
to
conform to ANSI database isolation terminology.
Environment.openDatabase
method to fail if the database already exists.
Database.openSequence
method to fail if the database already exists.
Environment.scanLog(long, long, com.sleepycat.je.LogScanConfig, com.sleepycat.je.LogScanner)
to scan forwards through the log.
StoredCollection.iterator()
method.
Environment.openDatabase
method to have a B+Tree duplicate tree fanout
of nodeMaxDupTreeEntries.
Environment.openDatabase
method to have a B+Tree fanout of
nodeMaxEntries.
Environment.verify
and Database.verify
to print basic verification information to System.out.
Environment.verify
and Database.verify
to propagate exceptions found during verification.
SerialBase.getSerialOutput(java.lang.Object)
.
Environment.beginTransaction(com.sleepycat.je.Transaction, com.sleepycat.je.TransactionConfig)
.
TupleBase.getTupleOutput(E)
.
UnsupportedOperationException
since this
object is not attached to a map.
SharedCache
property.
TupleBinding
for a Short
primitive
wrapper or a short
primitive.short
value into an entry buffer.
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.
- 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.
- SortedDoubleBinding - Class in com.sleepycat.bind.tuple
- A concrete
TupleBinding
for a Double
primitive
wrapper or a double
primitive. - SortedDoubleBinding() -
Constructor for class com.sleepycat.bind.tuple.SortedDoubleBinding
-
- SortedFloatBinding - Class in com.sleepycat.bind.tuple
- A concrete
TupleBinding
for a Float
primitive
wrapper or 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.ExceptionPredicate - Interface in com.sleepycat.je.dbi
-
- 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.PrimaryIndex
-
- sortedMap() -
Method in class com.sleepycat.persist.SecondaryIndex
-
- SOURCE_CRITICAL -
Static variable in class com.sleepycat.je.evictor.Evictor
-
- SOURCE_DAEMON -
Static variable in class com.sleepycat.je.evictor.Evictor
-
- SOURCE_MANUAL -
Static variable in class com.sleepycat.je.evictor.Evictor
-
- splitInternal(IN, int, int, int, CacheMode) -
Method in class com.sleepycat.je.tree.IN
-
- start(Xid, int) -
Method in class com.sleepycat.je.XAEnvironment
-
- 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
for this point in time.
- startDeleteProcessing() -
Method in class com.sleepycat.je.dbi.DatabaseImpl
- The delete cleanup is starting.
- startLsn -
Variable in class com.sleepycat.je.log.FileReader
-
- stat(StatsConfig) -
Method in class com.sleepycat.je.dbi.DatabaseImpl
-
- 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.
- 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, String, String, boolean) -
Constructor for class com.sleepycat.je.log.StatsFileReader
- Create this reader to start at a given LSN.
- status -
Variable in class com.sleepycat.je.dbi.CursorImpl.KeyChangeStatus
- Operation status;
- stifleExceptionChatter -
Variable in class com.sleepycat.je.utilint.DaemonThread
-
- 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.
- 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.
- 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.
- 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.
- StoredEntrySet<K,V> - Class in com.sleepycat.collections
- The Set returned by Map.entrySet().
- 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.
- 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
.
- 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
.
- StoredSortedEntrySet<K,V> - Class in com.sleepycat.collections
- The SortedSet returned by Map.entrySet().
- 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
.
- 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
.
- 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
.
- 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
.
- StringBinding - Class in com.sleepycat.bind.tuple
- A concrete
TupleBinding
for a simple String
value. - StringBinding() -
Constructor for class com.sleepycat.bind.tuple.StringBinding
-
- 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.
- 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).
- 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(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.
- 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.
- subtractFromMemoryBudget() -
Method in class com.sleepycat.je.cleaner.DbFileSummaryMap
-
- SUCCESS -
Static variable in class com.sleepycat.je.OperationStatus
- The operation was successful.
- SUCCESS -
Static variable in class com.sleepycat.je.PreloadStatus
Database.preload
was successful.
- summarize() -
Method in class com.sleepycat.je.log.DumpFileReader
-
- summarize() -
Method in class com.sleepycat.je.log.StatsFileReader
-
- 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 -
Static variable in class com.sleepycat.je.TransactionConfig
-
- 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
-
- syncDatabase(EnvironmentImpl, DatabaseImpl, boolean) -
Static method in class com.sleepycat.je.recovery.Checkpointer
- Flush a given database to disk.
- syncDeferredWrite(Database, boolean) -
Static method in class com.sleepycat.compat.DbCompat
-
- 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.
TransactionWorker.doWork()
, and handles
transaction retry and exceptions.EntryBinding
that treats a key or data entry as a
tuple; it includes predefined bindings for Java primitive types.InputStream
with DataInput
-like methods for
reading tuple fields.EntryBinding
that uses the TupleInput
object as the key or data object.TupleBinding
that delegates to the
MarshalledTupleEntry
interface of the data or key object.OutputStream
with DataOutput
-like methods for
writing tuple fields.EntityBinding
that treats an entity's key entry as
a tuple and its data entry as a serialized object.TupleSerialBinding
that delegates to the
MarshalledTupleKeyEntity
interface of the entity class.TupleSerialMarshalledBinding
.EntityBinding
that treats an entity's key entry and
data entry as tuples.TupleTupleBinding
that delegates to the
MarshalledTupleEntry
and
MarshalledTupleKeyEntity
interfaces of the entity class.TupleTupleMarshalledBinding
.TxnSerializableIsolation
property.
TxnTimeout
property.
BigInteger
.
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 signed 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.
- WriteLockInfo - Class in com.sleepycat.je.txn
-
- WriteLockInfo() -
Constructor for class com.sleepycat.je.txn.WriteLockInfo
-
- 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 class com.sleepycat.persist.impl.EnhancedAccessor
-
- 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).
- writePackedInt(int) -
Method in class com.sleepycat.bind.tuple.TupleOutput
- Writes a 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 a packed long integer.
- writePackedLong(ByteBuffer, long) -
Static method in class com.sleepycat.je.log.LogUtils
- Write a packed long into the log.
- writePriKeyField(Object, EntityOutput) -
Method in class com.sleepycat.persist.impl.EnhancedAccessor
-
- writeSecKeyFields(Object, EntityOutput) -
Method in class com.sleepycat.persist.impl.EnhancedAccessor
-
- 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
-
- writeSortedDouble(double) -
Method in class com.sleepycat.bind.tuple.TupleOutput
- Writes a signed double (eight byte) value to the buffer, with support
for correct default sorting of all values.
- writeSortedDouble(double) -
Method in interface com.sleepycat.persist.impl.EntityOutput
-
- writeSortedFloat(float) -
Method in class com.sleepycat.bind.tuple.TupleOutput
- Writes a signed float (four byte) value to the buffer, with support for
correct default sorting of all values.
- writeSortedFloat(float) -
Method in interface com.sleepycat.persist.impl.EntityOutput
-
- 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
-
- 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(Database) -
Method in class com.sleepycat.je.utilint.FileMapper
-
- 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.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.DBIN
-
- writeToLog(ByteBuffer) -
Method in class com.sleepycat.je.tree.DeltaInfo
-
- writeToLog(ByteBuffer) -
Method in class com.sleepycat.je.tree.DIN
-
- writeToLog(ByteBuffer) -
Method in class com.sleepycat.je.tree.DupCountLN
-
- 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.INDeleteInfo
-
- writeToLog(ByteBuffer) -
Method in class com.sleepycat.je.tree.INDupDeleteInfo
-
- 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.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.Tracer
-
- writeToLog(ByteBuffer) -
Method in class com.sleepycat.je.utilint.VLSN
-
- 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
-
|
|||||||||
PREV NEXT | FRAMES NO FRAMES |