Berkeley DB Java Edition High Availability (JE HA) enables replication of JE
environments.
- 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
-
- 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
-
- 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 BeanDescriptor
s.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- getDetail() - Method in exception com.sleepycat.util.IOExceptionWrapper
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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 EventSetDescriptor
s.
- 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
-
- getExclusiveCreate() - Method in class com.sleepycat.je.SequenceConfig
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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 PropertyDescriptor
s.
- 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
-
- getReadLockIds() - Method in class com.sleepycat.je.txn.Txn
-
- getReadLongLength(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
-
- 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
-
- getReadSortedLongLength(byte[], int) - Static method in class com.sleepycat.util.PackedInteger
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- getTrackerLagConsistencyWaits() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
-
- getTrackerStats(StatsConfig) - Method in class com.sleepycat.je.rep.impl.node.Replica
-
- getTrackerVLSNConsistencyWaitMs() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
-
- getTrackerVLSNConsistencyWaits() - Method in class com.sleepycat.je.rep.ReplicatedEnvironmentStats
-
- 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
-
- 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
-
- 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
-
- getWriteNoSync() - Method in class com.sleepycat.je.TransactionConfig
-
- 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
-
- getWriteSortedLongLength(long) - Static method in class com.sleepycat.util.PackedInteger
-
- 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
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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 - 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
-
- 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
-
- 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
-
- 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
-
- setExclusiveCreate(boolean) - Method in class com.sleepycat.je.SequenceConfig
-
- 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
-
- 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
-
- 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
-
- 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
-
- setNodeMaxDupTreeEntriesVoid(int) - Method in class com.sleepycat.je.DatabaseConfig
-
- setNodeMaxEntries(int) - Method in class com.sleepycat.je.DatabaseConfig
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- StoredList(Database, EntityBinding<E>, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.StoredList
-
- StoredMap<K,V> - Class in com.sleepycat.collections
-
- StoredMap(Database, EntryBinding<K>, EntryBinding<V>, boolean) - Constructor for class com.sleepycat.collections.StoredMap
-
- StoredMap(Database, EntryBinding<K>, EntryBinding<V>, PrimaryKeyAssigner) - Constructor for class com.sleepycat.collections.StoredMap
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.