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

A

add(String, long) - Method in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
add(String, long) - Method in class org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetrics
 
add(String, long) - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
addOrderRecord(Text, String, Replication.Status, Value) - Method in class org.apache.accumulo.master.replication.StatusMaker
Create a record to track when the file was closed to ensure that replication preference is given to files that have been closed the longest and allow the work assigner to try to replicate in order that data was ingested (avoid replay in different order)
addReplicationQueueTimeMetrics() - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
addStatusRecord(Text, String, Value) - Method in class org.apache.accumulo.master.replication.StatusMaker
Create a status record in the replication table
addWorkRecord(Text, Value, Map<String, String>, String) - Method in class org.apache.accumulo.master.replication.WorkMaker
 
allReferencesReplicated(BatchScanner, Text, Set<String>) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
assigned() - Method in class org.apache.accumulo.master.state.TableCounts
 
assignedTablet(KeyExtent) - Method in class org.apache.accumulo.master.Master
 
assignedToDeadServers() - Method in class org.apache.accumulo.master.state.TableCounts
 
assignWork() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 

B

begin() - Method in class org.apache.accumulo.master.state.TableStats
 
BulkImport - Class in org.apache.accumulo.master.tableOps
 
BulkImport(String, String, String, boolean) - Constructor for class org.apache.accumulo.master.tableOps.BulkImport
 

C

call(long, Master) - Method in class org.apache.accumulo.master.tableOps.BulkImport
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.CancelCompactions
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.ChangeTableState
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.CloneTable
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.CompactRange
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.CreateNamespace
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.CreateTable
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.DeleteNamespace
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.DeleteTable
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.ExportTable
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.ImportTable
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.MasterRepo
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.RenameNamespace
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.RenameTable
 
call(long, Master) - Method in class org.apache.accumulo.master.tableOps.TableRangeOp
 
call(long, Master) - Method in class org.apache.accumulo.master.tserverOps.ShutdownTServer
 
call(long, T) - Method in class org.apache.accumulo.master.tableOps.TraceRepo
 
CAN_CLONE - Static variable in class org.apache.accumulo.master.util.TableValidators
 
CancelCompactions - Class in org.apache.accumulo.master.tableOps
 
CancelCompactions(String, String) - Constructor for class org.apache.accumulo.master.tableOps.CancelCompactions
 
ChangeTableState - Class in org.apache.accumulo.master.tableOps
 
ChangeTableState(String, String, TableOperation) - Constructor for class org.apache.accumulo.master.tableOps.ChangeTableState
 
checkVersions(Master) - Method in class org.apache.accumulo.master.tableOps.ImportTable
 
cleanupFinishedWork() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
Remove finished replication work from the internal state
cleanupFinishedWork() - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
Iterate over the queued work to remove entries that have been completed.
cleanupFinishedWork() - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
Iterate over the queued work to remove entries that have been completed.
clearMergeState(String) - Method in class org.apache.accumulo.master.Master
 
clearMigrations(String) - Method in class org.apache.accumulo.master.Master
 
CloneTable - Class in org.apache.accumulo.master.tableOps
 
CloneTable(String, String, String, String, Map<String, String>, Set<String>, boolean) - Constructor for class org.apache.accumulo.master.tableOps.CloneTable
 
CompactRange - Class in org.apache.accumulo.master.tableOps
 
CompactRange(String, String, byte[], byte[], List<IteratorSetting>, CompactionStrategyConfig) - Constructor for class org.apache.accumulo.master.tableOps.CompactRange
 
conf - Variable in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
configure(AccumuloConfiguration, Connector) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
configureWorkAssigner() - Method in class org.apache.accumulo.master.replication.WorkDriver
 
conn - Variable in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
CONTEXT - Static variable in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
CONTEXT - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
CreateNamespace - Class in org.apache.accumulo.master.tableOps
 
CreateNamespace(String, String, Map<String, String>) - Constructor for class org.apache.accumulo.master.tableOps.CreateNamespace
 
CreateTable - Class in org.apache.accumulo.master.tableOps
 
CreateTable(String, String, TimeType, Map<String, String>, String) - Constructor for class org.apache.accumulo.master.tableOps.CreateTable
 
createWork() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
Scan over the ReplicationSchema.WorkSection of the replication table adding work for entries that have data to replicate and have not already been queued.
CUR_FATE_OPS - Static variable in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 

