Uses of Interface
org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Packages that use org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
Package
Description
Provides HBase Client
Provides implementations of
HFile and HFile
BlockCache.-
Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase
Classes in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.HColumnDescriptorDeprecated.Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.ColumnFamilyDescriptorHTableDescriptor.getColumnFamily(byte[] name) Deprecated.Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.HColumnDescriptorHTableDescriptor.toHColumnDescriptor(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc) Deprecated.Return a HColumnDescriptor for user to keep the compatibility as much as possible. -
Uses of org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeClassDescriptionstatic classorg.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptorAn ModifyableFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.classorg.apache.hadoop.hbase.client.ImmutableHColumnDescriptorDeprecated.Fields in org.apache.hadoop.hbase.client with type parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeFieldDescriptionstatic final Comparator<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor>ColumnFamilyDescriptor.COMPARATORstatic final Comparator<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor>ColumnFamilyDescriptor.COMPARATOR_IGNORE_REPLICATIONMethods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.build()static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.copy(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc) org.apache.hadoop.hbase.client.ColumnFamilyDescriptor[]TableDescriptor.getColumnFamilies()Returns an unmodifiable collection of all theColumnFamilyDescriptorof all the column families of the table.org.apache.hadoop.hbase.client.ColumnFamilyDescriptor[]TableDescriptorBuilder.ModifyableTableDescriptor.getColumnFamilies()org.apache.hadoop.hbase.client.ColumnFamilyDescriptorTableDescriptor.getColumnFamily(byte[] name) Returns the ColumnDescriptor for a specific column family with name as specified by the parameter column.org.apache.hadoop.hbase.client.ColumnFamilyDescriptorTableDescriptorBuilder.ModifyableTableDescriptor.getColumnFamily(byte[] column) Returns the ColumnFamilyDescriptor for a specific column family with name as specified by the parameter column.static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.of(byte[] name) static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.of(String name) static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.parseFrom(byte[] pbBytes) org.apache.hadoop.hbase.client.ColumnFamilyDescriptorTableDescriptorBuilder.ModifyableTableDescriptor.removeColumnFamily(byte[] column) Removes the ColumnFamilyDescriptor with name specified by the parameter column from the table descriptorMethods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeMethodDescriptiondefault voidAdmin.addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Deprecated.As of release 2.0.0.default voidAdmin.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.org.apache.hadoop.hbase.client.TableDescriptorBuilderTableDescriptorBuilder.addColumnFamily(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Admin.addColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Add a column family to an existing table.HBaseAdmin.addColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.copy(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc) default voidAdmin.modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) Deprecated.As of release 2.0.0.default voidAdmin.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.ModifyableTableDescriptorTableDescriptorBuilder.ModifyableTableDescriptor.modifyColumnFamily(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family) Modifies the existing column family.org.apache.hadoop.hbase.client.TableDescriptorBuilderTableDescriptorBuilder.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.HBaseAdmin.modifyColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilderColumnFamilyDescriptorBuilder.newBuilder(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc) org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptorTableDescriptorBuilder.ModifyableTableDescriptor.setColumnFamily(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family) Adds a column family.org.apache.hadoop.hbase.client.TableDescriptorBuilderTableDescriptorBuilder.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.protected org.apache.hadoop.hbase.HColumnDescriptorImmutableHTableDescriptor.toHColumnDescriptor(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc) Deprecated.Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeMethodDescriptionstatic Comparator<org.apache.hadoop.hbase.client.TableDescriptor>TableDescriptor.getComparator(Comparator<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor> cfComparator) org.apache.hadoop.hbase.client.TableDescriptorBuilderTableDescriptorBuilder.setColumnFamilies(Collection<org.apache.hadoop.hbase.client.ColumnFamilyDescriptor> families) Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifierConstructorDescriptionImmutableHColumnDescriptor(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc) Deprecated.ModifyableColumnFamilyDescriptor(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor desc) Constructor. -
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 inModifierConstructorDescriptionCacheConfig(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 inModifier and TypeMethodDescriptionlongHMaster.addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce) longMasterServices.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 tablelongHMaster.modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce) longMasterServices.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 inModifier and TypeMethodDescriptionstatic 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 inModifier and TypeMethodDescriptionvoidExpiredMobFileCleaner.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 voidMobUtils.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.StoreFileWriterMobUtils.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.StoreFileWriterMobUtils.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.StoreFileWriterMobUtils.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.StoreFileWriterMobUtils.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 booleanMobUtils.isMobFileExpired(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long current, String fileDate) Checks if the mob file is expired.voidMobFileCompactionChore.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 inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.ColumnFamilyDescriptorHStore.getColumnFamilyDescriptor()org.apache.hadoop.hbase.client.ColumnFamilyDescriptorStore.getColumnFamilyDescriptor()org.apache.hadoop.hbase.client.ColumnFamilyDescriptorStoreContext.getFamily()Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.io.hfile.CacheConfigHStore.createCacheConf(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family) Creates the cache config.static org.apache.hadoop.conf.ConfigurationStoreUtils.createStoreConfiguration(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.TableDescriptor td, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor cfd) static longHStore.determineTTLFromFamily(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family) Returns TTL in seconds of the specified familyprotected org.apache.hadoop.hbase.regionserver.HStoreHRegion.instantiateHStore(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, boolean warmup) org.apache.hadoop.hbase.regionserver.StoreContext.BuilderStoreContext.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 inModifierConstructorDescriptionHMobStore(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.conf.Configuration confParam, boolean warmup) protectedHStore(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.conf.Configuration confParam, boolean warmup) ConstructorScanInfo(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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerStoreFileTrackerFactory.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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.io.crypto.Encryption.ContextEncryptionUtil.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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.ColumnFamilyDescriptorProtobufUtil.toColumnFamilyDescriptor(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.ColumnFamilySchema cfs) Converts a ColumnFamilySchema to ColumnFamilyDescriptorMethods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequestRequestConverter.buildAddColumnRequest(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce) Create a protocol buffer AddColumnRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequestRequestConverter.buildModifyColumnRequest(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor column, long nonceGroup, long nonce) Create a protocol buffer ModifyColumnRequeststatic org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.ColumnFamilySchemaProtobufUtil.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.util
Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.client.ColumnFamilyDescriptor in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.ColumnFamilyDescriptorFSTableDescriptors.getReplBarrierFamilyDescForMeta()static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorFSTableDescriptors.getTableFamilyDescForMeta(org.apache.hadoop.conf.Configuration conf)