View Javadoc

1   /**
2    *
3    * Licensed to the Apache Software Foundation (ASF) under one
4    * or more contributor license agreements.  See the NOTICE file
5    * distributed with this work for additional information
6    * regarding copyright ownership.  The ASF licenses this file
7    * to you under the Apache License, Version 2.0 (the
8    * "License"); you may not use this file except in compliance
9    * with the License.  You may obtain a copy of the License at
10   *
11   *     http://www.apache.org/licenses/LICENSE-2.0
12   *
13   * Unless required by applicable law or agreed to in writing, software
14   * distributed under the License is distributed on an "AS IS" BASIS,
15   * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
16   * See the License for the specific language governing permissions and
17   * limitations under the License.
18   */
19  package org.apache.hadoop.hbase;
20  
21  import org.apache.hadoop.conf.Configuration;
22  import org.apache.hadoop.hbase.classification.InterfaceAudience;
23  import org.apache.hadoop.hbase.classification.InterfaceStability;
24  import org.apache.hadoop.hbase.client.ClusterConnection;
25  import org.apache.hadoop.hbase.zookeeper.MetaTableLocator;
26  import org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher;
27  
28  /**
29   * Defines the set of shared functions implemented by HBase servers (Masters
30   * and RegionServers).
31   */
32  @InterfaceAudience.LimitedPrivate(HBaseInterfaceAudience.COPROC)
33  @InterfaceStability.Evolving
34  public interface Server extends Abortable, Stoppable {
35    /**
36     * Gets the configuration object for this server.
37     */
38    Configuration getConfiguration();
39  
40    /**
41     * Gets the ZooKeeper instance for this server.
42     */
43    ZooKeeperWatcher getZooKeeper();
44  
45    /**
46     * Returns a reference to the servers' cluster connection.
47     *
48     * Important note: this method returns a reference to Connection which is managed
49     * by Server itself, so callers must NOT attempt to close connection obtained.
50     */
51    ClusterConnection getConnection();
52  
53    /**
54     * Returns instance of {@link org.apache.hadoop.hbase.zookeeper.MetaTableLocator}
55     * running inside this server. This MetaServerLocator is started and stopped by server, clients
56     * shouldn't manage it's lifecycle.
57     * @return instance of {@link MetaTableLocator} associated with this server.
58     */
59    MetaTableLocator getMetaTableLocator();
60  
61    /**
62     * @return The unique server name for this server.
63     */
64    ServerName getServerName();
65  
66    /**
67     * Get CoordinatedStateManager instance for this server.
68     */
69    CoordinatedStateManager getCoordinatedStateManager();
70  
71    /**
72     * @return The {@link ChoreService} instance for this server
73     */
74    ChoreService getChoreService();
75  }