D

DATA_VERSION_PROP - Static variable in class org.apache.accumulo.master.tableOps.ExportTable
 
delegationTokensAvailable() - Method in class org.apache.accumulo.master.Master
Can delegation tokens be generated for users
DeleteNamespace - Class in org.apache.accumulo.master.tableOps
 
DeleteNamespace(String) - Constructor for class org.apache.accumulo.master.tableOps.DeleteNamespace
 
deleteStatusRecord(Key) - Method in class org.apache.accumulo.master.replication.StatusMaker
Because there is only one active Master, and thus one active StatusMaker, the only safe time that we can issue the delete for a Status which is closed is immediately after writing it to the replication table.
DeleteTable - Class in org.apache.accumulo.master.tableOps
 
DeleteTable(String, String) - Constructor for class org.apache.accumulo.master.tableOps.DeleteTable
 
DESCRIPTION - Static variable in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
DESCRIPTION - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
DistributedWorkQueueWorkAssigner - Class in org.apache.accumulo.master.replication
Common methods for WorkAssigners
DistributedWorkQueueWorkAssigner() - Constructor for class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
drainReplicationTable(TInfo, TCredentials, String, Set<String>) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 

E

end(MasterState) - Method in class org.apache.accumulo.master.state.TableStats
 
event(String, Object...) - Method in class org.apache.accumulo.master.EventCoordinator
 
EventCoordinator - Class in org.apache.accumulo.master
 
EventCoordinator() - Constructor for class org.apache.accumulo.master.EventCoordinator
 
EventCoordinator.Listener - Class in org.apache.accumulo.master
 
execute(String[]) - Method in class org.apache.accumulo.master.MasterExecutable
 
EXPORT_VERSION_PROP - Static variable in class org.apache.accumulo.master.tableOps.ExportTable
 
ExportTable - Class in org.apache.accumulo.master.tableOps
 
ExportTable(String, String, String, String) - Constructor for class org.apache.accumulo.master.tableOps.ExportTable
 

F

FAILURES_TXT - Static variable in class org.apache.accumulo.master.tableOps.BulkImport
 
FateAdmin - Class in org.apache.accumulo.master.util
A utility to administer FATE operations
FateAdmin() - Constructor for class org.apache.accumulo.master.util.FateAdmin
 
FateHadoop2Metrics - Class in org.apache.accumulo.master.metrics.fate
 
FateHadoop2Metrics(String, MetricsSystem, long) - Constructor for class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
FateLegacyJMXMetrics - Class in org.apache.accumulo.master.metrics.fate
Basic implementation of fate metrics that publish to JMX when legacy metrics enabled.
FateLegacyJMXMetrics(String, long) - Constructor for class org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetrics
 
FateLegacyJMXMetricsMBean - Interface in org.apache.accumulo.master.metrics.fate
 
FinishedWorkUpdater - Class in org.apache.accumulo.master.replication
Update the status record in the replication table with work that has been replicated to each configured peer.
FinishedWorkUpdater(Connector) - Constructor for class org.apache.accumulo.master.replication.FinishedWorkUpdater
 

G

getActiveTservers(TInfo, TCredentials) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
getConf() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
getConf() - Method in class org.apache.accumulo.master.replication.WorkDriver
 
getConfigurationFactory() - Method in class org.apache.accumulo.master.Master
 
getConnection(TServerInstance) - Method in class org.apache.accumulo.master.Master
 
getConnector() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
getConnector() - Method in class org.apache.accumulo.master.replication.WorkDriver
 
getCurrentFateOps() - Method in class org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetrics
 
getCurrentFateOps() - Method in interface org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetricsMBean
 
getCurrentTime() - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
getDescription() - Method in class org.apache.accumulo.master.tableOps.MasterRepo
 
getDescription() - Method in class org.apache.accumulo.master.tableOps.TraceRepo
 
getEventCoordinator() - Method in class org.apache.accumulo.master.Master
 
getFileSystem() - Method in class org.apache.accumulo.master.Master
 
getLast() - Method in class org.apache.accumulo.master.state.TableStats
 
getLast(String) - Method in class org.apache.accumulo.master.state.TableStats
 
getLastMasterState() - Method in class org.apache.accumulo.master.state.TableStats
 
getListener() - Method in class org.apache.accumulo.master.EventCoordinator
 
