Package | Description |
---|---|
org.apache.hadoop.hdfs.server.federation.store |
The federation state store tracks persistent values that are shared between
multiple routers.
|
org.apache.hadoop.hdfs.server.federation.store.driver |
The state store uses modular data storage classes derived from
StateStoreDriver to handle querying, updating and deleting data records.
|
org.apache.hadoop.hdfs.server.federation.store.driver.impl |
Implementations of state store data providers/drivers.
|
org.apache.hadoop.hdfs.server.federation.store.records |
Contains the abstract definitions of the state store data records.
|
org.apache.hadoop.hdfs.server.federation.store.records.impl.pb |
The protobuf implementations of state store data records defined in the
org.apache.hadoop.hdfs.server.federation.store.records package.
|
Modifier and Type | Class and Description |
---|---|
class |
CachedRecordStore<R extends BaseRecord>
Record store that takes care of caching the records in memory.
|
Modifier and Type | Method and Description |
---|---|
static <T extends BaseRecord> |
StateStoreUtils.filterMultiple(Query<T> query,
Iterable<T> records)
Filters a list of records to find all records matching the query.
|
static <T extends BaseRecord> |
StateStoreUtils.getRecordClass(Class<T> clazz)
Get the base class for a record class.
|
static <T extends BaseRecord> |
StateStoreUtils.getRecordClass(T record)
Get the base class for a record.
|
static <T extends BaseRecord> |
StateStoreUtils.getRecordName(Class<T> clazz)
Get the base class name for a record.
|
Modifier and Type | Method and Description |
---|---|
static <T extends BaseRecord> |
StateStoreUtils.getRecordClass(Class<T> clazz)
Get the base class for a record class.
|
static <T extends BaseRecord> |
StateStoreUtils.getRecordClass(T record)
Get the base class for a record.
|
Modifier and Type | Method and Description |
---|---|
abstract <T extends BaseRecord> |
StateStoreSerializer.deserialize(byte[] byteArray,
Class<T> clazz)
Deserialize a bytes array into a record.
|
abstract <T extends BaseRecord> |
StateStoreSerializer.deserialize(String data,
Class<T> clazz)
Deserialize a string into a record.
|
abstract <T extends BaseRecord> |
StateStoreDriver.initRecordStorage(String className,
Class<T> clazz)
Initialize storage for a single record class.
|
Modifier and Type | Method and Description |
---|---|
abstract byte[] |
StateStoreSerializer.serialize(BaseRecord record)
Serialize a record into a byte array.
|
abstract String |
StateStoreSerializer.serializeString(BaseRecord record)
Serialize a record into a string.
|
Modifier and Type | Method and Description |
---|---|
boolean |
StateStoreDriver.init(org.apache.hadoop.conf.Configuration config,
String id,
Collection<Class<? extends BaseRecord>> records,
StateStoreMetrics stateStoreMetrics)
Initialize the state store connection.
|
Modifier and Type | Method and Description |
---|---|
<T extends BaseRecord> |
StateStoreSerializerPBImpl.deserialize(byte[] byteArray,
Class<T> clazz) |
<T extends BaseRecord> |
StateStoreSerializerPBImpl.deserialize(String data,
Class<T> clazz) |
<T extends BaseRecord> |
StateStoreMySQLImpl.get(Class<T> clazz) |
<T extends BaseRecord> |
StateStoreZooKeeperImpl.get(Class<T> clazz) |
<T extends BaseRecord> |
StateStoreFileBaseImpl.get(Class<T> clazz) |
<T extends BaseRecord> |
StateStoreBaseImpl.get(Class<T> clazz,
Query<T> query) |
<T extends BaseRecord> |
StateStoreBaseImpl.getMultiple(Class<T> clazz,
Query<T> query) |
protected <T extends BaseRecord> |
StateStoreFileSystemImpl.getReader(String pathName) |
protected <T extends BaseRecord> |
StateStoreFileImpl.getReader(String filename) |
protected abstract <T extends BaseRecord> |
StateStoreFileBaseImpl.getReader(String path)
Get the reader of a record for the file system.
|
<T extends BaseRecord> |
StateStoreFileSystemImpl.getWriter(String pathName) |
<T extends BaseRecord> |
StateStoreFileImpl.getWriter(String filename) |
abstract <T extends BaseRecord> |
StateStoreFileBaseImpl.getWriter(String path)
Get the writer of a record for the file system.
|
<T extends BaseRecord> |
StateStoreMySQLImpl.initRecordStorage(String className,
Class<T> clazz) |
<T extends BaseRecord> |
StateStoreZooKeeperImpl.initRecordStorage(String className,
Class<T> clazz) |
<T extends BaseRecord> |
StateStoreFileBaseImpl.initRecordStorage(String className,
Class<T> recordClass) |
protected <T extends BaseRecord> |
StateStoreSerializableImpl.newRecord(String data,
Class<T> clazz,
boolean includeDates)
Creates a record from an input data string.
|
<T extends BaseRecord> |
StateStoreBaseImpl.put(T record,
boolean allowUpdate,
boolean errorIfExists) |
<T extends BaseRecord> |
StateStoreMySQLImpl.putAll(List<T> records,
boolean allowUpdate,
boolean errorIfExists) |
<T extends BaseRecord> |
StateStoreZooKeeperImpl.putAll(List<T> records,
boolean update,
boolean error) |
<T extends BaseRecord> |
StateStoreFileBaseImpl.putAll(List<T> records,
boolean allowUpdate,
boolean errorIfExists) |
<T extends BaseRecord> |
StateStoreMySQLImpl.remove(Class<T> clazz,
Query<T> query) |
<T extends BaseRecord> |
StateStoreZooKeeperImpl.remove(Class<T> clazz,
Query<T> query) |
<T extends BaseRecord> |
StateStoreFileBaseImpl.remove(Class<T> clazz,
Query<T> query) |
<T extends BaseRecord> |
StateStoreBaseImpl.remove(T record) |
<T extends BaseRecord> |
StateStoreMySQLImpl.removeAll(Class<T> clazz) |
<T extends BaseRecord> |
StateStoreZooKeeperImpl.removeAll(Class<T> clazz) |
<T extends BaseRecord> |
StateStoreFileBaseImpl.removeAll(Class<T> clazz) |
protected <T extends BaseRecord> |
StateStoreSerializableImpl.serialize(T record)
Serialize a record using the serializer.
|
protected <T extends BaseRecord> |
StateStoreSerializableImpl.serializeString(T record)
Serialize a record using the serializer.
|
Modifier and Type | Method and Description |
---|---|
protected static String |
StateStoreSerializableImpl.getPrimaryKey(BaseRecord record)
Get the primary key for a record.
|
byte[] |
StateStoreSerializerPBImpl.serialize(BaseRecord record) |
String |
StateStoreSerializerPBImpl.serializeString(BaseRecord record) |
Modifier and Type | Method and Description |
---|---|
boolean |
StateStoreSerializableImpl.init(org.apache.hadoop.conf.Configuration config,
String id,
Collection<Class<? extends BaseRecord>> records,
StateStoreMetrics metrics) |
Modifier and Type | Class and Description |
---|---|
class |
Query<T extends BaseRecord>
Check if a record matches a query.
|
class |
QueryResult<T extends BaseRecord>
Encapsulates a state store query result that includes a set of records and a
time stamp for the result.
|
Modifier and Type | Class and Description |
---|---|
class |
DisabledNameservice
Data record indicating a specific name service ID has been disabled and
is no longer valid.
|
class |
MembershipState
Data schema for storing NN registration information in the
StateStoreService . |
class |
MembershipStats
Data schema for storing NN stats in the
StateStoreService . |
class |
MountTable
Data schema for
MountTableStore data stored in the StateStoreService . |
class |
RouterState
Entry to log the state of a
Router in the
StateStoreService . |
class |
StateStoreVersion
Entry to track the version of the State Store data stored in the State Store
by a Router.
|
Modifier and Type | Method and Description |
---|---|
int |
RouterState.compareTo(BaseRecord other) |
int |
BaseRecord.compareTo(BaseRecord record) |
int |
MembershipState.compareTo(BaseRecord record)
First use the comparator of the BaseRecord to compare the date modified.
|
boolean |
MountTable.like(BaseRecord o) |
boolean |
RouterState.like(BaseRecord o) |
boolean |
BaseRecord.like(BaseRecord other)
Check if this record matches a partial record.
|
boolean |
MembershipState.like(BaseRecord o) |
Modifier and Type | Class and Description |
---|---|
class |
DisabledNameservicePBImpl
Protobuf implementation of the
DisabledNameservice record. |
class |
MembershipStatePBImpl
Protobuf implementation of the MembershipState record.
|
class |
MembershipStatsPBImpl
Protobuf implementation of the MembershipStats record.
|
class |
MountTablePBImpl
Protobuf implementation of the MountTable record.
|
class |
RouterStatePBImpl
Protobuf implementation of the RouterState record.
|
class |
StateStoreVersionPBImpl
Protobuf implementation of the StateStoreVersion record.
|
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.