A B C D E F G H I K L M N O P Q R S T U V W 
All Classes All Packages

A

abortCommit() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
abortCommit(CommitSession) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
AccumuloReplicaSystem - Class in org.apache.accumulo.tserver.replication
 
AccumuloReplicaSystem() - Constructor for class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
AccumuloReplicaSystem.ReplicationStats - Class in org.apache.accumulo.tserver.replication
 
AccumuloReplicaSystem.RFileClientExecReturn - Class in org.apache.accumulo.tserver.replication
 
AccumuloReplicaSystem.WalClientExecReturn - Class in org.apache.accumulo.tserver.replication
 
AccumuloReplicaSystem.WalReplication - Class in org.apache.accumulo.tserver.replication
A "struct" to avoid a nested Entry.
ActiveAssignmentRunnable - Class in org.apache.accumulo.tserver
 
ActiveAssignmentRunnable(ConcurrentHashMap<KeyExtent, RunnableStartedAt>, KeyExtent, Runnable) - Constructor for class org.apache.accumulo.tserver.ActiveAssignmentRunnable
 
add(CompactionStats) - Method in class org.apache.accumulo.tserver.tablet.CompactionStats
 
addActive(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerMinCMetrics
 
addActiveScans(ScanDataSource) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
addAssignment(KeyExtent, Logger, TabletServer.AssignmentHandler) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
addCommitPrep(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerUpdateMetrics
 
addCommitTime(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerUpdateMetrics
 
addConstraintViolations(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerUpdateMetrics
 
addMetaDataAssignment(KeyExtent, Logger, TabletServer.AssignmentHandler) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
addMigration(KeyExtent, Runnable) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
addMutationArraySize(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerUpdateMetrics
 
addNewLogMarker(DfsLogger) - Method in class org.apache.accumulo.tserver.TabletServer
 
addPermissionErrors(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerUpdateMetrics
 
addQueued(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerMinCMetrics
 
addResult(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerScanMetrics
 
addResult(Object) - Method in class org.apache.accumulo.tserver.scan.ScanTask
 
addScan(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerScanMetrics
 
addUnknownTabletErrors(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerUpdateMetrics
 
addWalogWriteTime(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerUpdateMetrics
 
addYield(long) - Method in class org.apache.accumulo.tserver.metrics.TabletServerScanMetrics
 
AssignmentHandler(KeyExtent) - Constructor for class org.apache.accumulo.tserver.TabletServer.AssignmentHandler
 
AssignmentHandler(KeyExtent, int) - Constructor for class org.apache.accumulo.tserver.TabletServer.AssignmentHandler
 
AssignmentWatcher(AccumuloConfiguration, Map<KeyExtent, RunnableStartedAt>, SimpleTimer) - Constructor for class org.apache.accumulo.tserver.TabletServerResourceManager.AssignmentWatcher
 
authFailures - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
auths - Variable in class org.apache.accumulo.tserver.session.ConditionalSession
 
auths - Variable in class org.apache.accumulo.tserver.session.ScanSession
 
authTimes - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 

B

BasicCompactionStrategy - Class in org.apache.accumulo.tserver.compaction.strategies
A compaction strategy that covers the following uses cases.
BasicCompactionStrategy() - Constructor for class org.apache.accumulo.tserver.compaction.strategies.BasicCompactionStrategy
 
batchCount - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
batchTimeOut - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
batchTimeOut - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
BatchWriterReplicationReplayer - Class in org.apache.accumulo.tserver.replication
Use a BatchWriter to replay WAL entries to an Accumulo table.
BatchWriterReplicationReplayer() - Constructor for class org.apache.accumulo.tserver.replication.BatchWriterReplicationReplayer
 
beginUpdatingLogsUsed(InMemoryMap, DfsLogger, boolean) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
beginUpdatingLogsUsed(DfsLogger, boolean) - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
buildConfiguration(String, String) - Static method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
Generate the configuration string for this ReplicaSystem
BulkFailedCopyProcessor - Class in org.apache.accumulo.tserver
Copy failed bulk imports.
BulkImportCacheCleaner - Class in org.apache.accumulo.tserver.tablet
 
BulkImportCacheCleaner(TabletServer) - Constructor for class org.apache.accumulo.tserver.tablet.BulkImportCacheCleaner
 
BusiestTracker - Class in org.apache.accumulo.tserver
Computes the N tablets that have the highest deltas for a given monotonically increasing counter.
bytesAdded - Variable in class org.apache.accumulo.tserver.tablet.Tablet.LookupResult
 

C

call() - Method in class org.apache.accumulo.tserver.tablet.Compactor
 
call() - Method in class org.apache.accumulo.tserver.tablet.MinorCompactor
 
cancel(boolean) - Method in class org.apache.accumulo.tserver.scan.ScanTask
 
cenv - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.tserver.constraints.ConstraintChecker
 
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.tserver.constraints.UnsatisfiableConstraint
 
check(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.tserver.ConditionCheckerContext.ConditionChecker
 
checkConditions(ConditionCheckerContext.ConditionChecker, Authorizations, AtomicBoolean) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
checkConstraints() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
checkIfMinorCompactionNeededForLogs(List<DfsLogger>) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
CHOP - org.apache.accumulo.tserver.compaction.MajorCompactionReason
 
chopFiles() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
classLoaderChanged() - Method in class org.apache.accumulo.tserver.constraints.ConstraintChecker
 
cleanup() - Method in class org.apache.accumulo.tserver.session.ConditionalSession
 
cleanup() - Method in class org.apache.accumulo.tserver.session.MultiScanSession
 
cleanup() - Method in class org.apache.accumulo.tserver.session.Session
 
cleanup() - Method in class org.apache.accumulo.tserver.session.SingleScanSession
 
cleanup() - Method in class org.apache.accumulo.tserver.session.SummarySession
 
cleanupBulkLoadedFiles(Set<Long>) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
cleanupReplacement(VolumeManager, FileStatus[], boolean) - Static method in class org.apache.accumulo.tserver.tablet.RootFiles
 
client - Variable in class org.apache.accumulo.tserver.session.Session
 
clone() - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
clone() - Method in class org.apache.accumulo.tserver.MemKey
 
cloneWithSamplingEnabled() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
close() - Method in class org.apache.accumulo.tserver.InMemoryMap.MemoryIterator
 
close() - Method in interface org.apache.accumulo.tserver.log.CloseableIterator
 
close() - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
close() - Method in class org.apache.accumulo.tserver.log.RecoveryLogReader
 
close() - Method in class org.apache.accumulo.tserver.log.RecoveryLogsIterator
 
close() - Method in class org.apache.accumulo.tserver.tablet.Scanner
 
close() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.TabletResourceManager
 
close(boolean) - Method in class org.apache.accumulo.tserver.tablet.Tablet
Closes the mapfiles associated with a Tablet.
CLOSE - org.apache.accumulo.tserver.MinorCompactionReason
 
CloseableIterator<T> - Interface in org.apache.accumulo.tserver.log
 
closed - Variable in class org.apache.accumulo.tserver.tablet.Tablet.LookupResult
 
columnSet - Variable in class org.apache.accumulo.tserver.session.ScanSession
 
commit(List<Mutation>) - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
commit(CommitSession, List<Mutation>) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
CommitSession - Class in org.apache.accumulo.tserver.tablet
 
commitTimes - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
compactAll(long, UserCompactionConfig) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
COMPACTION_FINISH - org.apache.accumulo.tserver.logger.LogEvents
 
COMPACTION_START - org.apache.accumulo.tserver.logger.LogEvents
 
CompactionCanceledException() - Constructor for exception org.apache.accumulo.tserver.tablet.Compactor.CompactionCanceledException
 
CompactionInfo - Class in org.apache.accumulo.tserver.tablet
 
compactionIterator() - Method in class org.apache.accumulo.tserver.InMemoryMap
 
CompactionPlan - Class in org.apache.accumulo.tserver.compaction
A plan for a compaction: the input files, the files that are *not* inputs to a compaction that should simply be deleted, and the optional parameters used to create the resulting output file.
CompactionPlan() - Constructor for class org.apache.accumulo.tserver.compaction.CompactionPlan
 
CompactionStats - Class in org.apache.accumulo.tserver.tablet
 
CompactionStats() - Constructor for class org.apache.accumulo.tserver.tablet.CompactionStats
 
CompactionStrategy - Class in org.apache.accumulo.tserver.compaction
The interface for customizing major compactions.
CompactionStrategy() - Constructor for class org.apache.accumulo.tserver.compaction.CompactionStrategy
 
CompactionWatcher - Class in org.apache.accumulo.tserver.tablet
 
CompactionWatcher(AccumuloConfiguration) - Constructor for class org.apache.accumulo.tserver.tablet.CompactionWatcher
 
Compactor - Class in org.apache.accumulo.tserver.tablet
 
Compactor(ServerContext, Tablet, Map<FileRef, DataFileValue>, InMemoryMap, FileRef, boolean, Compactor.CompactionEnv, List<IteratorSetting>, int, AccumuloConfiguration) - Constructor for class org.apache.accumulo.tserver.tablet.Compactor
 
Compactor.CompactionCanceledException - Exception in org.apache.accumulo.tserver.tablet
 
Compactor.CompactionEnv - Interface in org.apache.accumulo.tserver.tablet
 
compareTo(Key) - Method in class org.apache.accumulo.tserver.MemKey
 
compareTo(DfsLogger) - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
compareTo(LogFileKey) - Method in class org.apache.accumulo.tserver.logger.LogFileKey
 
computeBusiest(Collection<Tablet>) - Method in class org.apache.accumulo.tserver.BusiestTracker
 
ConditionalMutationSet - Class in org.apache.accumulo.tserver
 
ConditionalMutationSet() - Constructor for class org.apache.accumulo.tserver.ConditionalMutationSet
 
ConditionalSession - Class in org.apache.accumulo.tserver.session
 
ConditionalSession(TCredentials, Authorizations, TableId, Durability) - Constructor for class org.apache.accumulo.tserver.session.ConditionalSession
 
ConditionChecker(List<ServerConditionalMutation>, List<ServerConditionalMutation>, List<TCMResult>) - Constructor for class org.apache.accumulo.tserver.ConditionCheckerContext.ConditionChecker
 
ConditionCheckerContext - Class in org.apache.accumulo.tserver
 
ConditionCheckerContext.ConditionChecker - Class in org.apache.accumulo.tserver
 
ConfigurableCompactionStrategy - Class in org.apache.accumulo.tserver.compaction.strategies
The compaction strategy used by the shell compact command.
ConfigurableCompactionStrategy() - Constructor for class org.apache.accumulo.tserver.compaction.strategies.ConfigurableCompactionStrategy
 
configure(ServerContext, String) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
ConstraintChecker - Class in org.apache.accumulo.tserver.constraints
 
ConstraintChecker(TableConfiguration) - Constructor for class org.apache.accumulo.tserver.constraints.ConstraintChecker
 
consumeWalPrefix(ReplicationTarget, DataInputStream, Replication.Status) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
context - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
context - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
CountingIterator - Class in org.apache.accumulo.tserver.tablet
 
CountingIterator(SortedKeyValueIterator<Key, Value>, AtomicLong) - Constructor for class org.apache.accumulo.tserver.tablet.CountingIterator
 
createLogId() - Method in class org.apache.accumulo.tserver.TabletServer
 
createScanExecutors(Collection<AccumuloConfiguration.ScanExecutorConfig>, Map<String, Queue<?>>) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
createScanner(Range, int, Set<Column>, Authorizations, List<IterInfo>, Map<String, Map<String, String>>, boolean, AtomicBoolean, SamplerConfiguration, long, String) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
createSession(Session, boolean) - Method in class org.apache.accumulo.tserver.session.SessionManager
 
createTableConfiguration(TableConfiguration, CompactionPlan) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
createTabletResourceManager(KeyExtent, AccumuloConfiguration) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
credentials - Variable in class org.apache.accumulo.tserver.session.ConditionalSession
 
currentTablet - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 

D

dataSize - Variable in class org.apache.accumulo.tserver.tablet.Tablet.LookupResult
 
decode(Value) - Static method in class org.apache.accumulo.tserver.MemValue
 
decrementCommitsInProgress() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.tserver.InMemoryMap.MemoryIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.tserver.tablet.CountingIterator
 
DefaultCompactionStrategy - Class in org.apache.accumulo.tserver.compaction
 
DefaultCompactionStrategy() - Constructor for class org.apache.accumulo.tserver.compaction.DefaultCompactionStrategy
 
DEFINE_TABLET - org.apache.accumulo.tserver.logger.LogEvents
 
defineTablet(CommitSession) - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
delete() - Method in class org.apache.accumulo.tserver.NativeMap
 
delete(long) - Method in class org.apache.accumulo.tserver.InMemoryMap
 
deleteFiles - Variable in class org.apache.accumulo.tserver.compaction.CompactionPlan
 
description() - Method in class org.apache.accumulo.tserver.TServerExecutable
 
detach() - Method in class org.apache.accumulo.tserver.FileManager.ScanFileManager
 
DfsLogger - Class in org.apache.accumulo.tserver.log
Wrap a connection to a logger.
DfsLogger(ServerContext, DfsLogger.ServerResources, String, String) - Constructor for class org.apache.accumulo.tserver.log.DfsLogger
Reference a pre-existing log file.
DfsLogger(ServerContext, DfsLogger.ServerResources, AtomicLong, AtomicLong) - Constructor for class org.apache.accumulo.tserver.log.DfsLogger
 
DfsLogger.DFSLoggerInputStreams - Class in org.apache.accumulo.tserver.log
 
DfsLogger.LogClosedException - Exception in org.apache.accumulo.tserver.log
 
DfsLogger.LogHeaderIncompleteException - Exception in org.apache.accumulo.tserver.log
A well-timed tabletserver failure could result in an incomplete header written to a write-ahead log.
DfsLogger.ServerResources - Interface in org.apache.accumulo.tserver.log
 
DFSLoggerInputStreams(FSDataInputStream, DataInputStream) - Constructor for class org.apache.accumulo.tserver.log.DfsLogger.DFSLoggerInputStreams
 
doesFileExist(Path, ReplicationTarget) - Method in class org.apache.accumulo.tserver.replication.ReplicationProcessor
 
durability - Variable in class org.apache.accumulo.tserver.session.ConditionalSession
 
durability - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 

E

encode(Value, int) - Static method in class org.apache.accumulo.tserver.MemValue
 
enqueueMasterMessage(MasterMessage) - Method in class org.apache.accumulo.tserver.TabletServer
 
entriesConsumed - Variable in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.ReplicationStats
The number of entries consumed from the log (to increment Replication.Status's begin)
entriesReturned - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
equals(Object) - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
equals(Object) - Method in class org.apache.accumulo.tserver.logger.LogFileKey
 
equals(Object) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.ReplicationStats
 
equals(Object) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.WalReplication
 
estimatedSizeInBytes() - Method in class org.apache.accumulo.tserver.InMemoryMap
Returns a long representing the size of the InMemoryMap
estimateTabletSize() - Method in class org.apache.accumulo.tserver.tablet.Tablet
Returns an int representing the total block size of the files served by this tablet.
event - Variable in class org.apache.accumulo.tserver.logger.LogFileKey
 
EverythingCompactionStrategy - Class in org.apache.accumulo.tserver.compaction
The default compaction strategy for user initiated compactions.
EverythingCompactionStrategy() - Constructor for class org.apache.accumulo.tserver.compaction.EverythingCompactionStrategy
 
execute(String[]) - Method in class org.apache.accumulo.tserver.TServerExecutable
 
execute(ReplicationServicer.Client) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.RFileClientExecReturn
 
execute(ReplicationServicer.Client) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.WalClientExecReturn
 
executeMajorCompaction(KeyExtent, Runnable) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
executeMajorCompaction(KeyExtent, Runnable) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.TabletResourceManager
 
executeMinorCompaction(Runnable) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.TabletResourceManager
 
executeReadAhead(KeyExtent, ScanDispatcher, ScanSession, Runnable) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
executeSplit(KeyExtent, Runnable) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
executeSplit(Tablet) - Method in class org.apache.accumulo.tserver.TabletServer
 
extent - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
extent - Variable in class org.apache.accumulo.tserver.tablet.Compactor
 
extractCount(Tablet) - Method in class org.apache.accumulo.tserver.BusiestTracker
 

F

failures - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
FileManager - Class in org.apache.accumulo.tserver
 
FileManager(ServerContext, VolumeManager, int, Cache<String, Long>, BlockCache, BlockCache) - Constructor for class org.apache.accumulo.tserver.FileManager
 
FileManager.ScanFileManager - Class in org.apache.accumulo.tserver
 
filename - Variable in class org.apache.accumulo.tserver.logger.LogFileKey
 
finalize() - Method in class org.apache.accumulo.tserver.NativeMap
 
FINISHED - org.apache.accumulo.tserver.scan.ScanRunState
 
finishedRun(long, long) - Method in class org.apache.accumulo.tserver.session.ScanSession
 
finishReplacement(AccumuloConfiguration, VolumeManager, Path, Set<FileRef>, String) - Static method in class org.apache.accumulo.tserver.tablet.RootFiles
 
finishUpdatingLogsUsed() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
finishUpdatingLogsUsed() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
flush(long) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
flushComplete(long) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
flushTime - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
format(LogFileValue, int) - Static method in class org.apache.accumulo.tserver.logger.LogFileValue
 

G

gatherInformation(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.CompactionStrategy
Called prior to obtaining the tablet lock, useful for examining metadata or indexes.
gatherInformation(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.SizeLimitCompactionStrategy
 
gatherInformation(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.BasicCompactionStrategy
 
gatherInformation(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.ConfigurableCompactionStrategy
 
gatherInformation(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
 
get() - Method in class org.apache.accumulo.tserver.scan.ScanTask
 
get(long, TimeUnit) - Method in class org.apache.accumulo.tserver.scan.ScanTask
 
get(Key) - Method in class org.apache.accumulo.tserver.NativeMap
 
getActiveScans() - Method in class org.apache.accumulo.tserver.session.SessionManager
 
getActiveScansPerTable() - Method in class org.apache.accumulo.tserver.session.SessionManager
 
getAndUpdateTime() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getAuthorizations() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
getAuthorizationsContainer() - Method in class org.apache.accumulo.tserver.TservConstraintEnv
 
getAverageFilesPerTablet() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getBlockSize() - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
getBulkImported() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getBulkIngestedFiles() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getClientAddressString() - Method in class org.apache.accumulo.tserver.TabletServer
 
getClientScanIterators() - Method in class org.apache.accumulo.tserver.session.ScanSession
 
getCompactID() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getCompactionID() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getCompactionPlan(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.CompactionStrategy
Get the plan for compacting a tablets files.
getCompactionPlan(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.DefaultCompactionStrategy
 
getCompactionPlan(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.EverythingCompactionStrategy
 
getCompactionPlan(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.SizeLimitCompactionStrategy
 
getCompactionPlan(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.BasicCompactionStrategy
 
getCompactionPlan(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.ConfigurableCompactionStrategy
 
getCompactionPlan(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
 
getCompactorID() - Method in class org.apache.accumulo.tserver.tablet.Compactor
 
getCompressType() - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
getConditions() - Method in class org.apache.accumulo.tserver.data.ServerConditionalMutation
 
getConfig() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
Deprecated.
getConfiguration() - Method in interface org.apache.accumulo.tserver.log.DfsLogger.ServerResources
 
getContext() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getContextForPeer(AccumuloConfiguration, ReplicationTarget, String, AuthenticationToken) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
getCount() - Method in class org.apache.accumulo.tserver.tablet.CountingIterator
 
getCreationTime() - Method in class org.apache.accumulo.tserver.session.ScanSession
 
getCredentials() - Method in class org.apache.accumulo.tserver.session.Session
 
getCurrentLocalityGroup() - Method in class org.apache.accumulo.tserver.tablet.Compactor
 
getDataCache() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
getDatafiles() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getDataFiles() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getDataSourceDeletions() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getDecryptingInputStream() - Method in class org.apache.accumulo.tserver.log.DfsLogger.DFSLoggerInputStreams
 
getDirectory() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getDurability() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getDurability() - Method in class org.apache.accumulo.tserver.TabletMutations
 
getEntries() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getEntriesInMemory() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getEntriesRead() - Method in class org.apache.accumulo.tserver.tablet.CompactionInfo
 
getEntriesRead() - Method in class org.apache.accumulo.tserver.tablet.CompactionStats
 
getEntriesWritten() - Method in class org.apache.accumulo.tserver.tablet.CompactionInfo
 
getEntriesWritten() - Method in class org.apache.accumulo.tserver.tablet.CompactionStats
 
getException() - Method in class org.apache.accumulo.tserver.ActiveAssignmentRunnable
 
getExecutionHints() - Method in class org.apache.accumulo.tserver.session.ScanSession
 
getExtent() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
getExtent() - Method in class org.apache.accumulo.tserver.tablet.CompactionInfo
 
getExtent() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getExtent() - Method in class org.apache.accumulo.tserver.TservConstraintEnv
 
getFetchedColumns() - Method in class org.apache.accumulo.tserver.session.ScanSession
 
getFileLenCache() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
getFileName() - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
getFiles() - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
getFileSize() - Method in class org.apache.accumulo.tserver.tablet.CompactionStats
 
getFileSystem() - Method in interface org.apache.accumulo.tserver.log.DfsLogger.ServerResources
 
getFileSystem() - Method in class org.apache.accumulo.tserver.tablet.Compactor
 
getFileSystem() - Method in class org.apache.accumulo.tserver.TabletServer
 
getFlushID() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getFlushID() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getFuture() - Method in class org.apache.accumulo.tserver.session.SummarySession
 
getHdfsBlockSize() - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
getHelper() - Method in class org.apache.accumulo.tserver.replication.ReplicationProcessor
 
getHoldTime() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getHoldTimeMillis() - Method in class org.apache.accumulo.tserver.TabletServer
 
getID() - Method in class org.apache.accumulo.tserver.data.ServerConditionalMutation
 
getID() - Method in class org.apache.accumulo.tserver.tablet.CompactionInfo
 
getIdleTimeStats() - Method in class org.apache.accumulo.tserver.session.ScanSession
 
getIdleTimeStats(long) - Method in class org.apache.accumulo.tserver.session.ScanSession
 
getIndexBlockSize() - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
getIndexCache() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
getIngest() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getIngestByteRate() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getInstanceID() - Method in class org.apache.accumulo.tserver.TabletServer
 
getIteratorScope() - Method in interface org.apache.accumulo.tserver.tablet.Compactor.CompactionEnv
 
getIteratorScope() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
getKeytab(AccumuloConfiguration, ReplicationTarget) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
getKVCount() - Method in class org.apache.accumulo.tserver.MemKey
 
getLastLocation() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getLastRunTime() - Method in class org.apache.accumulo.tserver.session.ScanSession
 
getLocalityGroups(AccumuloConfiguration) - Method in class org.apache.accumulo.tserver.tablet.Compactor
 
getLocalityGroups(AccumuloConfiguration) - Method in class org.apache.accumulo.tserver.tablet.MinorCompactor
 
getLocation() - Method in class org.apache.accumulo.tserver.tablet.Tablet
Returns a Path object representing the tablet's location on the DFS.
getLock() - Method in class org.apache.accumulo.tserver.TabletServer
 
getLogEntries() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getLogFile() - Method in class org.apache.accumulo.tserver.log.TabletServerLogger
Get the current WAL file
getLogger() - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
getLogId() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
getLogId() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getLogSorts() - Method in class org.apache.accumulo.tserver.log.LogSorter
 
getMajorCompactionReadLimiter() - Method in class org.apache.accumulo.tserver.TabletServer
Get the RateLimiter for reads during major compactions on this tserver.
getMajorCompactions() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getMajorCompactionsQueued() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getMajorCompactionWriteLimiter() - Method in class org.apache.accumulo.tserver.TabletServer
Get the RateLimiter for writes during major compactions on this tserver.
getMapType() - Method in class org.apache.accumulo.tserver.InMemoryMap
Description of the type of SimpleMap that is created.
getMaxCommittedTime() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
getMaxFilesPerTablet() - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
getMaxIdleTime() - Method in class org.apache.accumulo.tserver.session.SessionManager
 
getMemoryUsed() - Method in class org.apache.accumulo.tserver.NativeMap
 
getMeta() - Method in class org.apache.accumulo.tserver.log.DfsLogger
get the cq needed to reference this logger's entry in +r/!0
getMinCMetrics() - Method in class org.apache.accumulo.tserver.TabletServer
 
getMinorCompactions() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getMinorCompactionsQueued() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getMoreMetrics(MetricsRecordBuilder, boolean) - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetrics
 
getMutations() - Method in class org.apache.accumulo.tserver.TabletMutations
 
getName() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getNumEntries() - Method in class org.apache.accumulo.tserver.InMemoryMap
 
getNumEntries() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getNumEntriesInMemory() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getNumOpenFiles() - Method in class org.apache.accumulo.tserver.FileManager.ScanFileManager
 
getOnlineCount() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getOnlineTablet(KeyExtent) - Method in class org.apache.accumulo.tserver.TabletServer
 
getOnlineTablets() - Method in class org.apache.accumulo.tserver.TabletServer
 
getOpeningCount() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getOpeningCount() - Method in class org.apache.accumulo.tserver.TabletServer
 
getOriginalInput() - Method in class org.apache.accumulo.tserver.log.DfsLogger.DFSLoggerInputStreams
 
getOutputFile() - Method in class org.apache.accumulo.tserver.tablet.CompactionInfo
 
getPassword(AccumuloConfiguration, ReplicationTarget) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
getPath() - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
getPeerType(String) - Method in class org.apache.accumulo.tserver.replication.ReplicationProcessor
 
getPrincipal(AccumuloConfiguration, ReplicationTarget) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
getQueries() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getQueryByteRate() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getQueryRate() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getReadLimiter() - Method in interface org.apache.accumulo.tserver.tablet.Compactor.CompactionEnv
 
getReason() - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
getReplicaSystem(ReplicationTarget) - Method in class org.apache.accumulo.tserver.replication.ReplicationProcessor
 
getReplication() - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
getResults() - Method in class org.apache.accumulo.tserver.tablet.ScanBatch
 
getRunningCompactions() - Static method in class org.apache.accumulo.tserver.tablet.Compactor
 
getRunTimeStats() - Method in class org.apache.accumulo.tserver.session.ScanSession
 
getSamplerConfiguration() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
getScanFiles() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getScanInfo() - Method in class org.apache.accumulo.tserver.session.ScanSession.ScanMeasurer
 
getScanMetrics() - Method in class org.apache.accumulo.tserver.TabletServer
 
getScannedCounter() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getScannedRate() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getScanRunState() - Method in class org.apache.accumulo.tserver.scan.ScanTask
 
getScanType() - Method in class org.apache.accumulo.tserver.session.MultiScanSession
 
getScanType() - Method in class org.apache.accumulo.tserver.session.SingleScanSession
 
getSecurityOperation() - Method in class org.apache.accumulo.tserver.TabletServer
 
getSeq() - Method in class org.apache.accumulo.tserver.TabletMutations
 
getServerConfig() - Method in class org.apache.accumulo.tserver.TabletServer
 
getServerContext() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
getServerContext() - Method in class org.apache.accumulo.tserver.TservConstraintEnv
 
getServiceEnv() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
getSession(long) - Method in class org.apache.accumulo.tserver.session.SessionManager
 
getSession(long) - Method in class org.apache.accumulo.tserver.TabletServer
 
getSplitCreationTime() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getSplitTime() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getStartTime() - Method in class org.apache.accumulo.tserver.RunnableStartedAt
 
getStats(Map<TableId, MapCounter<ScanRunState>>) - Method in class org.apache.accumulo.tserver.TabletServer
 
getStatus(String, ReplicationTarget) - Method in class org.apache.accumulo.tserver.replication.ReplicationProcessor
 
getSummaries(Collection<FileRef>, Predicate<SummarizerConfiguration>) - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
Returns all summaries present in each file.
getSummaryCache() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
getSummaryPartitionExecutor() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
getSummaryRemoteExecutor() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
getSummaryRetrievalExecutor() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
getTableConfig(String) - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
getTableConfiguration() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getTableConfiguration(KeyExtent) - Method in class org.apache.accumulo.tserver.TabletServer
 
getTableId() - Method in class org.apache.accumulo.tserver.session.MultiScanSession
 
getTableId() - Method in class org.apache.accumulo.tserver.session.SingleScanSession
 
getTableId() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
getTableProperties() - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
getTabletId() - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
getTabletServerResourceManager() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.TabletResourceManager
 
getTabletSession() - Method in class org.apache.accumulo.tserver.TabletServer
 
getTabletStats() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
getTabletStats() - Method in class org.apache.accumulo.tserver.TabletStatsKeeper
 
getTask() - Method in class org.apache.accumulo.tserver.RunnableStartedAt
 
getThread() - Method in class org.apache.accumulo.tserver.tablet.CompactionInfo
 
getTid() - Method in class org.apache.accumulo.tserver.TabletMutations
 
getTime() - Method in class org.apache.accumulo.tserver.tablet.TabletData
 
getTopLevelIterator(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
getTotalMinorCompactions() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getTotalMinorCompactions() - Method in class org.apache.accumulo.tserver.TabletServer
 
getUnopenedCount() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
getUnopenedCount() - Method in class org.apache.accumulo.tserver.TabletServer
 
getUser() - Method in class org.apache.accumulo.tserver.session.Session
 
getUser() - Method in class org.apache.accumulo.tserver.TservConstraintEnv
 
getVersion() - Method in class org.apache.accumulo.tserver.TabletServer
 
getViolationDescription(short) - Method in class org.apache.accumulo.tserver.constraints.UnsatisfiableConstraint
 
getWalEdits(ReplicationTarget, DataInputStream, Path, Replication.Status, long, Set<Integer>) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
getWALogSeq() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
getWalStream(Path, FSDataInputStream) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
getWriteLimiter() - Method in interface org.apache.accumulo.tserver.tablet.Compactor.CompactionEnv
 
getWrites() - Method in class org.apache.accumulo.tserver.log.DfsLogger
 

H

hashCode() - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
hashCode() - Method in class org.apache.accumulo.tserver.logger.LogFileKey
 
hashCode() - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.ReplicationStats
 
hashCode() - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.WalReplication
 
hasNext() - Method in class org.apache.accumulo.tserver.log.RecoveryLogReader
 
hasNext() - Method in class org.apache.accumulo.tserver.log.RecoveryLogsIterator
 
holdAllCommits(boolean) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
holdTime() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager
 
HoldTimeoutException - Exception in org.apache.accumulo.tserver
 
HoldTimeoutException(String) - Constructor for exception org.apache.accumulo.tserver.HoldTimeoutException
 

I

IDLE - org.apache.accumulo.tserver.compaction.MajorCompactionReason
 
importedMapFiles() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.TabletResourceManager
 
importMapFiles(long, Map<FileRef, MapFileInfo>, boolean) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
incrementCommitsInProgress() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
incrementDataSourceDeletions() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
incrementStatusMajor() - Method in class org.apache.accumulo.tserver.TabletStatsKeeper
 
incrementStatusMinor() - Method in class org.apache.accumulo.tserver.TabletStatsKeeper
 
ingestByteRate() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
ingestRate() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
init(Map<String, String>) - Method in class org.apache.accumulo.tserver.compaction.CompactionStrategy
The settings for the compaction strategy pulled from zookeeper.
init(Map<String, String>) - Method in class org.apache.accumulo.tserver.compaction.SizeLimitCompactionStrategy
 
init(Map<String, String>) - Method in class org.apache.accumulo.tserver.compaction.strategies.BasicCompactionStrategy
 
init(Map<String, String>) - Method in class org.apache.accumulo.tserver.compaction.strategies.ConfigurableCompactionStrategy
 
init(Map<String, String>) - Method in class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.tserver.tablet.CountingIterator
 
initiateMajorCompaction(MajorCompactionReason) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
initiateMinorCompaction(MinorCompactionReason) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
InMemoryMap - Class in org.apache.accumulo.tserver
 
InMemoryMap(AccumuloConfiguration, ServerContext, TableId) - Constructor for class org.apache.accumulo.tserver.InMemoryMap
 
InMemoryMap.MemoryIterator - Class in org.apache.accumulo.tserver
 
inputFiles - Variable in class org.apache.accumulo.tserver.compaction.CompactionPlan
 
interruptFlag - Variable in class org.apache.accumulo.tserver.scan.ScanTask
 
interruptFlag - Variable in class org.apache.accumulo.tserver.session.ConditionalSession
 
interruptFlag - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
isCancelled() - Method in class org.apache.accumulo.tserver.scan.ScanTask
 
isCloseComplete() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
isClosed() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
isClosing() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
isCompactionEnabled() - Method in interface org.apache.accumulo.tserver.tablet.Compactor.CompactionEnv
 
isDone() - Method in class org.apache.accumulo.tserver.scan.ScanTask
 
isFullMajorCompaction() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
isLoaded() - Static method in class org.apache.accumulo.tserver.NativeMap
Check if native libraries are loaded.
isMajorCompactionQueued() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
isMajorCompactionRunning() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
isMinorCompactionQueued() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
isMinorCompactionRunning() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
isMore() - Method in class org.apache.accumulo.tserver.tablet.ScanBatch
 
isSamplingEnabled() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
isUserCompaction() - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
iterator() - Method in class org.apache.accumulo.tserver.NativeMap
 
iterator(Key) - Method in class org.apache.accumulo.tserver.NativeMap
 

K

keyword() - Method in class org.apache.accumulo.tserver.TServerExecutable
 
KVEntry - Class in org.apache.accumulo.tserver.tablet
 
KVEntry(Key, Value) - Constructor for class org.apache.accumulo.tserver.tablet.KVEntry
 

L

LARGE_FILE_COMPRESSION_THRESHOLD - Static variable in class org.apache.accumulo.tserver.compaction.strategies.BasicCompactionStrategy
Threshold memory in bytes.
LARGE_FILE_COMPRESSION_TYPE - Static variable in class org.apache.accumulo.tserver.compaction.strategies.BasicCompactionStrategy
Type of compression to use if large threshold is surpassed.
lastAccessTime - Variable in class org.apache.accumulo.tserver.session.Session
 
loadNativeLib(List<File>) - Static method in class org.apache.accumulo.tserver.NativeMap
If native libraries are not loaded, the specified search path will be used to attempt to load them.
log(CommitSession, Mutation, Durability) - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
log(CommitSession, Mutation, Durability) - Method in class org.apache.accumulo.tserver.log.TabletServerLogger
Log a single mutation.
LOG_FILE_HEADER_V3 - Static variable in class org.apache.accumulo.tserver.log.DfsLogger
 
LOG_FILE_HEADER_V4 - Static variable in class org.apache.accumulo.tserver.log.DfsLogger
Simplified encryption technique supported in V4.
LogClosedException() - Constructor for exception org.apache.accumulo.tserver.log.DfsLogger.LogClosedException
 
LogEvents - Enum in org.apache.accumulo.tserver.logger
 
LogFileKey - Class in org.apache.accumulo.tserver.logger
 
LogFileKey() - Constructor for class org.apache.accumulo.tserver.logger.LogFileKey
 
LogFileValue - Class in org.apache.accumulo.tserver.logger
 
LogFileValue() - Constructor for class org.apache.accumulo.tserver.logger.LogFileValue
 
LogHeaderIncompleteException(Throwable) - Constructor for exception org.apache.accumulo.tserver.log.DfsLogger.LogHeaderIncompleteException
 
logManyTablets(Collection<TabletMutations>) - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
logManyTablets(Map<CommitSession, TabletMutations>) - Method in class org.apache.accumulo.tserver.log.TabletServerLogger
Log mutations.
LogReader - Class in org.apache.accumulo.tserver.logger
 
LogReader() - Constructor for class org.apache.accumulo.tserver.logger.LogReader
 
LogSorter - Class in org.apache.accumulo.tserver.log
 
LogSorter(ClientContext, VolumeManager, AccumuloConfiguration) - Constructor for class org.apache.accumulo.tserver.log.LogSorter
 
lookup(List<Range>, HashSet<Column>, Authorizations, List<KVEntry>, long, List<IterInfo>, Map<String, Map<String, String>>, AtomicBoolean, SamplerConfiguration, long, String) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
LookupResult() - Constructor for class org.apache.accumulo.tserver.tablet.Tablet.LookupResult
 
lookupTask - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
LookupTask - Class in org.apache.accumulo.tserver.scan
 
LookupTask(TabletServer, long) - Constructor for class org.apache.accumulo.tserver.scan.LookupTask
 

M

main(String[]) - Static method in class org.apache.accumulo.tserver.logger.LogReader
Dump a Log File (Map or Sequence) to stdout.
main(String[]) - Static method in class org.apache.accumulo.tserver.TabletServer
 
MAJOR - org.apache.accumulo.tserver.TabletStatsKeeper.Operation
 
MajorCompactionReason - Enum in org.apache.accumulo.tserver.compaction
 
MajorCompactionRequest - Class in org.apache.accumulo.tserver.compaction
Information that can be used to determine how a tablet is to be major compacted, if needed.
MajorCompactionRequest(KeyExtent, MajorCompactionReason, AccumuloConfiguration, ServerContext) - Constructor for class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
MajorCompactionRequest(KeyExtent, MajorCompactionReason, VolumeManager, AccumuloConfiguration, BlockCache, BlockCache, Cache<String, Long>, ServerContext) - Constructor for class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
MajorCompactionRequest(MajorCompactionRequest) - Constructor for class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
MANY_MUTATIONS - org.apache.accumulo.tserver.logger.LogEvents
 
MasterMessage - Interface in org.apache.accumulo.tserver.mastermessage
 
MemKey - Class in org.apache.accumulo.tserver
 
MemKey() - Constructor for class org.apache.accumulo.tserver.MemKey
 
MemKey(byte[], byte[], byte[], byte[], long, boolean, boolean, int) - Constructor for class org.apache.accumulo.tserver.MemKey
 
MemKey(Key, int) - Constructor for class org.apache.accumulo.tserver.MemKey
 
MemValue - Class in org.apache.accumulo.tserver
 
MemValue(Value, int) - Constructor for class org.apache.accumulo.tserver.MemValue
 
MINOR - org.apache.accumulo.tserver.TabletStatsKeeper.Operation
 
minorCompactionComplete() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
minorCompactionFinished(long, int, Durability) - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
minorCompactionFinished(CommitSession, long) - Method in class org.apache.accumulo.tserver.TabletServer
 
minorCompactionFinished(CommitSession, long, Durability) - Method in class org.apache.accumulo.tserver.log.TabletServerLogger
 
MinorCompactionReason - Enum in org.apache.accumulo.tserver
 
minorCompactionStarted() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
minorCompactionStarted(long, int, String, Durability) - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
minorCompactionStarted(CommitSession, long, String) - Method in class org.apache.accumulo.tserver.TabletServer
 
minorCompactionStarted(CommitSession, long, String, Durability) - Method in class org.apache.accumulo.tserver.log.TabletServerLogger
 
minorCompactionWaitingToStart() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
minorCompactNow(MinorCompactionReason) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
MinorCompactor - Class in org.apache.accumulo.tserver.tablet
 
MinorCompactor(TabletServer, Tablet, InMemoryMap, FileRef, DataFileValue, FileRef, MinorCompactionReason, TableConfiguration) - Constructor for class org.apache.accumulo.tserver.tablet.MinorCompactor
 
MultiScanSession - Class in org.apache.accumulo.tserver.session
 
MultiScanSession(TCredentials, KeyExtent, Map<KeyExtent, List<Range>>, List<IterInfo>, Map<String, Map<String, String>>, Authorizations, SamplerConfiguration, long, String, Map<String, String>) - Constructor for class org.apache.accumulo.tserver.session.MultiScanSession
 
mutate(List<Mutation>, int) - Method in class org.apache.accumulo.tserver.InMemoryMap
Applies changes to a row in the InMemoryMap
mutate(List<Mutation>, int) - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
MUTATION - org.apache.accumulo.tserver.logger.LogEvents
 
MutationReceiver - Interface in org.apache.accumulo.tserver.log
 
mutations - Variable in class org.apache.accumulo.tserver.logger.LogFileValue
 

N

NativeMap - Class in org.apache.accumulo.tserver
This class stores data in a C++ map.
NativeMap() - Constructor for class org.apache.accumulo.tserver.NativeMap
 
needsMajorCompaction(SortedMap<FileRef, DataFileValue>, MajorCompactionReason) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.TabletResourceManager
 
needsMajorCompaction(MajorCompactionReason) - Method in class org.apache.accumulo.tserver.tablet.Tablet
Returns true if a major compaction should be performed on the tablet.
needsSplit() - Method in class org.apache.accumulo.tserver.tablet.Tablet
Returns true if this tablet needs to be split
newChecker(List<ServerConditionalMutation>, List<ServerConditionalMutation>, List<TCMResult>) - Method in class org.apache.accumulo.tserver.ConditionCheckerContext
 
newProcessor() - Method in class org.apache.accumulo.tserver.BulkFailedCopyProcessor
 
newProcessor() - Method in class org.apache.accumulo.tserver.replication.ReplicationProcessor
 
newScanFileManager() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.TabletResourceManager
 
newScanFileManager(KeyExtent) - Method in class org.apache.accumulo.tserver.FileManager
 
next() - Method in class org.apache.accumulo.tserver.log.RecoveryLogReader
 
next() - Method in class org.apache.accumulo.tserver.log.RecoveryLogsIterator
 
next() - Method in class org.apache.accumulo.tserver.tablet.CountingIterator
 
nextBatchTask - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
NextBatchTask - Class in org.apache.accumulo.tserver.scan
 
NextBatchTask(TabletServer, long, AtomicBoolean) - Constructor for class org.apache.accumulo.tserver.scan.NextBatchTask
 
NORMAL - org.apache.accumulo.tserver.compaction.MajorCompactionReason
 
numEntries - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
numRanges - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
numTablets - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
numUpdates - Variable in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.WalReplication
The number of updates contained in this batch

O

OnlineTablets - Class in org.apache.accumulo.tserver
 
OnlineTablets() - Constructor for class org.apache.accumulo.tserver.OnlineTablets
 
open(String) - Method in class org.apache.accumulo.tserver.log.DfsLogger
Opens a Write-Ahead Log file and writes the necessary header information and OPEN entry to the file.
OPEN - org.apache.accumulo.tserver.logger.LogEvents
 
openFiles(Map<FileRef, DataFileValue>, boolean, SamplerConfigurationImpl) - Method in class org.apache.accumulo.tserver.FileManager.ScanFileManager
 
openReader(FileRef) - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
org.apache.accumulo.tserver - package org.apache.accumulo.tserver
 
org.apache.accumulo.tserver.compaction - package org.apache.accumulo.tserver.compaction
 
org.apache.accumulo.tserver.compaction.strategies - package org.apache.accumulo.tserver.compaction.strategies
 
org.apache.accumulo.tserver.constraints - package org.apache.accumulo.tserver.constraints
 
org.apache.accumulo.tserver.data - package org.apache.accumulo.tserver.data
 
org.apache.accumulo.tserver.log - package org.apache.accumulo.tserver.log
 
org.apache.accumulo.tserver.logger - package org.apache.accumulo.tserver.logger
 
org.apache.accumulo.tserver.mastermessage - package org.apache.accumulo.tserver.mastermessage
 
org.apache.accumulo.tserver.metrics - package org.apache.accumulo.tserver.metrics
 
org.apache.accumulo.tserver.replication - package org.apache.accumulo.tserver.replication
 
org.apache.accumulo.tserver.scan - package org.apache.accumulo.tserver.scan
 
org.apache.accumulo.tserver.session - package org.apache.accumulo.tserver.session
 
org.apache.accumulo.tserver.tablet - package org.apache.accumulo.tserver.tablet
 

P

prepareMetrics() - Method in class org.apache.accumulo.tserver.metrics.TabletServerMetrics
 
prepareMutationsForCommit(TservConstraintEnv, List<Mutation>) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
prepareReplacement(VolumeManager, Path, Set<FileRef>, String) - Static method in class org.apache.accumulo.tserver.tablet.RootFiles
 
prepareTimes - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
printLogEvent(LogFileKey, LogFileValue, Text, Matcher, KeyExtent, Set<Integer>, int) - Static method in class org.apache.accumulo.tserver.logger.LogReader
 
PROCEED_ZERO_NO_SUMMARY_OPT - Static variable in class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
 
PROCEED_ZERO_NO_SUMMARY_OPT_DEFAULT - Static variable in class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
 
process(String, byte[]) - Method in class org.apache.accumulo.tserver.BulkFailedCopyProcessor
 
process(String, byte[]) - Method in class org.apache.accumulo.tserver.replication.ReplicationProcessor
 
put(Key, Value) - Method in class org.apache.accumulo.tserver.NativeMap
 
put(KeyExtent, Tablet) - Method in class org.apache.accumulo.tserver.OnlineTablets
 

Q

queries - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
queryByteRate() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
queryRate() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
QUEUED - org.apache.accumulo.tserver.scan.ScanRunState
 
queuedMutations - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
queuedMutationSize - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 

R

rate() - Method in class org.apache.accumulo.tserver.tablet.Rate
 
Rate - Class in org.apache.accumulo.tserver.tablet
 
Rate(double) - Constructor for class org.apache.accumulo.tserver.tablet.Rate
Turn a counter into an exponentially smoothed rate over time.
read() - Method in class org.apache.accumulo.tserver.tablet.Scanner
 
readaheadThreshold - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
readFields(DataInput) - Method in class org.apache.accumulo.tserver.logger.LogFileKey
 
readFields(DataInput) - Method in class org.apache.accumulo.tserver.logger.LogFileValue
 
readFields(DataInput) - Method in class org.apache.accumulo.tserver.MemKey
 
readHeaderAndReturnStream(FSDataInputStream, AccumuloConfiguration) - Static method in class org.apache.accumulo.tserver.log.DfsLogger
 
reattach(SamplerConfigurationImpl) - Method in class org.apache.accumulo.tserver.FileManager.ScanFileManager
 
receive(Mutation) - Method in interface org.apache.accumulo.tserver.log.MutationReceiver
 
recover(KeyExtent, List<Path>, Set<String>, MutationReceiver) - Method in class org.apache.accumulo.tserver.log.SortedLogRecovery
 
recover(VolumeManager, KeyExtent, List<LogEntry>, Set<String>, MutationReceiver) - Method in class org.apache.accumulo.tserver.TabletServer
 
recover(VolumeManager, KeyExtent, List<Path>, Set<String>, MutationReceiver) - Method in class org.apache.accumulo.tserver.log.TabletServerLogger
 
RECOVERY - org.apache.accumulo.tserver.MinorCompactionReason
 
RecoveryLogReader - Class in org.apache.accumulo.tserver.log
A class which reads sorted recovery logs produced from a single WAL.
RecoveryLogReader(VolumeManager, Path) - Constructor for class org.apache.accumulo.tserver.log.RecoveryLogReader
 
RecoveryLogReader(VolumeManager, Path, LogFileKey, LogFileKey) - Constructor for class org.apache.accumulo.tserver.log.RecoveryLogReader
 
RecoveryLogsIterator - Class in org.apache.accumulo.tserver.log
Iterates over multiple sorted recovery logs merging them into a single sorted stream.
registerSideChannel(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
Deprecated.
releaseOpenFiles(boolean) - Method in class org.apache.accumulo.tserver.FileManager.ScanFileManager
 
remove() - Method in class org.apache.accumulo.tserver.log.RecoveryLogReader
 
remove() - Method in class org.apache.accumulo.tserver.log.RecoveryLogsIterator
 
remove(KeyExtent) - Method in class org.apache.accumulo.tserver.OnlineTablets
 
removeBulkImportState(List<String>) - Method in class org.apache.accumulo.tserver.TabletServer
 
removeIfNotAccessed(long, long) - Method in class org.apache.accumulo.tserver.session.SessionManager
 
removeInUseLogs(Set<DfsLogger>) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
removeScan(ScanDataSource) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
removeSession(long) - Method in class org.apache.accumulo.tserver.session.SessionManager
 
removeSession(long, boolean) - Method in class org.apache.accumulo.tserver.session.SessionManager
 
renameReplacement(VolumeManager, FileRef, FileRef) - Static method in class org.apache.accumulo.tserver.tablet.RootFiles
 
replaceFiles(AccumuloConfiguration, VolumeManager, Path, Set<FileRef>, FileRef, FileRef) - Static method in class org.apache.accumulo.tserver.tablet.RootFiles
 
replicate(Path, Replication.Status, ReplicationTarget, ReplicaSystemHelper) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
replicateKeyValues(String, KeyValues, TCredentials) - Method in class org.apache.accumulo.tserver.replication.ReplicationServicerHandler
 
replicateLog(String, WalEdits, TCredentials) - Method in class org.apache.accumulo.tserver.replication.ReplicationServicerHandler
 
replicateLog(ClientContext, String, WalEdits) - Method in class org.apache.accumulo.tserver.replication.BatchWriterReplicationReplayer
 
replicateLogs(ClientContext, HostAndPort, ReplicationTarget, Path, Replication.Status, long, String, TCredentials, ReplicaSystemHelper, UserGroupInformation, long) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
replicateRFiles(ClientContext, HostAndPort, ReplicationTarget, Path, Replication.Status, long) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
ReplicationProcessor - Class in org.apache.accumulo.tserver.replication
Transmit the given data to a peer
ReplicationProcessor(ServerContext, AccumuloConfiguration, VolumeManager) - Constructor for class org.apache.accumulo.tserver.replication.ReplicationProcessor
 
ReplicationServicerHandler - Class in org.apache.accumulo.tserver.replication
 
ReplicationServicerHandler(TabletServer) - Constructor for class org.apache.accumulo.tserver.replication.ReplicationServicerHandler
 
ReplicationStats(long, long, long) - Constructor for class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.ReplicationStats
 
ReplicationWorker - Class in org.apache.accumulo.tserver.replication
ReplicationWorker(ServerContext, VolumeManager) - Constructor for class org.apache.accumulo.tserver.replication.ReplicationWorker
 
reserveMapFileReader(String) - Method in class org.apache.accumulo.tserver.TabletIteratorEnvironment
Deprecated.
reserveSession(long) - Method in class org.apache.accumulo.tserver.session.SessionManager
while a session is reserved, it cannot be canceled or removed
reserveSession(long, boolean) - Method in class org.apache.accumulo.tserver.session.SessionManager
 
resetLastLocation() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
resultQueue - Variable in class org.apache.accumulo.tserver.scan.ScanTask
 
RFileClientExecReturn() - Constructor for class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.RFileClientExecReturn
 
RootFiles - Class in org.apache.accumulo.tserver.tablet
 
RootFiles() - Constructor for class org.apache.accumulo.tserver.tablet.RootFiles
 
run() - Method in class org.apache.accumulo.tserver.ActiveAssignmentRunnable
 
run() - Method in class org.apache.accumulo.tserver.replication.ReplicationWorker
 
run() - Method in class org.apache.accumulo.tserver.scan.LookupTask
 
run() - Method in class org.apache.accumulo.tserver.scan.NextBatchTask
 
run() - Method in class org.apache.accumulo.tserver.session.ScanSession.ScanMeasurer
 
run() - Method in class org.apache.accumulo.tserver.tablet.BulkImportCacheCleaner
 
run() - Method in class org.apache.accumulo.tserver.tablet.CompactionWatcher
 
run() - Method in class org.apache.accumulo.tserver.TabletServer.AssignmentHandler
 
run() - Method in class org.apache.accumulo.tserver.TabletServer
 
run() - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.AssignmentWatcher
 
RunnableStartedAt - Class in org.apache.accumulo.tserver
Encapsulation of a task and the time it began execution.
RunnableStartedAt(ActiveAssignmentRunnable, Long) - Constructor for class org.apache.accumulo.tserver.RunnableStartedAt
 
RUNNING - org.apache.accumulo.tserver.scan.ScanRunState
 
runningCompactions - Static variable in class org.apache.accumulo.tserver.tablet.Compactor
 
runState - Variable in class org.apache.accumulo.tserver.scan.ScanTask
 
runStats - Variable in class org.apache.accumulo.tserver.session.ScanSession
 

S

samplerConfig - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
saveMajorMinorTimes(TabletStats) - Method in class org.apache.accumulo.tserver.TabletStatsKeeper
 
ScanBatch - Class in org.apache.accumulo.tserver.tablet
 
ScanBatch(List<KVEntry>, boolean) - Constructor for class org.apache.accumulo.tserver.tablet.ScanBatch
 
scanner - Variable in class org.apache.accumulo.tserver.session.SingleScanSession
 
Scanner - Class in org.apache.accumulo.tserver.tablet
 
scanRate() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
ScanRunState - Enum in org.apache.accumulo.tserver.scan
 
ScanSession - Class in org.apache.accumulo.tserver.session
 
ScanSession.ScanMeasurer - Class in org.apache.accumulo.tserver.session
 
ScanTask<T> - Class in org.apache.accumulo.tserver.scan
 
seekCount - Static variable in class org.apache.accumulo.tserver.TabletServer
 
send(TCredentials, String, MasterClientService.Iface) - Method in interface org.apache.accumulo.tserver.mastermessage.MasterMessage
 
send(TCredentials, String, MasterClientService.Iface) - Method in class org.apache.accumulo.tserver.mastermessage.SplitReportMessage
 
send(TCredentials, String, MasterClientService.Iface) - Method in class org.apache.accumulo.tserver.mastermessage.TabletStatusMessage
 
seq - Variable in class org.apache.accumulo.tserver.logger.LogFileKey
 
server - Variable in class org.apache.accumulo.tserver.scan.ScanTask
 
ServerConditionalMutation - Class in org.apache.accumulo.tserver.data
 
ServerConditionalMutation(TConditionalMutation) - Constructor for class org.apache.accumulo.tserver.data.ServerConditionalMutation
 
ServerConditionalMutation.TCMTranslator - Class in org.apache.accumulo.tserver.data
 
Session - Class in org.apache.accumulo.tserver.session
 
SessionManager - Class in org.apache.accumulo.tserver.session
 
SessionManager(AccumuloConfiguration) - Constructor for class org.apache.accumulo.tserver.session.SessionManager
 
setBlockSize(long) - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
setCompressType(String) - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
setConf(AccumuloConfiguration) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
 
setExecutor(ThreadPoolExecutor) - Method in class org.apache.accumulo.tserver.replication.ReplicationWorker
 
setExtent(KeyExtent) - Method in class org.apache.accumulo.tserver.TservConstraintEnv
 
setFiles(Map<FileRef, DataFileValue>) - Method in class org.apache.accumulo.tserver.compaction.MajorCompactionRequest
 
setFileSize(long) - Method in class org.apache.accumulo.tserver.tablet.CompactionStats
 
setHdfsBlockSize(long) - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
setIndexBlockSize(long) - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.tserver.InMemoryMap.MemoryIterator
 
setLastCompactionID(Long) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
setMDS(InMemoryMap.MemoryDataSource) - Method in class org.apache.accumulo.tserver.InMemoryMap.MemoryIterator
 
setReplication(int) - Method in class org.apache.accumulo.tserver.compaction.WriteParameters
 
shouldCompact(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.CompactionStrategy
Determine if this tablet is eligible for a major compaction.
shouldCompact(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.DefaultCompactionStrategy
 
shouldCompact(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.EverythingCompactionStrategy
 
shouldCompact(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.SizeLimitCompactionStrategy
 
shouldCompact(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.BasicCompactionStrategy
 
shouldCompact(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.ConfigurableCompactionStrategy
 
shouldCompact(MajorCompactionRequest) - Method in class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
 
SingleScanSession - Class in org.apache.accumulo.tserver.session
 
SingleScanSession(TCredentials, KeyExtent, HashSet<Column>, List<IterInfo>, Map<String, Map<String, String>>, Authorizations, long, long, String, Map<String, String>) - Constructor for class org.apache.accumulo.tserver.session.SingleScanSession
 
size() - Method in class org.apache.accumulo.tserver.NativeMap
 
SIZE_LIMIT_OPT - Static variable in class org.apache.accumulo.tserver.compaction.SizeLimitCompactionStrategy
 
SIZE_LIMIT_OPT - Static variable in class org.apache.accumulo.tserver.compaction.strategies.BasicCompactionStrategy
 
sizeInBytes - Variable in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.ReplicationStats
The size, in bytes, of the data sent
sizeInRecords - Variable in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.ReplicationStats
The number of records sent
SizeLimitCompactionStrategy - Class in org.apache.accumulo.tserver.compaction
BasicCompactionStrategy offer the same functionality as this class and more.
SizeLimitCompactionStrategy() - Constructor for class org.apache.accumulo.tserver.compaction.SizeLimitCompactionStrategy
 
skvIterator() - Method in class org.apache.accumulo.tserver.NativeMap
 
skvIterator(SamplerConfigurationImpl) - Method in class org.apache.accumulo.tserver.InMemoryMap
 
SortedLogRecovery - Class in org.apache.accumulo.tserver.log
Extract Mutations for a tablet from a set of logs that have been sorted by operation and tablet.
SortedLogRecovery(VolumeManager) - Constructor for class org.apache.accumulo.tserver.log.SortedLogRecovery
 
split(byte[]) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
split(KeyExtent, Tablet, Tablet) - Method in class org.apache.accumulo.tserver.OnlineTablets
 
SPLIT - org.apache.accumulo.tserver.TabletStatsKeeper.Operation
 
SplitReportMessage - Class in org.apache.accumulo.tserver.mastermessage
 
SplitReportMessage(KeyExtent, KeyExtent, Text, KeyExtent, Text) - Constructor for class org.apache.accumulo.tserver.mastermessage.SplitReportMessage
 
ssiList - Variable in class org.apache.accumulo.tserver.session.ScanSession
 
ssio - Variable in class org.apache.accumulo.tserver.session.ScanSession
 
startTime - Variable in class org.apache.accumulo.tserver.session.Session
 
startWatching(AccumuloConfiguration) - Static method in class org.apache.accumulo.tserver.tablet.CompactionWatcher
 
startWatchingForRecoveryLogs(ThreadPoolExecutor) - Method in class org.apache.accumulo.tserver.log.LogSorter
 
state - Variable in class org.apache.accumulo.tserver.scan.ScanTask
 
successfulCommits - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
SummarySession - Class in org.apache.accumulo.tserver.session
 
SummarySession(TCredentials, Future<SummaryCollection>) - Constructor for class org.apache.accumulo.tserver.session.SummarySession
 
SYSTEM - org.apache.accumulo.tserver.MinorCompactionReason
 
SystemConstraint - Class in org.apache.accumulo.tserver.constraints
 
SystemConstraint() - Constructor for class org.apache.accumulo.tserver.constraints.SystemConstraint
 

T

tableId - Variable in class org.apache.accumulo.tserver.session.ConditionalSession
 
tablet - Variable in class org.apache.accumulo.tserver.logger.LogFileKey
 
Tablet - Class in org.apache.accumulo.tserver.tablet
Provide access to a single row range in a living TabletServer.
Tablet(TabletTime, String, int, Path, DatafileManager, TabletServer, TabletServerResourceManager.TabletResourceManager, TabletMemory, TableConfiguration, KeyExtent, ConfigurationObserver) - Constructor for class org.apache.accumulo.tserver.tablet.Tablet
Only visible for testing
Tablet(TabletServer, KeyExtent, TabletServerResourceManager.TabletResourceManager, TabletData) - Constructor for class org.apache.accumulo.tserver.tablet.Tablet
 
Tablet.LookupResult - Class in org.apache.accumulo.tserver.tablet
 
TabletClosedException - Exception in org.apache.accumulo.tserver.tablet
 
TabletClosedException() - Constructor for exception org.apache.accumulo.tserver.tablet.TabletClosedException
 
TabletClosedException(Exception) - Constructor for exception org.apache.accumulo.tserver.tablet.TabletClosedException
 
TabletData - Class in org.apache.accumulo.tserver.tablet
 
TabletData(String, SortedMap<FileRef, DataFileValue>, String, long, long, TServerInstance, Map<Long, List<FileRef>>) - Constructor for class org.apache.accumulo.tserver.tablet.TabletData
 
TabletData(KeyExtent, VolumeManager, Iterator<Map.Entry<Key, Value>>) - Constructor for class org.apache.accumulo.tserver.tablet.TabletData
 
TabletData(ServerContext, VolumeManager, AccumuloConfiguration) - Constructor for class org.apache.accumulo.tserver.tablet.TabletData
 
tabletId - Variable in class org.apache.accumulo.tserver.logger.LogFileKey
 
TabletIteratorEnvironment - Class in org.apache.accumulo.tserver
 
TabletIteratorEnvironment(ServerContext, IteratorUtil.IteratorScope, boolean, AccumuloConfiguration, TableId, MajorCompactionReason) - Constructor for class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
TabletIteratorEnvironment(ServerContext, IteratorUtil.IteratorScope, AccumuloConfiguration, TableId) - Constructor for class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
TabletIteratorEnvironment(ServerContext, IteratorUtil.IteratorScope, AccumuloConfiguration, TableId, FileManager.ScanFileManager, Map<FileRef, DataFileValue>, Authorizations, SamplerConfigurationImpl, ArrayList<SortedKeyValueIterator<Key, Value>>) - Constructor for class org.apache.accumulo.tserver.TabletIteratorEnvironment
 
TabletMutations - Class in org.apache.accumulo.tserver
 
TabletMutations(CommitSession, List<Mutation>, Durability) - Constructor for class org.apache.accumulo.tserver.TabletMutations
 
TabletServer - Class in org.apache.accumulo.tserver
 
TabletServer.AssignmentHandler - Class in org.apache.accumulo.tserver
 
TabletServerLogger - Class in org.apache.accumulo.tserver.log
Central logging facility for the TServerInfo.
TabletServerLogger(TabletServer, long, AtomicLong, AtomicLong, Retry.RetryFactory, Retry.RetryFactory, long) - Constructor for class org.apache.accumulo.tserver.log.TabletServerLogger
 
TabletServerMetrics - Class in org.apache.accumulo.tserver.metrics
 
TabletServerMetrics(TabletServer) - Constructor for class org.apache.accumulo.tserver.metrics.TabletServerMetrics
 
TabletServerMetricsUtil - Class in org.apache.accumulo.tserver.metrics
Wrapper around extracting metrics from a TabletServer instance Necessary to support both old custom JMX metrics and Hadoop Metrics2
TabletServerMetricsUtil(TabletServer) - Constructor for class org.apache.accumulo.tserver.metrics.TabletServerMetricsUtil
 
TabletServerMinCMetrics - Class in org.apache.accumulo.tserver.metrics
 
TabletServerMinCMetrics() - Constructor for class org.apache.accumulo.tserver.metrics.TabletServerMinCMetrics
 
TabletServerResourceManager - Class in org.apache.accumulo.tserver
ResourceManager is responsible for managing the resources of all tablets within a tablet server.
TabletServerResourceManager(ServerContext) - Constructor for class org.apache.accumulo.tserver.TabletServerResourceManager
 
TabletServerResourceManager.AssignmentWatcher - Class in org.apache.accumulo.tserver
Accepts some map which is tracking active assignment task(s) (running) and monitors them to ensure that the time the assignment(s) have been running don't exceed a threshold.
TabletServerResourceManager.TabletResourceManager - Class in org.apache.accumulo.tserver
 
TabletServerScanMetrics - Class in org.apache.accumulo.tserver.metrics
 
TabletServerScanMetrics() - Constructor for class org.apache.accumulo.tserver.metrics.TabletServerScanMetrics
 
TabletServerUpdateMetrics - Class in org.apache.accumulo.tserver.metrics
 
TabletServerUpdateMetrics() - Constructor for class org.apache.accumulo.tserver.metrics.TabletServerUpdateMetrics
 
TabletStatsKeeper - Class in org.apache.accumulo.tserver
 
TabletStatsKeeper() - Constructor for class org.apache.accumulo.tserver.TabletStatsKeeper
 
TabletStatsKeeper.Operation - Enum in org.apache.accumulo.tserver
 
TabletStatusMessage - Class in org.apache.accumulo.tserver.mastermessage
 
TabletStatusMessage(TabletLoadState, KeyExtent) - Constructor for class org.apache.accumulo.tserver.mastermessage.TabletStatusMessage
 
TCMT - Static variable in class org.apache.accumulo.tserver.data.ServerConditionalMutation
 
TCMTranslator() - Constructor for class org.apache.accumulo.tserver.data.ServerConditionalMutation.TCMTranslator
 
TConstraintViolationException - Exception in org.apache.accumulo.tserver
 
TConstraintViolationException(Violations, List<Mutation>, List<Mutation>, CommitSession) - Constructor for exception org.apache.accumulo.tserver.TConstraintViolationException
 
thread - Variable in class org.apache.accumulo.tserver.tablet.Compactor
 
threadPoolExtent - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
THRESHOLD_OPT - Static variable in class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
This option should be a floating point number between 1 and 0.
THRESHOLD_OPT_DEFAULT - Static variable in class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
The default threshold.
TooManyDeletesCompactionStrategy - Class in org.apache.accumulo.tserver.compaction.strategies
This compaction strategy works in concert with the DeletesSummarizer.
TooManyDeletesCompactionStrategy() - Constructor for class org.apache.accumulo.tserver.compaction.strategies.TooManyDeletesCompactionStrategy
 
TooManyFilesException - Exception in org.apache.accumulo.tserver
 
TooManyFilesException(String) - Constructor for exception org.apache.accumulo.tserver.TooManyFilesException
 
toString() - Method in class org.apache.accumulo.tserver.compaction.CompactionPlan
 
toString() - Method in class org.apache.accumulo.tserver.log.DfsLogger
 
toString() - Method in class org.apache.accumulo.tserver.logger.LogFileKey
 
toString() - Method in class org.apache.accumulo.tserver.logger.LogFileValue
 
toString() - Method in class org.apache.accumulo.tserver.MemKey
 
totalIngest() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
totalLookupTime - Variable in class org.apache.accumulo.tserver.session.MultiScanSession
 
totalQueries() - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
totalUpdates - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
toThrift() - Method in class org.apache.accumulo.tserver.tablet.CompactionInfo
 
translate(TConditionalMutation) - Method in class org.apache.accumulo.tserver.data.ServerConditionalMutation.TCMTranslator
 
TservConstraintEnv - Class in org.apache.accumulo.tserver
 
TServerExecutable - Class in org.apache.accumulo.tserver
 
TServerExecutable() - Constructor for class org.apache.accumulo.tserver.TServerExecutable
 
tserverSession - Variable in class org.apache.accumulo.tserver.logger.LogFileKey
 
TYPE_DEFAULT_MAP - Static variable in class org.apache.accumulo.tserver.InMemoryMap
 
TYPE_LOCALITY_GROUP_MAP - Static variable in class org.apache.accumulo.tserver.InMemoryMap
 
TYPE_LOCALITY_GROUP_MAP_NATIVE - Static variable in class org.apache.accumulo.tserver.InMemoryMap
 
TYPE_NATIVE_MAP_WRAPPER - Static variable in class org.apache.accumulo.tserver.InMemoryMap
 

U

unfinishedRanges - Variable in class org.apache.accumulo.tserver.tablet.Tablet.LookupResult
 
unreserveSession(long) - Method in class org.apache.accumulo.tserver.session.SessionManager
 
unreserveSession(Session) - Method in class org.apache.accumulo.tserver.session.SessionManager
 
UnsatisfiableConstraint - Class in org.apache.accumulo.tserver.constraints
 
UnsatisfiableConstraint(short, String) - Constructor for class org.apache.accumulo.tserver.constraints.UnsatisfiableConstraint
 
update(long, long) - Method in class org.apache.accumulo.tserver.tablet.Rate
 
updateBulkImportState(List<String>, BulkImportState) - Method in class org.apache.accumulo.tserver.TabletServer
 
updateMaxCommittedTime(long) - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
updateMemoryUsageStats(long, long) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
updateMemoryUsageStats(Tablet, long, long) - Method in class org.apache.accumulo.tserver.TabletServerResourceManager.TabletResourceManager
 
updatePersistedTime(long, Map<FileRef, DataFileValue>, long) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
updateQueryStats(int, long) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
updateRates(long) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
UpdateSession - Class in org.apache.accumulo.tserver.session
 
UpdateSession(TservConstraintEnv, TCredentials, Durability) - Constructor for class org.apache.accumulo.tserver.session.UpdateSession
 
updateTabletDataFile(long, FileRef, FileRef, DataFileValue, Set<String>, Set<FileRef>, long) - Method in class org.apache.accumulo.tserver.tablet.Tablet
 
updateTime(TabletStatsKeeper.Operation, long, boolean) - Method in class org.apache.accumulo.tserver.TabletStatsKeeper
 
updateTime(TabletStatsKeeper.Operation, long, long, long, boolean) - Method in class org.apache.accumulo.tserver.TabletStatsKeeper
 
updateTotalQueuedMutationSize(long) - Method in class org.apache.accumulo.tserver.TabletServer
 
usageGroup() - Method in class org.apache.accumulo.tserver.TServerExecutable
 
USER - org.apache.accumulo.tserver.compaction.MajorCompactionReason
 
USER - org.apache.accumulo.tserver.MinorCompactionReason
 

V

validate(Set<FileRef>) - Method in class org.apache.accumulo.tserver.compaction.CompactionPlan
Validate compaction plan.
valueOf(String) - Static method in enum org.apache.accumulo.tserver.compaction.MajorCompactionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.tserver.logger.LogEvents
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.tserver.MinorCompactionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.tserver.scan.ScanRunState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.tserver.TabletStatsKeeper.Operation
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.accumulo.tserver.compaction.MajorCompactionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.tserver.logger.LogEvents
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.tserver.MinorCompactionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.tserver.scan.ScanRunState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.tserver.TabletStatsKeeper.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
verifyTabletInformation(ServerContext, KeyExtent, TServerInstance, SortedMap<Key, Value>, String, ZooLock) - Static method in class org.apache.accumulo.tserver.TabletServer
 
VERSION - Static variable in class org.apache.accumulo.tserver.logger.LogFileKey
 
violations - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 

W

waitForCommitsToFinish() - Method in class org.apache.accumulo.tserver.tablet.CommitSession
 
WalClientExecReturn(ReplicationTarget, DataInputStream, Path, Replication.Status, long, String, TCredentials, Set<Integer>) - Constructor for class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.WalClientExecReturn
 
walEdits - Variable in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.WalReplication
The data to send over the wire
walogClosed(DfsLogger) - Method in class org.apache.accumulo.tserver.TabletServer
 
walogTimes - Variable in class org.apache.accumulo.tserver.session.UpdateSession
 
WalReplication(WalEdits, long, long, long) - Constructor for class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem.WalReplication
 
wrap(ScanSession, Runnable) - Static method in class org.apache.accumulo.tserver.session.ScanSession
 
write(DataOutput) - Method in class org.apache.accumulo.tserver.logger.LogFileKey
 
write(DataOutput) - Method in class org.apache.accumulo.tserver.logger.LogFileValue
 
write(DataOutput) - Method in class org.apache.accumulo.tserver.MemKey
 
writeParameters - Variable in class org.apache.accumulo.tserver.compaction.CompactionPlan
 
WriteParameters - Class in org.apache.accumulo.tserver.compaction
 
WriteParameters() - Constructor for class org.apache.accumulo.tserver.compaction.WriteParameters
 
writeValueAvoidingReplicationCycles(DataOutputStream, LogFileValue, ReplicationTarget) - Method in class org.apache.accumulo.tserver.replication.AccumuloReplicaSystem
Wrapper around LogFileValue.write(java.io.DataOutput) which does not serialize Mutations that do not need to be replicate to the given ReplicationTarget
A B C D E F G H I K L M N O P Q R S T U V W 
All Classes All Packages