getMasterLock() - Method in class org.apache.accumulo.master.Master
 
getMasterMonitorInfo() - Method in class org.apache.accumulo.master.Master
 
getMasterState() - Method in class org.apache.accumulo.master.Master
 
getMasterStats(TInfo, TCredentials) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
getMaxQueueSize() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
getMaxReplicationThreads() - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
getMaxReplicationThreads() - Method in class org.apache.accumulo.master.metrics.ReplicationMetrics
 
getMaxReplicationThreads() - Method in interface org.apache.accumulo.master.metrics.ReplicationMetricsMBean
The total number of threads available to replicate data to peers.
getMergeInfo() - Method in class org.apache.accumulo.master.state.MergeStats
 
getMergeInfo(String) - Method in class org.apache.accumulo.master.Master
 
getMetrics(MetricsCollector, boolean) - Method in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
getMetrics(MetricsCollector, boolean) - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
getMetricsPrefix() - Method in class org.apache.accumulo.master.metrics.ReplicationMetrics
 
getName() - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
getName() - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
getNamespaceId(Instance, String, TableOperation, String) - Static method in class org.apache.accumulo.master.tableOps.Utils
 
getNumConfiguredPeers() - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
getNumConfiguredPeers() - Method in class org.apache.accumulo.master.metrics.ReplicationMetrics
 
getNumConfiguredPeers() - Method in interface org.apache.accumulo.master.metrics.ReplicationMetricsMBean
Peers are systems which data can be replicated to.
getNumFilesPendingReplication() - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
getNumFilesPendingReplication() - Method in class org.apache.accumulo.master.metrics.ReplicationMetrics
 
getNumFilesPendingReplication() - Method in interface org.apache.accumulo.master.metrics.ReplicationMetricsMBean
A system may have multiple Replication targets, each of which have a queue of files to be replicated.
getObjectName() - Method in class org.apache.accumulo.master.metrics.ReplicationMetrics
 
getQueuedWork() - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
getQueuedWork() - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
getQueuedWork(ReplicationTarget) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
getQueuedWork(ReplicationTarget) - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
getQueuedWork(ReplicationTarget) - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
getQueueSize() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
getQueueSize() - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
getQueueSize() - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
getRandomTServer(Set<TServerInstance>, int) - Method in class org.apache.accumulo.master.replication.MasterReplicationCoordinator
 
getReadLock(String, long) - Static method in class org.apache.accumulo.master.tableOps.Utils
 
getReplicationTargets(TableConfiguration) - Method in class org.apache.accumulo.master.replication.WorkMaker
 
getReturn() - Method in class org.apache.accumulo.master.tableOps.MasterRepo
 
getReturn() - Method in class org.apache.accumulo.master.tableOps.TraceRepo
 
getScanTime() - Method in class org.apache.accumulo.master.state.TableStats
 
getServicerAddress(String, TCredentials) - Method in class org.apache.accumulo.master.replication.MasterReplicationCoordinator
 
getSteadyTime() - Method in class org.apache.accumulo.master.Master
Return how long (in milliseconds) there has been a master overseeing this cluster.
getTableId(Instance, String) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
getTime() - Method in class org.apache.accumulo.master.MasterTime
How long has this cluster had a Master?
getWorkQueue() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
getZKConnectionErrorsTotal() - Method in class org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetrics
 
getZKConnectionErrorsTotal() - Method in interface org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetricsMBean
 
getZkFateChildOpsTotal() - Method in class org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetrics
 
getZkFateChildOpsTotal() - Method in interface org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetricsMBean
 
getZooCache() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 

H

hasCycled(long) - Method in class org.apache.accumulo.master.Master
 
hosted() - Method in class org.apache.accumulo.master.state.TableCounts
 

I

ImportTable - Class in org.apache.accumulo.master.tableOps
 
ImportTable(String, String, String, String) - Constructor for class org.apache.accumulo.master.tableOps.ImportTable
 
initialize(Map<String, TableState>) - Method in class org.apache.accumulo.master.Master
 
initializeQueuedWork() - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
Set up any internal state before using the WorkAssigner
initializeQueuedWork() - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
Initialize the queuedWork set with the work already sent out
initializeQueuedWork() - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
Initialize the queuedWork set with the work already sent out
initializeWorkQueue(AccumuloConfiguration) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
Initialize the DistributedWorkQueue using the proper ZK location
initiateFlush(TInfo, TCredentials, String) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
isEnabled() - Method in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
isEnabled() - Method in class org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetrics
 
