Uses of Interface
org.apache.hadoop.hbase.Cell
Packages that use org.apache.hadoop.hbase.Cell
Package
Description
Provides HBase Client
Table of Contents
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next().Provides implementations of
HFile and HFile
BlockCache.Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
-
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase
Subinterfaces of org.apache.hadoop.hbase.Cell in in org.apache.hadoop.hbaseModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.ExtendedCellExtension toCellwith server side required functions.interfaceorg.apache.hadoop.hbase.RawCellAn extended version of Cell that allows CPs manipulate Tags.Classes in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.Cell in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.ByteBufferExtendedCellThis class is a server side extension to theCellinterface.classorg.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValueThis is a key only Cell implementation which is identical toKeyValue.KeyOnlyKeyValuewith respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).classorg.apache.hadoop.hbase.ByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.IndividualBytesFieldCellclassorg.apache.hadoop.hbase.KeyValueAn HBase Key/Value.static classorg.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValueA simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.classorg.apache.hadoop.hbase.NoTagsByteBufferKeyValueAn extension of the ByteBufferKeyValue where the tags length is always 0classorg.apache.hadoop.hbase.NoTagsKeyValueAn extension of the KeyValue where the tags length is always 0classorg.apache.hadoop.hbase.SizeCachedByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.SizeCachedKeyValueThis class is an extension to KeyValue where rowLen and keyLen are cached.classorg.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.SizeCachedNoTagsKeyValueThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellCellBuilder.build()static org.apache.hadoop.hbase.CellCellUtil.cloneIfNecessary(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.CellRawCell.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags) Returns A new cell which is having the extra tags also added to it.org.apache.hadoop.hbase.CellCellScanner.current()Returns the current Cell which may be mutableMethods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.Cell>HBaseTestingUtility.getFromStoreFile(org.apache.hadoop.hbase.regionserver.HStore store, byte[] row, NavigableSet<byte[]> columns) Deprecated.Do a small get/scan against one store.static List<org.apache.hadoop.hbase.Cell>HBaseTestingUtility.getFromStoreFile(org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.client.Get get) Deprecated.Do a small get/scan against one store.Comparator<org.apache.hadoop.hbase.Cell>CellComparator.getSimpleComparator()Return a dumbed-down, fast comparator for hbase2 base-type, theByteBufferKeyValue.Comparator<org.apache.hadoop.hbase.Cell>CellComparatorImpl.getSimpleComparator()Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic voidPerformanceEvaluationCommons.assertKey(byte[] expected, org.apache.hadoop.hbase.Cell c) static byte[]CellUtil.cloneFamily(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.CellCellUtil.cloneIfNecessary(org.apache.hadoop.hbase.Cell cell) static byte[]CellUtil.cloneQualifier(org.apache.hadoop.hbase.Cell cell) static byte[]CellUtil.cloneRow(org.apache.hadoop.hbase.Cell cell) get individual arrays for testsstatic byte[]CellUtil.cloneValue(org.apache.hadoop.hbase.Cell cell) intCellComparator.compare(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexographically compares two cells.intCellComparator.compare(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell, boolean ignoreSequenceid) Compare cells.final intCellComparatorImpl.compare(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) intCellComparatorImpl.compare(org.apache.hadoop.hbase.Cell l, org.apache.hadoop.hbase.Cell r, boolean ignoreSequenceid) intMetaCellComparator.compare(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b, boolean ignoreSequenceid) final intCellComparatorImpl.compareColumns(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the family and qualifier part of the cellstatic final intCellUtil.compareColumns(org.apache.hadoop.hbase.Cell left, byte[] right, int rfoffset, int rflength, int rqoffset, int rqlength) Compares the cell's column (family and qualifier) with the given byte[]intCellComparator.compareFamilies(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the families of the two cellsprotected intCellComparatorImpl.compareFamilies(org.apache.hadoop.hbase.Cell left, int leftFamLen, org.apache.hadoop.hbase.Cell right, int rightFamLen) This method will be overridden when we compare cells inner store to bypass family comparing.final intCellComparatorImpl.compareFamilies(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compare the families of left and right cellstatic final intCellUtil.compareFamilies(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength) Compares the cell's family with the given byte[]protected intInnerStoreCellComparator.compareFamilies(org.apache.hadoop.hbase.Cell left, int leftFamilyLength, org.apache.hadoop.hbase.Cell right, int rightFamilyLength) static intPrivateCellUtil.compareFamily(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's column family against given comparatorstatic final intPrivateCellUtil.compareKeyIgnoresMvcc(CellComparator comparator, org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares only the key portion of a cell.static intPrivateCellUtil.compareQualifier(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's qualifier against given comparatorintCellComparator.compareQualifiers(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the qualifiers of the two cellsfinal intCellComparatorImpl.compareQualifiers(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compare the qualifiers part of the left and right cells.static final intCellUtil.compareQualifiers(org.apache.hadoop.hbase.Cell left, byte[] right, int rOffset, int rLength) Compares the cell's qualifier with the given byte[]static intPrivateCellUtil.compareRow(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's row against given comparatordefault intCellComparator.compareRows(ByteBuffer row, org.apache.hadoop.hbase.Cell cell) Lexicographically compare two rowsintCellComparator.compareRows(org.apache.hadoop.hbase.Cell cell, byte[] bytes, int offset, int length) Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.intCellComparator.compareRows(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexographically compares the rows of two cells.intCellComparatorImpl.compareRows(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength) Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.intCellComparatorImpl.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the rows of the left and right cell.intMetaCellComparator.compareRows(ByteBuffer row, org.apache.hadoop.hbase.Cell cell) intMetaCellComparator.compareRows(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength) intMetaCellComparator.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intCellComparator.compareTimestamps(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Compares cell's timestamps in DESCENDING order.intCellComparatorImpl.compareTimestamps(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static intPrivateCellUtil.compareValue(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's value against given comparatorintCellComparator.compareWithoutRow(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the two cells excluding the row part.final intCellComparatorImpl.compareWithoutRow(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static voidPrivateCellUtil.compressFamily(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static voidPrivateCellUtil.compressQualifier(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static voidPrivateCellUtil.compressRow(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static intCellUtil.copyFamilyTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the family to the given byte[]static intCellUtil.copyFamilyTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the family to the given bytebufferstatic intCellUtil.copyQualifierTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the qualifier to the given byte[]static intCellUtil.copyQualifierTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the qualifier to the given bytebufferstatic byte[]CellUtil.copyRow(org.apache.hadoop.hbase.Cell cell) Copies the row to a new byte[]static intCellUtil.copyRowTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the row to the given byte[]static intCellUtil.copyRowTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the row to the given bytebufferstatic intCellUtil.copyValueTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the value to the given byte[]static intCellUtil.copyValueTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the value to the given bytebufferstatic org.apache.hadoop.hbase.CellRawCell.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags) Returns A new cell which is having the extra tags also added to it.static org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(org.apache.hadoop.hbase.Cell[] cellArray) Returns CellScanner interface overcellArraystatic org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.createFirstOnNextRow(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.createFirstOnRow(org.apache.hadoop.hbase.Cell cell) Create a Cell that is smaller than all other possible Cells for the given Cell's row.static org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.createFirstOnRowCol(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.createFirstOnRowCol(org.apache.hadoop.hbase.Cell cell, byte[] qArray, int qoffest, int qlength) Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and passed qualifier.static org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.createFirstOnRowColTS(org.apache.hadoop.hbase.Cell cell, long ts) Creates the first cell with the row/family/qualifier of this cell and the given timestamp.static org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.createFirstOnRowFamily(org.apache.hadoop.hbase.Cell cell, byte[] fArray, int foff, int flen) static org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.createLastOnRow(org.apache.hadoop.hbase.Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's row.static org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.createLastOnRowCol(org.apache.hadoop.hbase.Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.static org.apache.hadoop.hbase.ExtendedCellPrivateCellUtil.ensureExtendedCell(org.apache.hadoop.hbase.Cell cell) In fact, in HBase, allCells areExtendedCells.static booleanCellUtil.equals(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) equalsstatic intPrivateCellUtil.estimatedSerializedSizeOf(org.apache.hadoop.hbase.Cell cell) Estimate based on keyvalue's serialization format in the RPC layer.static intPrivateCellUtil.estimatedSerializedSizeOfKey(org.apache.hadoop.hbase.Cell cell) Calculates the serialized key size.static org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillFamilyRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillQualifierRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillRowRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) ByteRangestatic org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillValueRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static StringCellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell) Returns The Key portion of the passedcellas a String.static StringCellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell, Function<org.apache.hadoop.hbase.Cell, String> rowConverter) Return the Key portion of the passedcellas a String.static List<org.apache.hadoop.hbase.client.RegionInfo>CatalogFamilyFormat.getMergeRegions(org.apache.hadoop.hbase.Cell[] cells) Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array ofcells.CatalogFamilyFormat.getMergeRegionsWithName(org.apache.hadoop.hbase.Cell[] cells) Returns Deserialized values of <qualifier,regioninfo> pairs taken from column values that match the regex 'info:merge.*' in array ofcells.static bytePrivateCellUtil.getQualifierByte(org.apache.hadoop.hbase.Cell cell, int index) static intPrivateCellUtil.getRowAsInt(org.apache.hadoop.hbase.Cell cell) Converts the rowkey bytes of the given cell into an int valuestatic bytePrivateCellUtil.getRowByte(org.apache.hadoop.hbase.Cell cell, int index) miscstatic longPrivateCellUtil.getSequenceId(org.apache.hadoop.hbase.Cell c) static bytePrivateCellUtil.getTypeByte(org.apache.hadoop.hbase.Cell c) static BigDecimalPrivateCellUtil.getValueAsBigDecimal(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a BigDecimalstatic doublePrivateCellUtil.getValueAsDouble(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a double valuestatic intPrivateCellUtil.getValueAsInt(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a int valuestatic longPrivateCellUtil.getValueAsLong(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a long valuestatic ByteBufferPrivateCellUtil.getValueBufferShallowCopy(org.apache.hadoop.hbase.Cell cell) static booleanCatalogFamilyFormat.hasMergeRegions(org.apache.hadoop.hbase.Cell[] cells) Returns True if any merge regions present incells; i.e.static booleanCellUtil.isDelete(org.apache.hadoop.hbase.Cell cell) Return true if a delete type, aKeyValue.Type.Deleteor a {KeyValue.Type#DeleteFamily} or aKeyValue.Type.DeleteColumnKeyValue type.static booleanCatalogFamilyFormat.isMergeQualifierPrefix(org.apache.hadoop.hbase.Cell cell) Returns True if the column incellmatches the regex 'info:merge.*'.static booleanCellUtil.isPut(org.apache.hadoop.hbase.Cell cell) Returns True if this cell is a Put.static intKeyValueUtil.keyLength(org.apache.hadoop.hbase.Cell cell) Returns number of bytes this cell's key part would have been used if serialized as inKeyValue.static booleanCellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, byte[] fam, byte[] qual) static booleanCellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanPrivateCellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, byte[] fam, int foffset, int flength, byte[] qual, int qoffset, int qlength) static booleanCellUtil.matchingColumnFamilyAndQualifierPrefix(org.apache.hadoop.hbase.Cell left, byte[] fam, byte[] qual) Returns True if matching column family and the qualifier starts withqualstatic booleanCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte[] buf) static booleanCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte lfamlength, org.apache.hadoop.hbase.Cell right, byte rfamlength) static booleanCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanPrivateCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) static booleanCellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, byte[] buf) Finds if the qualifier part of the cell and the KV serialized byte[] are equal.static booleanCellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanPrivateCellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) Finds if the qualifier part of the cell and the KV serialized byte[] are equalstatic booleanCellUtil.matchingRow(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) static booleanCellUtil.matchingRowColumn(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row and column of two keyvalues for equalitystatic booleanCellUtil.matchingRowColumnBytes(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row and column of two keyvalues for equalitystatic booleanCellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, byte[] buf) static booleanCellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, short lrowlength, org.apache.hadoop.hbase.Cell right, short rrowlength) Compares the row of two keyvalues for equalitystatic booleanCellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row of two keyvalues for equalitystatic booleanPrivateCellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) static booleanCellUtil.matchingTags(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.Since 3.0.0, will be removed in 4.0.0.static booleanCellUtil.matchingTimestamp(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) static booleanCellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, byte[] buf) static booleanCellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanCellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right, int lvlength, int rvlength) static booleanPrivateCellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right, int lvlength, int rvlength) static booleanPrivateCellUtil.qualifierStartsWith(org.apache.hadoop.hbase.Cell left, byte[] startsWith) Finds if the start of the qualifier part of the Cell matchesbufstatic voidPrivateCellUtil.setSequenceId(org.apache.hadoop.hbase.Cell cell, long seqId) Sets the given seqId to the cell.static voidCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, byte[] ts, int tsOffset) Sets the given timestamp to the cell.static voidCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, long ts) Sets the given timestamp to the cell.static voidPrivateCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, byte[] ts) Sets the given timestamp to the cell.static voidPrivateCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, long ts) Sets the given timestamp to the cell.static StringCellUtil.toString(org.apache.hadoop.hbase.Cell cell, boolean verbose) Returns a string representation of the cellstatic booleanPrivateCellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, byte[] ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP.static voidPrivateCellUtil.writeFamily(OutputStream out, org.apache.hadoop.hbase.Cell cell, byte flength) Writes the family from the given cell to the output streamstatic voidPrivateCellUtil.writeQualifier(OutputStream out, org.apache.hadoop.hbase.Cell cell, int qlength) Writes the qualifier from the given cell to the output streamstatic voidPrivateCellUtil.writeQualifierSkippingBytes(DataOutputStream out, org.apache.hadoop.hbase.Cell cell, int qlength, int commonPrefix) Writes the qualifier from the given cell to the output stream excluding the common prefixstatic voidPrivateCellUtil.writeRow(OutputStream out, org.apache.hadoop.hbase.Cell cell, short rlength) Writes the row from the given cell to the output streamstatic voidPrivateCellUtil.writeRowKeyExcludingCommon(org.apache.hadoop.hbase.Cell cell, short rLen, int commonPrefix, DataOutputStream out) Write rowkey excluding the common part.static voidPrivateCellUtil.writeRowSkippingBytes(DataOutputStream out, org.apache.hadoop.hbase.Cell cell, short rlength, int commonPrefix) Writes the row from the given cell to the output stream excluding the common prefixMethod parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic voidHBaseTestingUtility.assertKVListsEqual(String additionalMsg, List<? extends org.apache.hadoop.hbase.Cell> expected, List<? extends org.apache.hadoop.hbase.Cell> actual) Deprecated.static voidCellUtil.cloneIfNecessary(ArrayList<org.apache.hadoop.hbase.Cell> cells) static booleanKeyValueTestUtil.containsIgnoreMvccVersion(Collection<? extends org.apache.hadoop.hbase.Cell> kvCollection1, Collection<? extends org.apache.hadoop.hbase.Cell> kvCollection2) Checks whether KeyValues from kvCollection2 are contained in kvCollection1.static org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(Iterable<org.apache.hadoop.hbase.Cell> cellIterable) Returns CellScanner interface overcellIterablestatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(Iterator<org.apache.hadoop.hbase.Cell> cells) Returns CellScanner interface overcellIterableor null ifcellsis nullstatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Flatten the map of cells out under the CellScannerstatic StringCellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell, Function<org.apache.hadoop.hbase.Cell, String> rowConverter) Return the Key portion of the passedcellas a String. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellResult.getColumnLatestCell(byte[] family, byte[] qualifier) The Cell for the most recent timestamp for a given column.org.apache.hadoop.hbase.CellResult.getColumnLatestCell(byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength) The Cell for the most recent timestamp for a given column.org.apache.hadoop.hbase.Cell[]Result.rawCells()Return the array of Cells backing this Result instance.Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.Cell>Mutation.get(byte[] family, byte[] qualifier) Returns a list of all KeyValue objects with matching column family and qualifier.List<org.apache.hadoop.hbase.Cell>Result.getColumnCells(byte[] family, byte[] qualifier) Return the Cells for the specific column.NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> Mutation.getFamilyCellMap()Method for retrieving the put's familyMapList<org.apache.hadoop.hbase.Cell>Result.listCells()Create a sorted list of the Cell's in this result.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.AppendAppend.add(org.apache.hadoop.hbase.Cell cell) Deprecated.Since 3.0.0, and the method signature will be changed in 4.0.0, where we will throw IOException out when the row of the given cell does not match.org.apache.hadoop.hbase.client.DeleteDelete.add(org.apache.hadoop.hbase.Cell cell) Add an existing delete marker to this Delete object.org.apache.hadoop.hbase.client.IncrementIncrement.add(org.apache.hadoop.hbase.Cell cell) Add the specified KeyValue to this operation.org.apache.hadoop.hbase.client.PutPut.add(org.apache.hadoop.hbase.Cell cell) Add the specified KeyValue to this Put operation.static org.apache.hadoop.hbase.client.ResultResult.create(org.apache.hadoop.hbase.Cell[] cells) Instantiate a Result with the specified array of KeyValues.static org.apache.hadoop.hbase.client.ResultResult.create(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale) static org.apache.hadoop.hbase.client.ResultResult.create(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.ResultResult.create(List<? extends org.apache.hadoop.hbase.Cell> cells) Instantiate a Result with the specified List of KeyValues.static org.apache.hadoop.hbase.client.Resultstatic org.apache.hadoop.hbase.client.Resultstatic org.apache.hadoop.hbase.client.ResultResult.create(List<? extends org.apache.hadoop.hbase.Cell> cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionAppend(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the Append with user defined data.Delete(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the Delete with user defined data.Increment(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the Increment with user defined data.protectedMutation(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the mutation with user defined data.Put(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the Put with user defined data. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptiondefault org.apache.hadoop.hbase.CellRegionObserver.postMutationBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType opType, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell oldCell, org.apache.hadoop.hbase.Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.Methods in org.apache.hadoop.hbase.coprocessor that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptiondefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionabstract TColumnInterpreter.getValue(byte[] colFamily, byte[] colQualifier, org.apache.hadoop.hbase.Cell c) Returns value of type Tdefault org.apache.hadoop.hbase.CellRegionObserver.postMutationBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType opType, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell oldCell, org.apache.hadoop.hbase.Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.default booleanRegionObserver.postScannerFilterRow(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.regionserver.InternalScanner s, org.apache.hadoop.hbase.Cell curRowCell, boolean hasMore) This will be called by the scan flow when the current scanned row is being filtered out by the filter.default voidRegionObserver.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell cell, byte[] byteNow, org.apache.hadoop.hbase.client.Get get) Deprecated.Since hbase-2.0.0.Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptiondefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.default voidRegionObserver.postGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> result) Called after the client performs a Getdefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.default voidRegionObserver.preGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> result) Called before the client performs a Get -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.filter
Fields in org.apache.hadoop.hbase.filter declared as org.apache.hadoop.hbase.Cell in inModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.CellPrefixFilter.forwardNextCellHintprotected org.apache.hadoop.hbase.CellPrefixFilter.reversedNextCellHintMethods in org.apache.hadoop.hbase.filter that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellColumnPaginationFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.CellFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.org.apache.hadoop.hbase.CellFilterBase.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.org.apache.hadoop.hbase.CellFilterList.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterListWithAND.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterListWithOR.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterWrapper.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFuzzyRowFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellMultipleColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellMultiRowRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentKV) org.apache.hadoop.hbase.CellPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellTimestampsFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) Pick the next cell that the scanner should seek to.abstract org.apache.hadoop.hbase.CellFilter.transformCell(org.apache.hadoop.hbase.Cell v) Give the filter a chance to transform the passed Cell.org.apache.hadoop.hbase.CellFilterBase.transformCell(org.apache.hadoop.hbase.Cell v) By default no transformation takes place Give the filter a chance to transform the passed Cell.org.apache.hadoop.hbase.CellFilterList.transformCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.CellFilterListBase.transformCell(org.apache.hadoop.hbase.Cell c) For FilterList, we can consider a filter list as a node in a tree.org.apache.hadoop.hbase.CellFilterWrapper.transformCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellKeyOnlyFilter.transformCell(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellSkipFilter.transformCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellWhileMatchFilter.transformCell(org.apache.hadoop.hbase.Cell v) Methods in org.apache.hadoop.hbase.filter with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected intFilterListBase.compareCell(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) protected booleanCompareFilter.compareFamily(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected booleanCompareFilter.compareQualifier(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected booleanCompareFilter.compareRow(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected booleanCompareFilter.compareValue(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnCountGetFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnPaginationFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnPrefixFilter.filterCell(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnRangeFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnValueFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeDependentColumnFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFamilyFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilter.filterCell(org.apache.hadoop.hbase.Cell c) A way to filter based on the column family, column qualifier and/or the column value.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterAllFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterList.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterListWithAND.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterListWithOR.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterWrapper.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFirstKeyOnlyFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFuzzyRowFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeInclusiveStopFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeKeyOnlyFilter.filterCell(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCodeMultipleColumnPrefixFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeMultiRowRangeFilter.filterCell(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCodePageFilter.filterCell(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCodePrefixFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeQualifierFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeRandomRowFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeRowFilter.filterCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.filter.Filter.ReturnCodeSingleColumnValueFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeSkipFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeTimestampsFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeValueFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeWhileMatchFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnPrefixFilter.filterColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCodeMultipleColumnPrefixFilter.filterColumn(org.apache.hadoop.hbase.Cell cell) booleanColumnCountGetFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanColumnPaginationFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanColumnPrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanColumnRangeFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanColumnValueFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanCompareFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) abstract booleanFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) Filters a row based on the row key.booleanFilterAllFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanFilterBase.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanFilterList.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanFilterListWithAND.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanFilterListWithOR.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanFilterWrapper.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanFirstKeyOnlyFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanInclusiveStopFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanKeyOnlyFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanMultipleColumnPrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanMultiRowRangeFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanPageFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanPrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanRandomRowFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanRowFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanSingleColumnValueFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanSkipFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanTimestampsFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanWhileMatchFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnPaginationFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.CellFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.org.apache.hadoop.hbase.CellFilterBase.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.org.apache.hadoop.hbase.CellFilterList.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterListWithAND.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterListWithOR.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterWrapper.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFuzzyRowFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellMultipleColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellMultiRowRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentKV) org.apache.hadoop.hbase.CellPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellTimestampsFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) Pick the next cell that the scanner should seek to.abstract org.apache.hadoop.hbase.CellFilter.transformCell(org.apache.hadoop.hbase.Cell v) Give the filter a chance to transform the passed Cell.org.apache.hadoop.hbase.CellFilterBase.transformCell(org.apache.hadoop.hbase.Cell v) By default no transformation takes place Give the filter a chance to transform the passed Cell.org.apache.hadoop.hbase.CellFilterList.transformCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.CellFilterListBase.transformCell(org.apache.hadoop.hbase.Cell c) For FilterList, we can consider a filter list as a node in a tree.org.apache.hadoop.hbase.CellFilterWrapper.transformCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellKeyOnlyFilter.transformCell(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellSkipFilter.transformCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellWhileMatchFilter.transformCell(org.apache.hadoop.hbase.Cell v) Method parameters in org.apache.hadoop.hbase.filter with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidDependentColumnFilter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs) abstract voidFilter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs) Chance to alter the list of Cells to be submitted.voidFilterBase.filterRowCells(List<org.apache.hadoop.hbase.Cell> ignored) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.voidFilterList.filterRowCells(List<org.apache.hadoop.hbase.Cell> cells) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.voidFilterListBase.filterRowCells(List<org.apache.hadoop.hbase.Cell> cells) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.voidFilterWrapper.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs) voidSingleColumnValueExcludeFilter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs) org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCodeFilterWrapper.filterRowCellsWithRet(List<org.apache.hadoop.hbase.Cell> kvs) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.io.hfile
Methods in org.apache.hadoop.hbase.io.hfile that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellHFileWriterImpl.getLastCell()org.apache.hadoop.hbase.CellCompoundBloomFilterWriter.getPrevCell()abstract org.apache.hadoop.hbase.CellHFileBlockIndex.BlockIndexReader.midkey(org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) An approximation to theHFile's mid-key.Methods in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected intHFileReaderImpl.HFileScannerImpl.blockSeek(org.apache.hadoop.hbase.Cell key, boolean seekBefore) Within a loaded block, seek looking for the last key that is smaller than (or equal to?) the key we are interested in.protected booleanHFileWriterImpl.checkKey(org.apache.hadoop.hbase.Cell cell) Checks that the given Cell's key does not violate the key order.booleanCompoundBloomFilter.contains(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type) static intHFileBlockIndex.BlockIndexReader.locateNonRootIndexEntry(org.apache.hadoop.hbase.nio.ByteBuff nonRootBlock, org.apache.hadoop.hbase.Cell key, CellComparator comparator) Search for one key using the secondary index in a non-root block.abstract intHFileBlockIndex.BlockIndexReader.rootBlockContainingKey(org.apache.hadoop.hbase.Cell key) Finds the root-level index block containing the given key.intHFileIndexBlockEncoder.EncodedSeeker.rootBlockContainingKey(org.apache.hadoop.hbase.Cell key) intNoOpIndexBlockEncoder.NoOpEncodedSeeker.rootBlockContainingKey(org.apache.hadoop.hbase.Cell key) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.mapreduce
Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellCellCreator.create(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength, long timestamp, byte[] value, int voffset, int vlength) org.apache.hadoop.hbase.CellCellCreator.create(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength, long timestamp, byte[] value, int voffset, int vlength, List<org.apache.hadoop.hbase.Tag> tags) Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.NullWritable,org.apache.hadoop.hbase.Cell> HFileInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.Cell> HFileOutputFormat2.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected voidImport.Importer.addPutToKv(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.Cell kv) org.apache.hadoop.hbase.KeyValueCellSerialization.CellDeserializer.deserialize(org.apache.hadoop.hbase.Cell ignore) protected booleanWALPlayer.WALMapper.filter(org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.wal.WALKey, org.apache.hadoop.hbase.wal.WALEdit, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, org.apache.hadoop.hbase.Cell cell) intImport.CellWritableComparablePartitioner.getPartition(org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable key, org.apache.hadoop.hbase.Cell value, int numPartitions) voidCellSerialization.CellSerializer.serialize(org.apache.hadoop.hbase.Cell kv) Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializerCellSerialization.getDeserializer(Class<org.apache.hadoop.hbase.Cell> t) org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializerCellSerialization.getSerializer(Class<org.apache.hadoop.hbase.Cell> c) protected voidCellSortReducer.reduce(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, Iterable<org.apache.hadoop.hbase.Cell> kvs, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Reducer.Context context) protected voidImport.CellReducer.reduce(org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable row, Iterable<org.apache.hadoop.hbase.Cell> kvs, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable, org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Reducer.Context context) protected voidPreSortedCellsReducer.reduce(org.apache.hadoop.hbase.mapreduce.KeyOnlyCellComparable keyComparable, Iterable<org.apache.hadoop.hbase.Cell> values, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.mapreduce.KeyOnlyCellComparable, org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Reducer.Context context) Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionCellWritableComparable(org.apache.hadoop.hbase.Cell kv) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.mob
Methods in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic StringMobUtils.getMobFileName(org.apache.hadoop.hbase.Cell cell) Gets the mob file name from the mob ref cell.static intMobUtils.getMobValueLength(org.apache.hadoop.hbase.Cell cell) Gets the mob value length from the mob ref cell.static booleanMobUtils.hasValidMobRefCellValue(org.apache.hadoop.hbase.Cell cell) Indicates whether the current mob ref cell has a valid value. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.quotas
Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected static StringQuotaTableUtil.extractSnapshotNameFromSizeCell(org.apache.hadoop.hbase.Cell c) Method parameters in org.apache.hadoop.hbase.quotas with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidDefaultOperationQuota.addScanResultCells(List<org.apache.hadoop.hbase.Cell> cells) voidOperationQuota.addScanResultCells(List<org.apache.hadoop.hbase.Cell> cells) Add a scan result in the form of cells.static longQuotaUtil.calculateCellsSize(List<org.apache.hadoop.hbase.Cell> cells) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver
Classes in org.apache.hadoop.hbase.regionserver with type parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.CellArrayMap<T extends org.apache.hadoop.hbase.Cell>CellArrayMap is a simple array of Cells and cannot be allocated off-heap.classorg.apache.hadoop.hbase.regionserver.CellChunkMap<T extends org.apache.hadoop.hbase.Cell>CellChunkMap is an array of serialized representations of Cell (pointing to Chunks with full Cell data) and can be allocated both off-heap and on-heap.classorg.apache.hadoop.hbase.regionserver.CellFlatMap<T extends org.apache.hadoop.hbase.Cell>CellFlatMap stores a constant number of elements and is immutable after creation stage.classorg.apache.hadoop.hbase.regionserver.CellSet<T extends org.apache.hadoop.hbase.Cell>ASetofCells, where an add will overwrite the entry if already exists in the set.Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.Cell in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offsetclassorg.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offset and with no tagsMethods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellCellSet.get(org.apache.hadoop.hbase.Cell kv) Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.Cell>HRegion.get(org.apache.hadoop.hbase.client.Get get, boolean withCoprocessor) List<org.apache.hadoop.hbase.Cell>Region.get(org.apache.hadoop.hbase.client.Get get, boolean withCoprocessor) Do a get based on the get parameter.List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected booleanCompactingMemStore.checkAndAddToActiveSize(org.apache.hadoop.hbase.regionserver.MutableSegment currActive, org.apache.hadoop.hbase.Cell cellToAdd, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Check whether anything need to be done based on the current active set size.protected voidReversedStoreScanner.checkScanOrder(org.apache.hadoop.hbase.Cell prevKV, org.apache.hadoop.hbase.Cell kv, CellComparator comparator) protected voidStoreScanner.checkScanOrder(org.apache.hadoop.hbase.Cell prevKV, org.apache.hadoop.hbase.Cell kv, CellComparator comparator) Check whether scan as expected orderintCompositeImmutableSegment.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intKeyValueHeap.KVScannerComparator.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares two KeyValueintSegment.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intCompositeImmutableSegment.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intSegment.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) org.apache.hadoop.hbase.CellCellSet.get(org.apache.hadoop.hbase.Cell kv) protected longSegment.heapSizeChange(org.apache.hadoop.hbase.Cell cell, boolean allocated) protected booleanRegionScannerImpl.nextRow(org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext, org.apache.hadoop.hbase.Cell curRowCell) protected longSegment.offHeapSizeChange(org.apache.hadoop.hbase.Cell cell, boolean allocated) booleanRegionCoprocessorHost.postScannerFilterRow(org.apache.hadoop.hbase.regionserver.InternalScanner s, org.apache.hadoop.hbase.Cell curRowCell) This will be called by the scan flow when the current scanned row is being filtered out by the filter.booleanRegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell kv, byte[] byteNow, org.apache.hadoop.hbase.client.Get get) Supports Coprocessor 'bypass'.protected voidStripeMultiFileWriter.sanityCheckLeft(byte[] left, org.apache.hadoop.hbase.Cell cell) Subclasses can call this method to make sure the first KV is within multi-writer range.protected voidStripeMultiFileWriter.sanityCheckRight(byte[] right, org.apache.hadoop.hbase.Cell cell) Subclasses can call this method to make sure the last KV is within multi-writer range.protected booleanRegionScannerImpl.shouldStop(org.apache.hadoop.hbase.Cell currentRowCell) NavigableSet<T>CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, boolean fromInclusive, org.apache.hadoop.hbase.Cell toElement, boolean toInclusive) Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate) Updates the candidate list for finding row key before.Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate) SeeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)andStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)for details on this methods.Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidCheck the collection of families for valid timestampsList<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) voidRegionCoprocessorHost.postGet(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) booleanRegionCoprocessorHost.preGet(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results) Supports Coprocessor 'bypass'.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionCellArrayMap(Comparator<? super T> comparator, T[] b, int min, int max, boolean descending) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.throttle
Method parameters in org.apache.hadoop.hbase.regionserver.throttle with type arguments of type org.apache.hadoop.hbase.Cell in in -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.wal
Method parameters in org.apache.hadoop.hbase.regionserver.wal with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic voidWALUtil.filterCells(org.apache.hadoop.hbase.wal.WALEdit edit, Function<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell> mapper) static voidWALUtil.filterCells(org.apache.hadoop.hbase.wal.WALEdit edit, Function<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell> mapper) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellNamespaceTableCfWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellScopeWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellWALCellFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) Applies the filter, possibly returning a different Cell instance.Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellNamespaceTableCfWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellScopeWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellWALCellFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) Applies the filter, possibly returning a different Cell instance. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.rest
Methods in org.apache.hadoop.hbase.rest that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellRowResultGenerator.next()org.apache.hadoop.hbase.CellScannerResultGenerator.next()Methods in org.apache.hadoop.hbase.rest with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionabstract voidResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv) voidRowResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv) voidScannerResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.shaded.protobuf
Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CursorProtobufUtil.toCursor(org.apache.hadoop.hbase.Cell cell) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.thrift
Methods in org.apache.hadoop.hbase.thrift with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift.generated.TCell>ThriftUtilities.cellFromHBase(org.apache.hadoop.hbase.Cell in) This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell object.static List<org.apache.hadoop.hbase.thrift.generated.TCell>ThriftUtilities.cellFromHBase(org.apache.hadoop.hbase.Cell[] in) This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell array. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.util
Classes in org.apache.hadoop.hbase.util that implement org.apache.hadoop.hbase.Cell in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.util.MapReduceExtendedCellA wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellBloomContext.getLastCell()org.apache.hadoop.hbase.CellBloomFilterWriter.getPrevCell()Returns the previous cell written by this writerMethods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidBloomFilterChunk.add(org.apache.hadoop.hbase.Cell cell) static intBytes.binarySearch(org.apache.hadoop.hbase.Cell[] arr, org.apache.hadoop.hbase.Cell key, CellComparator comparator) Binary search for keys in indexes.booleanBloomFilter.contains(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type) Check if the specified key is contained in the bloom filter.static booleanBloomFilterUtil.contains(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.nio.ByteBuff bloomBuf, int bloomOffset, int bloomSize, org.apache.hadoop.hbase.util.Hash hash, int hashCount, org.apache.hadoop.hbase.regionserver.BloomType type) Constructors in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionCellHashKey(org.apache.hadoop.hbase.Cell cell) RowBloomHashKey(org.apache.hadoop.hbase.Cell cell) RowColBloomHashKey(org.apache.hadoop.hbase.Cell cell) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal that return types with arguments of type org.apache.hadoop.hbase.Cell in inMethods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.wal.WALEditWALEdit.add(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.wal.WALEditWALEdit.add(org.apache.hadoop.hbase.Cell cell, byte[] family) static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptorWALEdit.getBulkLoadDescriptor(org.apache.hadoop.hbase.Cell cell) Deserialized and returns a BulkLoadDescriptor from the passed in Cellstatic org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptorWALEdit.getCompaction(org.apache.hadoop.hbase.Cell kv) Deserialized and returns a CompactionDescriptor is the KeyValue contains one.static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptorWALEdit.getFlushDescriptor(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptorWALEdit.getRegionEventDescriptor(org.apache.hadoop.hbase.Cell cell) static booleanWALEdit.isCompactionMarker(org.apache.hadoop.hbase.Cell cell) Returns true if the given cell is a serializedWALProtos.CompactionDescriptorstatic booleanWALEdit.isMetaEditFamily(org.apache.hadoop.hbase.Cell cell) Replaying WALs can read Cell-at-a-time so need this method in those cases.Method parameters in org.apache.hadoop.hbase.wal with type arguments of type org.apache.hadoop.hbase.Cell in in