Uses of Interface
org.apache.hadoop.hbase.client.ColumnFamilyDescriptor

Packages that use org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase

    Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor>
    HBaseTestingUtility.generateColumnDescriptors()
    Deprecated.
    Create a set of column descriptors with the combination of compression, encoding, bloom codecs available.
    static List<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor>
    HBaseTestingUtility.generateColumnDescriptors(String prefix)
    Deprecated.
    Create a set of column descriptors with the combination of compression, encoding, bloom codecs available.
    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static int
    HBaseTestingUtility.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.TableDescriptor desc, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor hcd)
    Deprecated.
    Creates a pre-split table for load testing.
    static int
    HBaseTestingUtility.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.TableDescriptor desc, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor[] hcds, int numRegionsPerServer)
    Deprecated.
    Creates a pre-split table for load testing.
    static int
    HBaseTestingUtility.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.TableDescriptor td, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor[] cds, org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm splitter, int numRegionsPerServer)
    Deprecated.
    Creates a pre-split table for load testing.
    static int
    HBaseTestingUtility.createPreSplitLoadTestTable(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.TableDescriptor desc, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor hcd, int numRegionsPerServer)
    Deprecated.
    Creates a pre-split table for load testing.
    org.apache.hadoop.hbase.regionserver.HRegion
    HBaseTestingUtility.createTestRegion(String tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor cd)
    Deprecated.
     
    org.apache.hadoop.hbase.regionserver.HRegion
    HBaseTestingUtility.createTestRegion(String tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor cd, org.apache.hadoop.hbase.io.hfile.BlockCache blockCache)
    Deprecated.
     
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.client

    Fields in org.apache.hadoop.hbase.client with type parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Field
    Description
    static final Comparator<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor>
    ColumnFamilyDescriptor.COMPARATOR
     
    static final Comparator<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor>
    ColumnFamilyDescriptor.COMPARATOR_IGNORE_REPLICATION
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    ColumnFamilyDescriptorBuilder.build()
     
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    ColumnFamilyDescriptorBuilder.copy(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc)
     
    org.apache.hadoop.hbase.client.ColumnFamilyDescriptor[]
    TableDescriptor.getColumnFamilies()
    Returns an unmodifiable collection of all the ColumnFamilyDescriptor of all the column families of the table.
    org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    TableDescriptor.getColumnFamily(byte[] name)
    Returns the ColumnDescriptor for a specific column family with name as specified by the parameter column.
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    ColumnFamilyDescriptorBuilder.of(byte[] name)
     
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    ColumnFamilyDescriptorBuilder.of(String name)
     
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    ColumnFamilyDescriptorBuilder.parseFrom(byte[] pbBytes)
     
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    default void
    Admin.addColumnFamily(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Add a column family to an existing table.
    AsyncAdmin.addColumnFamily(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Add a column family to an existing table.
    Admin.addColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Add a column family to an existing table.
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    ColumnFamilyDescriptorBuilder.copy(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc)
     
    default void
    Admin.modifyColumnFamily(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Modify an existing column family on a table.
    AsyncAdmin.modifyColumnFamily(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Modify an existing column family on a table.
    org.apache.hadoop.hbase.client.TableDescriptorBuilder
    TableDescriptorBuilder.modifyColumnFamily(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family)
     
    Admin.modifyColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily)
    Modify an existing column family on a table.
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
    ColumnFamilyDescriptorBuilder.newBuilder(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc)
     
    org.apache.hadoop.hbase.client.TableDescriptorBuilder
    TableDescriptorBuilder.setColumnFamily(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family)
     
    static byte[]
    ColumnFamilyDescriptorBuilder.toByteArray(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc)
    Serialize the table descriptor to a byte array.
    Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static Comparator<org.apache.hadoop.hbase.client.TableDescriptor>
    TableDescriptor.getComparator(Comparator<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor> cfComparator)
     
    org.apache.hadoop.hbase.client.TableDescriptorBuilder
    TableDescriptorBuilder.setColumnFamilies(Collection<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor> families)
     
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.io.hfile

    Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier
    Constructor
    Description
     
    CacheConfig(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.hbase.io.hfile.BlockCache blockCache, org.apache.hadoop.hbase.io.ByteBuffAllocator byteBuffAllocator)
    Create a cache configuration using the specified configuration object and family descriptor.
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.master

    Methods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    long
    HMaster.addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce)
     
    long
    MasterServices.addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce)
    Add a new column to an existing table
    long
    HMaster.modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce)
     
    long
    MasterServices.modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce)
    Modify the column descriptor of an existing column in an existing table
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.mob

    Methods in org.apache.hadoop.hbase.mob that return types with arguments of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor>
    MobUtils.getMobColumnFamilies(org.apache.hadoop.hbase.client.TableDescriptor htd)
    Get list of Mob column families (if any exists)
    Methods in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    void
    ExpiredMobFileCleaner.cleanExpiredMobFiles(String tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family)
    Cleans the MOB files when they're expired and their min versions are 0.
    static void
    MobUtils.cleanExpiredMobFiles(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnDescriptor, org.apache.hadoop.hbase.io.hfile.CacheConfig cacheConfig, long current)
    Cleans the expired mob files.
    static org.apache.hadoop.hbase.regionserver.StoreFileWriter
    MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, String date, org.apache.hadoop.fs.Path basePath, long maxKeyCount, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, String startKey, org.apache.hadoop.hbase.io.hfile.CacheConfig cacheConfig, org.apache.hadoop.hbase.io.crypto.Encryption.Context cryptoContext, boolean isCompaction, String regionName)
    Creates a writer for the mob file in temp directory.
    static org.apache.hadoop.hbase.regionserver.StoreFileWriter
    MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.fs.Path path, long maxKeyCount, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.hfile.CacheConfig cacheConfig, org.apache.hadoop.hbase.io.crypto.Encryption.Context cryptoContext, org.apache.hadoop.hbase.util.ChecksumType checksumType, int bytesPerChecksum, int blocksize, org.apache.hadoop.hbase.regionserver.BloomType bloomType, boolean isCompaction)
    Creates a writer for the mob file in temp directory.
    static org.apache.hadoop.hbase.regionserver.StoreFileWriter
    MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.fs.Path path, long maxKeyCount, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.hfile.CacheConfig cacheConfig, org.apache.hadoop.hbase.io.crypto.Encryption.Context cryptoContext, org.apache.hadoop.hbase.util.ChecksumType checksumType, int bytesPerChecksum, int blocksize, org.apache.hadoop.hbase.regionserver.BloomType bloomType, boolean isCompaction, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
    Creates a writer for the mob file in temp directory.
    static org.apache.hadoop.hbase.regionserver.StoreFileWriter
    MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.hbase.mob.MobFileName mobFileName, org.apache.hadoop.fs.Path basePath, long maxKeyCount, org.apache.hadoop.hbase.io.compress.Compression.Algorithm compression, org.apache.hadoop.hbase.io.hfile.CacheConfig cacheConfig, org.apache.hadoop.hbase.io.crypto.Encryption.Context cryptoContext, boolean isCompaction)
    Creates a writer for the mob file in temp directory.
    static boolean
    MobUtils.isMobFileExpired(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long current, String fileDate)
    Checks if the mob file is expired.
    void
    MobFileCompactionChore.performMajorCompactionInBatches(org.apache.hadoop.hbase.client.Admin admin, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor hcd)
     
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    HStore.getColumnFamilyDescriptor()
     
    org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    Store.getColumnFamilyDescriptor()
     
    org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    StoreContext.getFamily()
     
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.io.hfile.CacheConfig
    HStore.createCacheConf(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family)
    Creates the cache config.
    static org.apache.hadoop.conf.Configuration
    StoreUtils.createStoreConfiguration(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.TableDescriptor td, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor cfd)
     
    static long
    HStore.determineTTLFromFamily(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family)
    Returns TTL in seconds of the specified family
    protected org.apache.hadoop.hbase.regionserver.HStore
    HRegion.instantiateHStore(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, boolean warmup)
     
    org.apache.hadoop.hbase.regionserver.StoreContext.Builder
    StoreContext.Builder.withColumnFamilyDescriptor(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family)
     
    Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier
    Constructor
    Description
     
    HMobStore(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.conf.Configuration confParam, boolean warmup)
     
    protected
    HStore(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.conf.Configuration confParam, boolean warmup)
    Constructor
     
    ScanInfo(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, long ttl, long timeToPurgeDeletes, CellComparator comparator)
     
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.regionserver.storefiletracker

    Methods in org.apache.hadoop.hbase.regionserver.storefiletracker with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
    StoreFileTrackerFactory.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.TableDescriptor td, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor cfd, org.apache.hadoop.hbase.regionserver.HRegionFileSystem regionFs)
    Used at master side when splitting/merging regions, as we do not have a Store, thus no StoreContext at master side.
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.security

    Methods in org.apache.hadoop.hbase.security with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.io.crypto.Encryption.Context
    EncryptionUtil.createEncryptionContext(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family)
    Helper to create an encyption context.
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.shaded.protobuf

    Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    ProtobufUtil.toColumnFamilyDescriptor(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.ColumnFamilySchema cfs)
    Converts a ColumnFamilySchema to ColumnFamilyDescriptor
    Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequest
    RequestConverter.buildAddColumnRequest(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce)
    Create a protocol buffer AddColumnRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequest
    RequestConverter.buildModifyColumnRequest(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce)
    Create a protocol buffer ModifyColumnRequest
    static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.ColumnFamilySchema
    ProtobufUtil.toColumnFamilySchema(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor hcd)
    Converts an ColumnFamilyDescriptor to ColumnFamilySchema
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.thrift

    Methods in org.apache.hadoop.hbase.thrift that return org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    ThriftUtilities.colDescFromThrift(org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor in)
    This utility method creates a new Hbase HColumnDescriptor object based on a Thrift ColumnDescriptor "struct".
    Methods in org.apache.hadoop.hbase.thrift with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
    ThriftUtilities.colDescFromHbase(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in)
    This utility method creates a new Thrift ColumnDescriptor "struct" based on an Hbase HColumnDescriptor object.
  • Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.util

    Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    FSTableDescriptors.getNamespaceFamilyDescForMeta(org.apache.hadoop.conf.Configuration conf)
     
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    FSTableDescriptors.getReplBarrierFamilyDescForMeta()
     
    static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
    FSTableDescriptors.getTableFamilyDescForMeta(org.apache.hadoop.conf.Configuration conf)