isEnabled() - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.BulkImport
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.CancelCompactions
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.ChangeTableState
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.CloneTable
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.CompactRange
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.CreateNamespace
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.CreateTable
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.DeleteNamespace
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.DeleteTable
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.ExportTable
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.ImportTable
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.MasterRepo
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.RenameNamespace
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.RenameTable
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tableOps.TableRangeOp
 
isReady(long, Master) - Method in class org.apache.accumulo.master.tserverOps.ShutdownTServer
 
isReady(long, T) - Method in class org.apache.accumulo.master.tableOps.TraceRepo
 
isWorkRequired(Replication.Status) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 

K

keyword() - Method in class org.apache.accumulo.master.MasterExecutable
 

L

lastScanFinished() - Method in class org.apache.accumulo.master.state.TableStats
 

M

main(String[]) - Static method in class org.apache.accumulo.master.Master
 
main(String[]) - Static method in class org.apache.accumulo.master.state.MergeStats
 
main(String[]) - Static method in class org.apache.accumulo.master.state.SetGoalState
Utility program that will change the goal state for the master from the command line.
main(String[]) - Static method in class org.apache.accumulo.master.util.FateAdmin
 
markDeadServerLogsAsClosed(Map<TServerInstance, List<Path>>) - Method in class org.apache.accumulo.master.Master
 
Master - Class in org.apache.accumulo.master
The Master is responsible for assigning and balancing tablets to tablet servers.
Master(ServerConfigurationFactory, VolumeManager, String) - Constructor for class org.apache.accumulo.master.Master
 
MasterClientServiceHandler - Class in org.apache.accumulo.master
 
MasterClientServiceHandler(Master) - Constructor for class org.apache.accumulo.master.MasterClientServiceHandler
 
MasterExecutable - Class in org.apache.accumulo.master
 
MasterExecutable() - Constructor for class org.apache.accumulo.master.MasterExecutable
 
MasterMetricsFactory - Class in org.apache.accumulo.master.metrics
Provide master metrics configuration.
MasterMetricsFactory(AccumuloConfiguration, Master) - Constructor for class org.apache.accumulo.master.metrics.MasterMetricsFactory
 
MasterReplicationCoordinator - Class in org.apache.accumulo.master.replication
Choose a tserver to service a replication task
MasterReplicationCoordinator(Master) - Constructor for class org.apache.accumulo.master.replication.MasterReplicationCoordinator
 
MasterReplicationCoordinator(Master, ZooReader) - Constructor for class org.apache.accumulo.master.replication.MasterReplicationCoordinator
 
MasterRepo - Class in org.apache.accumulo.master.tableOps
 
MasterRepo() - Constructor for class org.apache.accumulo.master.tableOps.MasterRepo
 
MasterTime - Class in org.apache.accumulo.master
Keep a persistent roughly monotone view of how long a master has been overseeing this cluster.
MasterTime(Master) - Constructor for class org.apache.accumulo.master.MasterTime
 
MAX_REPLICATION_THREADS - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
maxQueueSize - Variable in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
merges() - Method in class org.apache.accumulo.master.Master
 
MergeStats - Class in org.apache.accumulo.master.state
 
MergeStats(MergeInfo) - Constructor for class org.apache.accumulo.master.state.MergeStats
 
Metrics2ReplicationMetrics - Class in org.apache.accumulo.master.metrics
 
migrationsSnapshot() - Method in class org.apache.accumulo.master.Master
 
mustBeOnline(String) - Method in class org.apache.accumulo.master.Master
 

N

NAME - Static variable in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
NAME - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
nextMergeState(Connector, CurrentState) - Method in class org.apache.accumulo.master.state.MergeStats
 
NOT_METADATA - Static variable in class org.apache.accumulo.master.util.TableValidators
 
NOT_ROOT - Static variable in class org.apache.accumulo.master.util.TableValidators
 
NOT_ROOT_ID - Static variable in class org.apache.accumulo.master.util.TableValidators
 
NOT_SYSTEM - Static variable in class org.apache.accumulo.master.util.TableValidators
 
NUM_PEERS - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 

O

onlineTables() - Method in class org.apache.accumulo.master.Master
 
