org.apache.accumulo.server.master
public class Master extends Object implements LiveTServerSet.Listener, TableObserver, CurrentState
Constructor and Description |
---|
Master(ServerConfiguration config,
org.apache.hadoop.fs.FileSystem fs,
String hostname) |
public Master(ServerConfiguration config, org.apache.hadoop.fs.FileSystem fs, String hostname) throws IOException
IOException
public boolean stillMaster()
public void mustBeOnline(String tableId) throws ThriftTableOperationException
ThriftTableOperationException
public Connector getConnector() throws AccumuloException, AccumuloSecurityException
public static <T> T createInstanceFromPropertyName(AccumuloConfiguration conf, Property property, Class<T> base, T defaultInstance)
public LiveTServerSet.TServerConnection getConnection(TServerInstance server)
public MergeInfo getMergeInfo(org.apache.hadoop.io.Text tableId)
public void setMergeState(MergeInfo info, MergeState state) throws IOException, org.apache.zookeeper.KeeperException, InterruptedException
IOException
org.apache.zookeeper.KeeperException
InterruptedException
public void clearMergeState(org.apache.hadoop.io.Text tableId) throws IOException, org.apache.zookeeper.KeeperException, InterruptedException
IOException
org.apache.zookeeper.KeeperException
InterruptedException
public boolean hasCycled(long time)
public void clearMigrations(String tableId)
public void run() throws IOException, InterruptedException, org.apache.zookeeper.KeeperException
IOException
InterruptedException
org.apache.zookeeper.KeeperException
public ZooLock getMasterLock()
public void update(LiveTServerSet current, Set<TServerInstance> deleted, Set<TServerInstance> added)
update
in interface LiveTServerSet.Listener
public void stateChanged(String tableId, TableState state)
stateChanged
in interface TableObserver
public void initialize(Map<String,TableState> tableIdToStateMap)
initialize
in interface TableObserver
public void sessionExpired()
sessionExpired
in interface TableObserver
public Set<String> onlineTables()
onlineTables
in interface CurrentState
public Set<TServerInstance> onlineTabletServers()
onlineTabletServers
in interface CurrentState
public Collection<MergeInfo> merges()
merges
in interface CurrentState
public void killTServer(TServerInstance server)
public void shutdownTServer(TServerInstance server)
public EventCoordinator getEventCoordinator()
public Instance getInstance()
public AccumuloConfiguration getSystemConfiguration()
public ServerConfiguration getConfiguration()
public org.apache.hadoop.fs.FileSystem getFileSystem()
public void updateRecoveryInProgress(String file)
public Collection<KeyExtent> migrations()
migrations
in interface CurrentState
Copyright © 2011-2015 The Apache Software Foundation. All Rights Reserved.