org.apache.accumulo.server.tabletserver
public class Tablet extends Object
Modifier and Type | Class and Description |
---|---|
class |
Tablet.CommitSession |
static class |
Tablet.KVEntry |
static interface |
Tablet.KVReceiver |
static class |
Tablet.TabletClosedException |
Modifier and Type | Field and Description |
---|---|
Object |
bulkFileImportLock |
TabletStatsKeeper |
timer |
Constructor and Description |
---|
Tablet(TabletServer tabletServer,
org.apache.hadoop.io.Text location,
KeyExtent extent,
TabletServerResourceManager.TabletResourceManager trm,
SortedMap<Key,Value> tabletsKeyValues) |
Tablet(TabletServer tabletServer,
org.apache.hadoop.io.Text location,
KeyExtent extent,
TabletServerResourceManager.TabletResourceManager trm,
SortedMap<String,MetadataTable.DataFileValue> datafiles,
String time,
long initFlushID,
long initCompactID) |
Modifier and Type | Method and Description |
---|---|
void |
abortCommit(Tablet.CommitSession commitSession,
List<Mutation> value) |
void |
checkConstraints() |
void |
chopFiles() |
void |
close(boolean saveState)
Closes the mapfiles associated with a Tablet.
|
void |
commit(Tablet.CommitSession commitSession,
List<Mutation> mutations) |
void |
compactAll(long compactionId) |
long |
estimateTabletSize()
Returns an int representing the total block size of the mapfiles served by this tablet.
|
Set<String> |
getCurrentLogs() |
SortedMap<String,MetadataTable.DataFileValue> |
getDatafiles() |
KeyExtent |
getExtent()
Returns a KeyExtent object representing this tablet's key range.
|
org.apache.hadoop.fs.Path |
getLocation()
Returns a Path object representing the tablet's location on the DFS.
|
int |
getLogCount() |
int |
getLogId() |
long |
getNumEntries() |
long |
getNumEntriesInMemory() |
long |
getSplitCreationTime() |
TableConfiguration |
getTableConfiguration() |
void |
importMapFiles(long tid,
Map<String,MapFileInfo> fileMap,
boolean setTime) |
double |
ingestByteRate() |
double |
ingestRate() |
boolean |
isCloseComplete() |
boolean |
isClosed() |
boolean |
isClosing() |
org.apache.accumulo.server.tabletserver.Tablet.LookupResult |
lookup(List<Range> ranges,
HashSet<Column> columns,
Authorizations authorizations,
ArrayList<Tablet.KVEntry> results,
long maxResultSize,
List<IterInfo> ssiList,
Map<String,Map<String,String>> ssio,
AtomicBoolean interruptFlag) |
boolean |
majorCompactionQueued() |
boolean |
majorCompactionRunning() |
boolean |
minorCompactionQueued() |
boolean |
minorCompactionRunning() |
boolean |
needsMajorCompaction(org.apache.accumulo.server.tabletserver.Tablet.MajorCompactionReason reason)
Returns true if a major compaction should be performed on the tablet.
|
boolean |
needsSplit()
Returns true if this tablet needs to be split
|
Tablet.CommitSession |
prepareMutationsForCommit(org.apache.accumulo.server.tabletserver.TabletServer.TservConstraintEnv cenv,
List<Mutation> mutations) |
double |
queryByteRate() |
double |
queryRate() |
double |
scanRate() |
TreeMap<KeyExtent,org.apache.accumulo.server.tabletserver.Tablet.SplitInfo> |
split(byte[] sp) |
long |
totalIngest() |
long |
totalQueries() |
void |
updateRates(long now) |
void |
waitForMinC() |
public TabletStatsKeeper timer
public final Object bulkFileImportLock
public Tablet(TabletServer tabletServer, org.apache.hadoop.io.Text location, KeyExtent extent, TabletServerResourceManager.TabletResourceManager trm, SortedMap<Key,Value> tabletsKeyValues) throws IOException
IOException
public Tablet(TabletServer tabletServer, org.apache.hadoop.io.Text location, KeyExtent extent, TabletServerResourceManager.TabletResourceManager trm, SortedMap<String,MetadataTable.DataFileValue> datafiles, String time, long initFlushID, long initCompactID) throws IOException
IOException
public int getLogId()
public org.apache.accumulo.server.tabletserver.Tablet.LookupResult lookup(List<Range> ranges, HashSet<Column> columns, Authorizations authorizations, ArrayList<Tablet.KVEntry> results, long maxResultSize, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, AtomicBoolean interruptFlag) throws IOException
IOException
public void waitForMinC()
public void checkConstraints()
public Tablet.CommitSession prepareMutationsForCommit(org.apache.accumulo.server.tabletserver.TabletServer.TservConstraintEnv cenv, List<Mutation> mutations) throws org.apache.accumulo.server.tabletserver.Tablet.TConstraintViolationException
org.apache.accumulo.server.tabletserver.Tablet.TConstraintViolationException
public void abortCommit(Tablet.CommitSession commitSession, List<Mutation> value)
public void commit(Tablet.CommitSession commitSession, List<Mutation> mutations)
public void close(boolean saveState) throws IOException
IOException
public org.apache.hadoop.fs.Path getLocation()
public boolean needsMajorCompaction(org.apache.accumulo.server.tabletserver.Tablet.MajorCompactionReason reason)
public long estimateTabletSize()
public boolean needsSplit()
public KeyExtent getExtent()
public long getNumEntries()
public long getNumEntriesInMemory()
public boolean isClosing()
public boolean isClosed()
public boolean isCloseComplete()
public boolean majorCompactionRunning()
public boolean minorCompactionQueued()
public boolean minorCompactionRunning()
public boolean majorCompactionQueued()
public TreeMap<KeyExtent,org.apache.accumulo.server.tabletserver.Tablet.SplitInfo> split(byte[] sp) throws IOException
IOException
public SortedMap<String,MetadataTable.DataFileValue> getDatafiles()
public double queryRate()
public double queryByteRate()
public double ingestRate()
public double ingestByteRate()
public double scanRate()
public long totalQueries()
public long totalIngest()
public void updateRates(long now)
public long getSplitCreationTime()
public void importMapFiles(long tid, Map<String,MapFileInfo> fileMap, boolean setTime) throws IOException
IOException
public int getLogCount()
public void chopFiles()
public void compactAll(long compactionId)
public TableConfiguration getTableConfiguration()
Copyright © 2015 Apache Accumulo Project. All Rights Reserved.