onlineTabletServers() - Method in class org.apache.accumulo.master.Master
 
org.apache.accumulo.master - package org.apache.accumulo.master
 
org.apache.accumulo.master.metrics - package org.apache.accumulo.master.metrics
 
org.apache.accumulo.master.metrics.fate - package org.apache.accumulo.master.metrics.fate
 
org.apache.accumulo.master.recovery - package org.apache.accumulo.master.recovery
 
org.apache.accumulo.master.replication - package org.apache.accumulo.master.replication
 
org.apache.accumulo.master.state - package org.apache.accumulo.master.state
 
org.apache.accumulo.master.tableOps - package org.apache.accumulo.master.tableOps
 
org.apache.accumulo.master.tserverOps - package org.apache.accumulo.master.tserverOps
 
org.apache.accumulo.master.util - package org.apache.accumulo.master.util
 

P

PENDING_FILES - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
prepareBulkImport(AccumuloServerContext, VolumeManager, String, String) - Static method in class org.apache.accumulo.master.tableOps.BulkImport
 
prepareMetrics() - Method in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 

Q

queueWork(Path, ReplicationTarget) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
Queue the given work for the target
queueWork(Path, ReplicationTarget) - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
queueWork(Path, ReplicationTarget) - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
Distribute the work for the given path with filename

R

RECORD - Static variable in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
RECORD - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
recoverLogs(KeyExtent, Collection<Collection<String>>) - Method in class org.apache.accumulo.master.recovery.RecoveryManager
 
RecoveryManager - Class in org.apache.accumulo.master.recovery
 
RecoveryManager(Master, long) - Constructor for class org.apache.accumulo.master.recovery.RecoveryManager
 
register() - Method in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
register() - Method in class org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetrics
 
register() - Method in class org.apache.accumulo.master.metrics.MasterMetricsFactory
 
register() - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
removeBulkImportStatus(String) - Method in class org.apache.accumulo.master.Master
 
removeCompleteRecords(Connector, BatchScanner, BatchWriter) - Method in class org.apache.accumulo.master.replication.RemoveCompleteReplicationRecords
Removes Replication.Status records read from the given bs and writes a delete, using the given bw, when that Replication.Status is fully replicated and closed, as defined by StatusUtil.isSafeForRemoval(org.apache.accumulo.server.replication.proto.Replication.Status).
RemoveCompleteReplicationRecords - Class in org.apache.accumulo.master.replication
Delete replication entries from the replication table that are fully replicated and closed
RemoveCompleteReplicationRecords(Connector) - Constructor for class org.apache.accumulo.master.replication.RemoveCompleteReplicationRecords
 
removeNamespaceProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
removeQueuedWork(ReplicationTarget, String) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
Remove the given work from the internal state
removeQueuedWork(ReplicationTarget, String) - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
removeQueuedWork(ReplicationTarget, String) - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
removeRowIfNecessary(BatchWriter, SortedMap<Key, Value>, Text, Text, Text) - Method in class org.apache.accumulo.master.replication.RemoveCompleteReplicationRecords
 
removeSystemProperty(TInfo, TCredentials, String) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
removeTableProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
RenameNamespace - Class in org.apache.accumulo.master.tableOps
 
RenameNamespace(String, String, String) - Constructor for class org.apache.accumulo.master.tableOps.RenameNamespace
 
RenameTable - Class in org.apache.accumulo.master.tableOps
 
RenameTable(String, String, String, String) - Constructor for class org.apache.accumulo.master.tableOps.RenameTable
 
REPLICATION_QUEUE_TIME - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
REPLICATION_QUEUE_TIME_QUANTILES - Static variable in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
ReplicationDriver - Class in org.apache.accumulo.master.replication
Daemon wrapper around the WorkMaker that separates it from the Master
ReplicationDriver(Master) - Constructor for class org.apache.accumulo.master.replication.ReplicationDriver
 
ReplicationMetrics - Class in org.apache.accumulo.master.metrics
JMX bindings to expose 'high-level' metrics about Replication
ReplicationMetricsMBean - Interface in org.apache.accumulo.master.metrics
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
reserveHdfsDirectory(String, long) - Static method in class org.apache.accumulo.master.tableOps.Utils
 
reserveNamespace(String, long, boolean, boolean, TableOperation) - Static method in class org.apache.accumulo.master.tableOps.Utils
 
