Uses of Class
org.apache.accumulo.core.data.TableId
-
-
Uses of TableId in org.apache.accumulo.core.client
Methods in org.apache.accumulo.core.client with parameters of type TableId Modifier and Type Method Description PluginEnvironment.Configuration
PluginEnvironment. getConfiguration(TableId tableId)
String
PluginEnvironment. getTableName(TableId tableId)
Many Accumulo plugins are given table IDs as this is what Accumulo uses internally to identify tables.<T> T
PluginEnvironment. instantiate(TableId tableId, String className, Class<T> base)
Instantiate a class using Accumulo's per table classloader.Constructors in org.apache.accumulo.core.client with parameters of type TableId Constructor Description TableOfflineException(TableId tableId, String tableName)
-
Uses of TableId in org.apache.accumulo.core.client.admin.compaction
Methods in org.apache.accumulo.core.client.admin.compaction that return TableId Modifier and Type Method Description TableId
CompactionConfigurer.InitParameters. getTableId()
TableId
CompactionConfigurer.InputParameters. getTableId()
TableId
CompactionSelector.InitParameters. getTableId()
TableId
CompactionSelector.SelectionParameters. getTableId()
-
Uses of TableId in org.apache.accumulo.core.clientImpl
Fields in org.apache.accumulo.core.clientImpl declared as TableId Modifier and Type Field Description protected TableId
TabletLocatorImpl. tableId
Methods in org.apache.accumulo.core.clientImpl that return TableId Modifier and Type Method Description TableId
ClientContext. _getTableIdDetectNamespaceNotFound(String tableName)
TableId
ClientContext. getTableId(String tableName)
TableId
ClientContext. requireNotDeleted(TableId tableId)
TableId
ClientContext. requireNotOffline(TableId tableId, String tableName)
TableId
ClientContext. requireTableExists(TableId tableId, String tableName)
Methods in org.apache.accumulo.core.clientImpl that return types with arguments of type TableId Modifier and Type Method Description static List<TableId>
Namespaces. getTableIds(ClientContext context, NamespaceId namespaceId)
Map<TableId,String>
ClientContext. getTableIdToNameMap()
Map<String,TableId>
ClientContext. getTableNameToIdMap()
Methods in org.apache.accumulo.core.clientImpl with parameters of type TableId Modifier and Type Method Description void
TabletServerBatchWriter. addMutation(TableId table, Iterator<Mutation> iterator)
void
TabletServerBatchWriter. addMutation(TableId table, Mutation m)
ServiceEnvironment.Configuration
ClientServiceEnvironmentImpl. getConfiguration(TableId tableId)
static TabletLocator
TabletLocator. getLocator(ClientContext context, TableId tableId)
NamespaceId
ClientContext. getNamespaceId(TableId tableId)
String
ClientContext. getPrintableTableInfoFromId(TableId tableId)
String
ClientContext. getTableName(TableId tableId)
String
ClientServiceEnvironmentImpl. getTableName(TableId tableId)
TableState
ClientContext. getTableState(TableId tableId)
TableState
ClientContext. getTableState(TableId tableId, boolean clearCachedState)
<T> T
ClientServiceEnvironmentImpl. instantiate(TableId tableId, String className, Class<T> base)
TableId
ClientContext. requireNotDeleted(TableId tableId)
TableId
ClientContext. requireNotOffline(TableId tableId, String tableName)
TableId
ClientContext. requireTableExists(TableId tableId, String tableName)
boolean
ClientContext. tableNodeExists(TableId tableId)
Constructors in org.apache.accumulo.core.clientImpl with parameters of type TableId Constructor Description BatchWriterImpl(ClientContext context, TableId tableId, BatchWriterConfig config)
OfflineScanner(ClientContext context, TableId tableId, Authorizations authorizations)
ScannerImpl(ClientContext context, TableId tableId, Authorizations authorizations)
ScanState(ClientContext context, TableId tableId, Authorizations authorizations, Range range, SortedSet<Column> fetchedColumns, int size, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, boolean isolated, long readaheadThreshold, SamplerConfiguration samplerConfig, long batchTimeOut, String classLoaderContext, Map<String,String> executionHints, boolean useScanServer)
SyncingTabletLocator(ClientContext context, TableId tableId)
TabletLocatorImpl(TableId tableId, TabletLocator parent, TabletLocatorImpl.TabletLocationObtainer tlo, TabletLocatorImpl.TabletServerLockChecker tslc)
TabletServerBatchDeleter(ClientContext context, TableId tableId, String tableName, Authorizations authorizations, int numQueryThreads, BatchWriterConfig bwConfig)
TabletServerBatchReader(ClientContext context, Class<?> scopeClass, TableId tableId, String tableName, Authorizations authorizations, int numQueryThreads)
TabletServerBatchReader(ClientContext context, TableId tableId, String tableName, Authorizations authorizations, int numQueryThreads)
TabletServerBatchReaderIterator(ClientContext context, TableId tableId, String tableName, Authorizations authorizations, ArrayList<Range> ranges, int numThreads, ExecutorService queryThreadPool, ScannerOptions scannerOptions, long retryTimeout)
TimeoutTabletLocator(long timeout, ClientContext context, TableId table)
Writer(ClientContext context, TableId tableId)
-
Uses of TableId in org.apache.accumulo.core.clientImpl.bulk
Methods in org.apache.accumulo.core.clientImpl.bulk with parameters of type TableId Modifier and Type Method Description SortedMap<KeyExtent,Bulk.Files>
BulkImport. computeFileToTabletMappings(org.apache.hadoop.fs.FileSystem fs, TableId tableId, Map<String,String> tableProps, org.apache.hadoop.fs.Path dirPath, Executor executor, ClientContext context, int maxTablets)
KeyExtent
Bulk.Mapping. getKeyExtent(TableId tableId)
static LoadMappingIterator
BulkSerialize. getUpdatedLoadMapping(String bulkDir, TableId tableId, BulkSerialize.Input input)
Read in both maps and change all the file names in the mapping to the new names.static LoadMappingIterator
BulkSerialize. readLoadMapping(String bulkDir, TableId tableId, BulkSerialize.Input input)
Read Json array of Bulk.Mapping into LoadMappingIteratorKeyExtent
Bulk.Tablet. toKeyExtent(TableId tableId)
static KeyExtent
Bulk. toKeyExtent(TableId tableId, Bulk.Tablet tablet)
-
Uses of TableId in org.apache.accumulo.core.crypto
Methods in org.apache.accumulo.core.crypto that return types with arguments of type TableId Modifier and Type Method Description Optional<TableId>
CryptoEnvironmentImpl. getTableId()
Methods in org.apache.accumulo.core.crypto with parameters of type TableId Modifier and Type Method Description static CryptoEnvironment
CryptoUtils. getCryptoEnv(CryptoEnvironment.Scope scope, TableId tableId, DataInputStream in)
static FileDecrypter
CryptoUtils. getFileDecrypter(CryptoService cs, CryptoEnvironment.Scope scope, TableId tableId, DataInputStream in)
Read the decryption parameters from the DataInputStream and get the FileDecrypter associated with the provided CryptoService and CryptoEnvironment.Scope.static CryptoService
CryptoFactoryLoader. getServiceForClientWithTable(Map<String,String> systemConfig, Map<String,String> tableProps, TableId tableId)
For use by client code, in a Table context.Constructors in org.apache.accumulo.core.crypto with parameters of type TableId Constructor Description CryptoEnvironmentImpl(CryptoEnvironment.Scope scope, TableId tableId, byte[] decryptionParams)
Construct the crypto environment. -
Uses of TableId in org.apache.accumulo.core.data
Methods in org.apache.accumulo.core.data that return TableId Modifier and Type Method Description TableId
TabletId. getTable()
static TableId
TableId. of(String canonical)
Get a TableId object for the provided canonical string. -
Uses of TableId in org.apache.accumulo.core.dataImpl
Methods in org.apache.accumulo.core.dataImpl that return TableId Modifier and Type Method Description TableId
TabletIdImpl. getTable()
TableId
KeyExtent. tableId()
Return the extent's table ID.Constructors in org.apache.accumulo.core.dataImpl with parameters of type TableId Constructor Description KeyExtent(TableId table, org.apache.hadoop.io.Text endRow, org.apache.hadoop.io.Text prevEndRow)
Create a new KeyExtent from its components. -
Uses of TableId in org.apache.accumulo.core.gc
Fields in org.apache.accumulo.core.gc declared as TableId Modifier and Type Field Description TableId
ReferenceFile. tableId
Methods in org.apache.accumulo.core.gc that return TableId Modifier and Type Method Description TableId
Reference. getTableId()
Get theTableId
of the reference.TableId
ReferenceFile. getTableId()
Constructors in org.apache.accumulo.core.gc with parameters of type TableId Constructor Description ReferenceDirectory(TableId tableId, String dirName)
ReferenceFile(TableId tableId, String metadataEntry)
-
Uses of TableId in org.apache.accumulo.core.iterators
Methods in org.apache.accumulo.core.iterators that return TableId Modifier and Type Method Description default TableId
IteratorEnvironment. getTableId()
Return the table Id associated with this iterator. -
Uses of TableId in org.apache.accumulo.core.metadata
Fields in org.apache.accumulo.core.metadata declared as TableId Modifier and Type Field Description static TableId
MetadataTable. ID
static TableId
RootTable. ID
Methods in org.apache.accumulo.core.metadata that return TableId Modifier and Type Method Description abstract TableId
MetadataServicer. getServicedTableId()
TableId
ReferencedTabletFile.FileParts. getTableId()
TableId
ReferencedTabletFile. getTableId()
TableId
StoredTabletFile. getTableId()
Methods in org.apache.accumulo.core.metadata with parameters of type TableId Modifier and Type Method Description static MetadataServicer
MetadataServicer. forTableId(ClientContext context, TableId tableId)
Constructors in org.apache.accumulo.core.metadata with parameters of type TableId Constructor Description FileParts(String volume, TableId tableId, String tabletDir, String fileName, String normalizedPath)
-
Uses of TableId in org.apache.accumulo.core.metadata.schema
Methods in org.apache.accumulo.core.metadata.schema that return TableId Modifier and Type Method Description TableId
TabletMetadata. getTableId()
TableId
Ample.DataLevel. tableId()
Methods in org.apache.accumulo.core.metadata.schema that return types with arguments of type TableId Modifier and Type Method Description static Pair<TableId,org.apache.hadoop.io.Text>
MetadataSchema.TabletsSection. decodeRow(org.apache.hadoop.io.Text metadataRow)
Decodes a metadata row into a pair of table ID and end row.Methods in org.apache.accumulo.core.metadata.schema with parameters of type TableId Modifier and Type Method Description static org.apache.hadoop.io.Text
MetadataSchema.TabletsSection. encodeRow(TableId tableId, org.apache.hadoop.io.Text endRow)
TabletsMetadata.TableRangeOptions
TabletsMetadata.Builder. forTable(TableId tableId)
TabletsMetadata.TableRangeOptions
TabletsMetadata.TableOptions. forTable(TableId tableId)
This method automatically determines where the metadata for the passed in table ID resides.static Range
MetadataSchema.TabletsSection. getRange(TableId tableId)
static Ample.DataLevel
Ample.DataLevel. of(TableId tableId)
default void
Ample. putGcCandidates(TableId tableId, Collection<StoredTabletFile> candidates)
default void
Ample. putGcFileAndDirCandidates(TableId tableId, Collection<ReferenceFile> candidates)
UnlikeAmple.putGcCandidates(TableId, Collection)
this takes file and dir GC candidates.default void
Ample. removeBulkLoadEntries(TableId tableId, long tid, org.apache.hadoop.io.Text firstSplit, org.apache.hadoop.io.Text lastSplit)
Remove all the Bulk Load transaction ids from a given table's metadata -
Uses of TableId in org.apache.accumulo.core.spi.balancer
Methods in org.apache.accumulo.core.spi.balancer that return types with arguments of type TableId Modifier and Type Method Description Map<String,TableId>
BalancerEnvironment. getTableIdMap()
Many Accumulo plugins are given table IDs as this is what Accumulo uses internally to identify tables.Methods in org.apache.accumulo.core.spi.balancer with parameters of type TableId Modifier and Type Method Description protected TabletBalancer
TableLoadBalancer. getBalancerForTable(TableId tableId)
protected String
TableLoadBalancer. getLoadBalancerClassNameForTable(TableId table)
protected List<TabletStatistics>
HostRegexTableLoadBalancer. getOnlineTabletsForTable(TabletServerId tabletServerId, TableId tableId)
protected List<TabletStatistics>
SimpleLoadBalancer. getOnlineTabletsForTable(TabletServerId tabletServerId, TableId tableId)
boolean
BalancerEnvironment. isTableOnline(TableId tableId)
Accumulo plugins working with a table may need to know if the table is online or not before operating on it.List<TabletStatistics>
BalancerEnvironment. listOnlineTabletsForTable(TabletServerId tabletServerId, TableId tableId)
Fetch the tablets for the given table by asking the tablet server.Map<TabletId,TabletServerId>
BalancerEnvironment. listTabletLocations(TableId tableId)
Fetch the locations for each oftableId
's tablets from the metadata table.String
BalancerEnvironment. tableContext(TableId tableId)
Retrieve the classloader context that is configured fortableId
, ornull
if none is configured.Constructors in org.apache.accumulo.core.spi.balancer with parameters of type TableId Constructor Description GroupBalancer(TableId tableId)
RegexGroupBalancer(TableId tableId)
SimpleLoadBalancer(TableId table)
-
Uses of TableId in org.apache.accumulo.core.spi.common
Methods in org.apache.accumulo.core.spi.common with parameters of type TableId Modifier and Type Method Description ServiceEnvironment.Configuration
ServiceEnvironment. getConfiguration(TableId tableId)
-
Uses of TableId in org.apache.accumulo.core.spi.compaction
Methods in org.apache.accumulo.core.spi.compaction that return TableId Modifier and Type Method Description TableId
CompactionDispatcher.InitParameters. getTableId()
TableId
CompactionPlanner.PlanningParameters. getTableId()
-
Uses of TableId in org.apache.accumulo.core.spi.crypto
Methods in org.apache.accumulo.core.spi.crypto that return types with arguments of type TableId Modifier and Type Method Description Optional<TableId>
CryptoEnvironment. getTableId()
If in the TABLE scope, get the tableId. -
Uses of TableId in org.apache.accumulo.core.spi.fs
Methods in org.apache.accumulo.core.spi.fs that return types with arguments of type TableId Modifier and Type Method Description Optional<TableId>
VolumeChooserEnvironment. getTable()
-
Uses of TableId in org.apache.accumulo.core.spi.scan
Methods in org.apache.accumulo.core.spi.scan that return TableId Modifier and Type Method Description TableId
ScanDispatcher.InitParameters. getTableId()
TableId
ScanInfo. getTableId()
-
Uses of TableId in org.apache.accumulo.core.util
Fields in org.apache.accumulo.core.util with type parameters of type TableId Modifier and Type Field Description static Validator<TableId>
Validators. CAN_CLONE_TABLE
static Validator<TableId>
Validators. NOT_ROOT_TABLE_ID
static Validator<TableId>
Validators. VALID_TABLE_ID
Methods in org.apache.accumulo.core.util that return TableId Modifier and Type Method Description static TableId
ByteBufferUtil. toTableId(ByteBuffer bytes)
Methods in org.apache.accumulo.core.util with parameters of type TableId Modifier and Type Method Description static Map<String,Set<ByteSequence>>
LocalityGroupUtil. getLocalityGroupsIgnoringErrors(AccumuloConfiguration acuconf, TableId tableId)
-
Uses of TableId in org.apache.accumulo.core.util.tables
Methods in org.apache.accumulo.core.util.tables that return TableId Modifier and Type Method Description TableId
TableZooHelper. _getTableIdDetectNamespaceNotFound(String tableName)
Lookup table ID in ZK.TableId
TableZooHelper. getTableId(String tableName)
Lookup table ID in ZK.Methods in org.apache.accumulo.core.util.tables that return types with arguments of type TableId Modifier and Type Method Description Map<TableId,String>
TableMap. getIdtoNameMap()
Map<String,TableId>
TableMap. getNameToIdMap()
Methods in org.apache.accumulo.core.util.tables with parameters of type TableId Modifier and Type Method Description NamespaceId
TableZooHelper. getNamespaceId(TableId tableId)
Returns the namespace id for a given table ID.String
TableZooHelper. getPrintableTableInfoFromId(TableId tableId)
String
TableZooHelper. getTableName(TableId tableId)
TableState
TableZooHelper. getTableState(TableId tableId, boolean clearCachedState)
Get the current state of the table using the tableid.boolean
TableZooHelper. tableNodeExists(TableId tableId)
-