reserveTable(String, long, boolean, boolean, TableOperation) - Static method in class org.apache.accumulo.master.tableOps.Utils
 
run() - Method in class org.apache.accumulo.master.Master
 
run() - Method in class org.apache.accumulo.master.MasterTime
 
run() - Method in class org.apache.accumulo.master.replication.FinishedWorkUpdater
 
run() - Method in class org.apache.accumulo.master.replication.RemoveCompleteReplicationRecords
 
run() - Method in class org.apache.accumulo.master.replication.ReplicationDriver
 
run() - Method in class org.apache.accumulo.master.replication.StatusMaker
 
run() - Method in class org.apache.accumulo.master.replication.WorkDriver
 
run() - Method in class org.apache.accumulo.master.replication.WorkMaker
 

S

SequentialWorkAssigner - Class in org.apache.accumulo.master.replication
Creates work in ZK which is filename.serialized_ReplicationTarget => filename, but replicates files in the order in which they were created.
SequentialWorkAssigner() - Constructor for class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
SequentialWorkAssigner(AccumuloConfiguration, Connector) - Constructor for class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
sessionExpired() - Method in class org.apache.accumulo.master.Master
 
setBatchWriter(BatchWriter) - Method in class org.apache.accumulo.master.replication.StatusMaker
 
setBatchWriter(BatchWriter) - Method in class org.apache.accumulo.master.replication.WorkMaker
 
setConf(AccumuloConfiguration) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
setConf(AccumuloConfiguration) - Method in class org.apache.accumulo.master.replication.WorkDriver
 
setConnector(Connector) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
setConnector(Connector) - Method in class org.apache.accumulo.master.replication.WorkDriver
 
SetGoalState - Class in org.apache.accumulo.master.state
 
SetGoalState() - Constructor for class org.apache.accumulo.master.state.SetGoalState
 
setMasterGoalState(TInfo, TCredentials, MasterGoalState) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
setMaxQueueSize(int) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
setMergeState(MergeInfo, MergeState) - Method in class org.apache.accumulo.master.Master
 
setNamespaceProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
setQueuedWork(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
setQueuedWork(Set<String>) - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
setSourceTableName(String) - Method in class org.apache.accumulo.master.replication.StatusMaker
Not for public use -- visible only for testing
setSystemProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
setTableProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
setWorkQueue(DistributedWorkQueue) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
setZooCache(ZooCache) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
shouldCreateWork(Replication.Status) - Method in class org.apache.accumulo.master.replication.WorkMaker
 
shouldQueueWork(ReplicationTarget) - Method in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
shouldQueueWork(ReplicationTarget) - Method in class org.apache.accumulo.master.replication.SequentialWorkAssigner
 
shouldQueueWork(ReplicationTarget) - Method in class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
shutdown() - Method in class org.apache.accumulo.master.MasterTime
Shut down the time keeping.
shutdown(TInfo, TCredentials, boolean) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
shutdownServers() - Method in class org.apache.accumulo.master.Master
 
shutdownTabletServer(TInfo, TCredentials, String, boolean) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
shutdownTServer(TServerInstance) - Method in class org.apache.accumulo.master.Master
 
ShutdownTServer - Class in org.apache.accumulo.master.tserverOps
 
ShutdownTServer(TServerInstance, boolean) - Constructor for class org.apache.accumulo.master.tserverOps.ShutdownTServer
 
snapshot() - Method in class org.apache.accumulo.master.metrics.fate.FateLegacyJMXMetrics
Update the metric values from zookeeper after minimumRefreshDelay has expired.
snapshot() - Method in class org.apache.accumulo.master.metrics.Metrics2ReplicationMetrics
 
stateChanged(String, TableState) - Method in class org.apache.accumulo.master.Master
 
StatusMaker - Class in org.apache.accumulo.master.replication
Reads replication records from the metadata table and creates status records in the replication table.
StatusMaker(Connector, VolumeManager) - Constructor for class org.apache.accumulo.master.replication.StatusMaker
 
stillMaster() - Method in class org.apache.accumulo.master.Master
 
suspended() - Method in class org.apache.accumulo.master.state.TableCounts
 

T

TableCounts - Class in org.apache.accumulo.master.state
 
TableCounts() - Constructor for class org.apache.accumulo.master.state.TableCounts
 
TableRangeOp - Class in org.apache.accumulo.master.tableOps
 
TableRangeOp(MergeInfo.Operation, String, String, Text, Text) - Constructor for class org.apache.accumulo.master.tableOps.TableRangeOp
 
TableStats - Class in org.apache.accumulo.master.state
 
TableStats() - Constructor for class org.apache.accumulo.master.state.TableStats
 
TableValidators - Class in org.apache.accumulo.master.util
 
TableValidators() - Constructor for class org.apache.accumulo.master.util.TableValidators
 
TOTAL_FATE_OPS - Static variable in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
TOTAL_ZK_CONN_ERRORS - Static variable in class org.apache.accumulo.master.metrics.fate.FateHadoop2Metrics
 
TraceRepo<T> - Class in org.apache.accumulo.master.tableOps
 
TraceRepo(Repo<T>) - Constructor for class org.apache.accumulo.master.tableOps.TraceRepo
 

U

unassigned() - Method in class org.apache.accumulo.master.state.TableCounts
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.BulkImport
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.CancelCompactions
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.ChangeTableState
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.CloneTable
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.CompactRange
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.CreateNamespace
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.CreateTable
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.DeleteNamespace
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.DeleteTable
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.ExportTable
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.ImportTable
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.MasterRepo
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.RenameNamespace
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.RenameTable
 
undo(long, Master) - Method in class org.apache.accumulo.master.tableOps.TableRangeOp
 
undo(long, Master) - Method in class org.apache.accumulo.master.tserverOps.ShutdownTServer
 
undo(long, T) - Method in class org.apache.accumulo.master.tableOps.TraceRepo
 
UnorderedWorkAssigner - Class in org.apache.accumulo.master.replication
Read work records from the replication table, create work entries for other nodes to complete.
UnorderedWorkAssigner() - Constructor for class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
UnorderedWorkAssigner(AccumuloConfiguration, Connector) - Constructor for class org.apache.accumulo.master.replication.UnorderedWorkAssigner
 
unreserveHdfsDirectory(String, long) - Static method in class org.apache.accumulo.master.tableOps.Utils
 
unreserveNamespace(String, long, boolean) - Static method in class org.apache.accumulo.master.tableOps.Utils
 
unreserveTable(String, long, boolean) - Static method in class org.apache.accumulo.master.tableOps.Utils
 
update(String, TabletState) - Method in class org.apache.accumulo.master.state.TableStats
 
update(KeyExtent, TabletState, boolean, boolean) - Method in class org.apache.accumulo.master.state.MergeStats
 
update(LiveTServerSet, Set<TServerInstance>, Set<TServerInstance>) - Method in class org.apache.accumulo.master.Master
 
updateBulkImportStatus(String, BulkImportState) - Method in class org.apache.accumulo.master.Master
 
Utils - Class in org.apache.accumulo.master.tableOps
 
Utils() - Constructor for class org.apache.accumulo.master.tableOps.Utils
 

V

VALID_ID - Static variable in class org.apache.accumulo.master.util.TableValidators
 
VALID_ID_REGEX - Static variable in class org.apache.accumulo.master.util.TableValidators
 
VALID_NAME - Static variable in class org.apache.accumulo.master.util.TableValidators
 
VERSION - Static variable in class org.apache.accumulo.master.tableOps.ExportTable
 

W

waitForBalance(TInfo) - Method in class org.apache.accumulo.master.Master
 
waitForBalance(TInfo) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
waitForEvents(long) - Method in class org.apache.accumulo.master.EventCoordinator.Listener
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Method in class org.apache.accumulo.master.MasterClientServiceHandler
 
WorkDriver - Class in org.apache.accumulo.master.replication
Driver for a WorkAssigner
WorkDriver(Master) - Constructor for class org.apache.accumulo.master.replication.WorkDriver
 
WorkMaker - Class in org.apache.accumulo.master.replication
Reads replication records from the replication table and creates work records which include target replication system information.
WorkMaker(AccumuloServerContext, Connector) - Constructor for class org.apache.accumulo.master.replication.WorkMaker
 
workQueue - Variable in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 

Z

zooCache - Variable in class org.apache.accumulo.master.replication.DistributedWorkQueueWorkAssigner
 
A B C D E F G H I K L M N O P Q R S T U V W Z 
All Classes All Packages