Class ImmutableScan
- All Implemented Interfaces:
Attributes
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.client.Scan
Scan.ReadType -
Field Summary
FieldsFields inherited from class org.apache.hadoop.hbase.client.Scan
DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH, HBASE_CLIENT_SCANNER_ASYNC_PREFETCH, SCAN_ATTRIBUTES_METRICS_DATA, SCAN_ATTRIBUTES_METRICS_ENABLE, SCAN_ATTRIBUTES_TABLE_NAMEFields inherited from class org.apache.hadoop.hbase.client.Query
colFamTimeRangeMap, consistency, filter, loadColumnFamiliesOnDemand, targetReplicaIdFields inherited from class org.apache.hadoop.hbase.client.OperationWithAttributes
ID_ATRIBUTE -
Constructor Summary
ConstructorsConstructorDescriptionImmutableScan(Scan scan) Create Immutable instance of Scan from given Scan object -
Method Summary
Modifier and TypeMethodDescriptionaddColumn(byte[] family, byte[] qualifier) Get the column from the specified family with the specified qualifier.addFamily(byte[] family) Get all columns from the specified family.booleanGet the logical value indicating whether on-demand CF loading should be allowed.byte[]getACL()Returns The serialized ACL for this operation, or null if nonebooleanReturns true when the constructor of this scan understands that the results they will see may only represent a partial portion of a row.byte[]getAttribute(String name) Gets an attributelongGets all attributesReturns The authorizations this Query is associated with.intgetBatch()Returns maximum number of values to return for a single call to next()booleanGet whether blocks should be cached for this Scan.intReturns caching the number of rows fetched when calling next on a scannerReturns A map of column families to time rangesReturns the consistency level for this operationbyte[][]Returns the keys of the familyMapMap<byte[],NavigableSet<byte[]>> Getting the familyMapReturns RowFilterCompile the table and column family (i.e.getId()This method allows you to retrieve the identifier for the operation if one was set.Returns The isolation level of this query.intgetLimit()Returns the limit of rows for this scanGet the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.longReturns the maximum result size in bytes.intReturns maximum number of values to return per row per CFintReturns the max number of versions to fetch(package private) longGet the mvcc read point used to open a scanner.intReturns the read type for this scanintReturns region replica id where Query will fetch data from.intMethod for retrieving the scan's offset per row per column family (#kvs to be skipped)byte[]Returns the startrowbyte[]Returns the stoprowReturns TimeRangebooleanReturns true if familyMap is non empty, false otherwisebooleanReturns true is a filter has been specified, false if notbooleanReturns if we should include start row when scanbooleanReturns if we should include stop row when scanbooleanbooleanbooleanisRaw()Returns True if this Scan is in "raw" mode.booleanGet whether this scan is a reversed one.booleanReturns True if collection of scan metrics is enabled.booleanisSmall()Deprecated.intReturns the number of families in familyMapGet all available versions.readVersions(int versions) Get up to the specified number of versions of each column.(package private) ScanSet the mvcc read point to -1 which means do not use it.setACL(String user, Permission perms) Set the ACL for the operation.setACL(Map<String, Permission> perms) Set the ACL for the operation.setAllowPartialResults(boolean allowPartialResults) Setting whether the caller wants to see the partial results when server returns less-than-expected cells.setAsyncPrefetch(boolean asyncPrefetch) Deprecated.setAttribute(String name, byte[] value) Sets an attribute.setAuthorizations(Authorizations authorizations) Sets the authorizations to be used by this QuerysetBatch(int batch) Set the maximum number of cells to return for each call to next().setCacheBlocks(boolean cacheBlocks) Set whether blocks should be cached for this Scan.setCaching(int caching) Set the number of rows for caching that will be passed to scanners.setColumnFamilyTimeRange(byte[] cf, long minStamp, long maxStamp) Get versions of columns only within the specified timestamp range, [minStamp, maxStamp) on a per CF bases.setConsistency(Consistency consistency) Sets the consistency level for this operationsetFamilyMap(Map<byte[], NavigableSet<byte[]>> familyMap) Setting the familyMapApply the specified server-side filter when performing the Query.This method allows you to set an identifier on an operation.setIsolationLevel(IsolationLevel level) Set the isolation level for this query.setLimit(int limit) Set the limit of rows for this scan.setLoadColumnFamiliesOnDemand(boolean value) Set the value indicating whether loading CFs on demand should be allowed (cluster default is false).setMaxResultSize(long maxResultSize) Set the maximum result size.setMaxResultsPerColumnFamily(int limit) Set the maximum number of values to return per row per Column Family(package private) ScansetMvccReadPoint(long mvccReadPoint) Set the mvcc read point used to open a scanner.setNeedCursorResult(boolean needCursorResult) When the server is slow or we scan a table with many deleted data or we use a sparse filter, the server will response heartbeat to prevent timeout.Call this when you only want to get one row.setPriority(int priority) setRaw(boolean raw) Enable/disable "raw" mode for this scan.setReadType(Scan.ReadType readType) Set the read type for this scan.setReplicaId(int id) Specify region replica id where Query will fetch data from.setReversed(boolean reversed) Set whether this scan is a reversed onesetRowOffsetPerColumnFamily(int offset) Set offset for the row per Column Family.setScanMetricsEnabled(boolean enabled) Enable collection ofScanMetrics.setSmall(boolean small) Deprecated.setStartStopRowForPrefixScan(byte[] rowPrefix) Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey starts with the specified prefix.setTimeRange(long minStamp, long maxStamp) Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).setTimestamp(long timestamp) Get versions of columns with the specified timestamp.setTimeStamp(long timestamp) Deprecated.toJSON()Produces a JSON object sufficient for description of a query in a debugging or logging context.toJSON(int maxCols) Produces a JSON object for fingerprint and details exposure in a parseable format.toMap()Produces a Map containing a full summary of a query.toMap(int maxCols) Compile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information.toString()Produces a string representation of this Operation.toString(int maxCols) Produces a string representation of this Operation.withStartRow(byte[] startRow) Set the start row of the scan.withStartRow(byte[] startRow, boolean inclusive) Set the start row of the scan.withStopRow(byte[] stopRow) Set the stop row of the scan.withStopRow(byte[] stopRow, boolean inclusive) Set the stop row of the scan.Methods inherited from class org.apache.hadoop.hbase.client.Scan
createScanFromCursor, getScanMetrics, setMaxVersions, setMaxVersions, setRowPrefixFilter, setStartRow, setStopRow
-
Field Details
-
delegateScan
-
-
Constructor Details
-
ImmutableScan
Create Immutable instance of Scan from given Scan object- Parameters:
scan- Copy all values from Scan
-
-
Method Details
-
addFamily
Description copied from class:ScanGet all columns from the specified family.Overrides previous calls to addColumn for this family.
-
addColumn
Description copied from class:ScanGet the column from the specified family with the specified qualifier.Overrides previous calls to addFamily for this family.
-
setTimeRange
Description copied from class:ScanGet versions of columns only within the specified timestamp range, [minStamp, maxStamp). Note, default maximum versions to return is 1. If your time range spans more than one version and you want all versions returned, up the number of versions beyond the default.- Overrides:
setTimeRangein classScan- Parameters:
minStamp- minimum timestamp value, inclusivemaxStamp- maximum timestamp value, exclusive- See Also:
-
setTimeStamp
Deprecated.Description copied from class:ScanGet versions of columns with the specified timestamp. Note, default maximum versions to return is 1. If your time range spans more than one version and you want all versions returned, up the number of versions beyond the defaut.- Overrides:
setTimeStampin classScan- Parameters:
timestamp- version timestamp- See Also:
-
setTimestamp
Description copied from class:ScanGet versions of columns with the specified timestamp. Note, default maximum versions to return is 1. If your time range spans more than one version and you want all versions returned, up the number of versions beyond the defaut.- Overrides:
setTimestampin classScan- Parameters:
timestamp- version timestamp- See Also:
-
setColumnFamilyTimeRange
Description copied from class:QueryGet versions of columns only within the specified timestamp range, [minStamp, maxStamp) on a per CF bases. Note, default maximum versions to return is 1. If your time range spans more than one version and you want all versions returned, up the number of versions beyond the default. Column Family time ranges take precedence over the global time range.- Overrides:
setColumnFamilyTimeRangein classScan- Parameters:
cf- the column family for which you want to restrictminStamp- minimum timestamp value, inclusivemaxStamp- maximum timestamp value, exclusive
-
withStartRow
Description copied from class:ScanSet the start row of the scan.If the specified row does not exist, the Scanner will start from the next closest row after the specified row.
- Overrides:
withStartRowin classScan- Parameters:
startRow- row to start scanner at or after
-
withStartRow
Description copied from class:ScanSet the start row of the scan.If the specified row does not exist, or the
inclusiveisfalse, the Scanner will start from the next closest row after the specified row.Note: Do NOT use this in combination with
Scan.setRowPrefixFilter(byte[])orScan.setStartStopRowForPrefixScan(byte[]). Doing so will make the scan result unexpected or even undefined.- Overrides:
withStartRowin classScan- Parameters:
startRow- row to start scanner at or afterinclusive- whether we should include the start row when scan
-
withStopRow
Description copied from class:ScanSet the stop row of the scan.The scan will include rows that are lexicographically less than the provided stopRow.
Note: When doing a filter for a rowKey Prefix use
Scan.setRowPrefixFilter(byte[]). The 'trailing 0' will not yield the desired result.- Overrides:
withStopRowin classScan- Parameters:
stopRow- row to end at (exclusive)
-
withStopRow
Description copied from class:ScanSet the stop row of the scan.The scan will include rows that are lexicographically less than (or equal to if
inclusiveistrue) the provided stopRow.Note: Do NOT use this in combination with
Scan.setRowPrefixFilter(byte[])orScan.setStartStopRowForPrefixScan(byte[]). Doing so will make the scan result unexpected or even undefined.- Overrides:
withStopRowin classScan- Parameters:
stopRow- row to end atinclusive- whether we should include the stop row when scan
-
setStartStopRowForPrefixScan
Description copied from class:ScanSet a filter (using stopRow and startRow) so the result set only contains rows where the rowKey starts with the specified prefix.
This is a utility method that converts the desired rowPrefix into the appropriate values for the startRow and stopRow to achieve the desired result.
This can safely be used in combination with setFilter.
This CANNOT be used in combination with withStartRow and/or withStopRow. Such a combination will yield unexpected and even undefined results.
- Overrides:
setStartStopRowForPrefixScanin classScan- Parameters:
rowPrefix- the prefix all rows must start with. (Set null to remove the filter.)
-
readAllVersions
Description copied from class:ScanGet all available versions.- Overrides:
readAllVersionsin classScan
-
readVersions
Description copied from class:ScanGet up to the specified number of versions of each column.- Overrides:
readVersionsin classScan- Parameters:
versions- specified number of versions for each column
-
setBatch
Description copied from class:ScanSet the maximum number of cells to return for each call to next(). Callers should be aware that this is not equivalent to callingScan.setAllowPartialResults(boolean). If you don't allow partial results, the number of cells in each Result must equal to your batch setting unless it is the last Result for current row. So this method is helpful in paging queries. If you just want to prevent OOM at client, use setAllowPartialResults(true) is better. -
setMaxResultsPerColumnFamily
Description copied from class:ScanSet the maximum number of values to return per row per Column Family- Overrides:
setMaxResultsPerColumnFamilyin classScan- Parameters:
limit- the maximum number of values returned / row / CF
-
setRowOffsetPerColumnFamily
Description copied from class:ScanSet offset for the row per Column Family.- Overrides:
setRowOffsetPerColumnFamilyin classScan- Parameters:
offset- is the number of kvs that will be skipped.
-
setCaching
Description copied from class:ScanSet the number of rows for caching that will be passed to scanners. If not set, the Configuration settingHConstants.HBASE_CLIENT_SCANNER_CACHINGwill apply. Higher caching values will enable faster scanners but will use more memory.- Overrides:
setCachingin classScan- Parameters:
caching- the number of rows for caching
-
setMaxResultSize
Description copied from class:ScanSet the maximum result size. The default is -1; this means that no specific maximum result size will be set for this scan, and the global configured value will be used instead. (Defaults to unlimited).- Overrides:
setMaxResultSizein classScan- Parameters:
maxResultSize- The maximum result size in bytes.
-
setFilter
Description copied from class:QueryApply the specified server-side filter when performing the Query. OnlyFilter.filterCell(org.apache.hadoop.hbase.Cell)is called AFTER all tests for ttl, column match, deletes and column family's max versions have been run. -
setFamilyMap
Description copied from class:ScanSetting the familyMap- Overrides:
setFamilyMapin classScan- Parameters:
familyMap- map of family to qualifier
-
setCacheBlocks
Description copied from class:ScanSet whether blocks should be cached for this Scan.This is true by default. When true, default settings of the table and family are used (this will never override caching blocks if the block cache is disabled for that family or entirely).
- Overrides:
setCacheBlocksin classScan- Parameters:
cacheBlocks- if false, default settings are overridden and blocks will not be cached
-
setReversed
Description copied from class:ScanSet whether this scan is a reversed oneThis is false by default which means forward(normal) scan.
- Overrides:
setReversedin classScan- Parameters:
reversed- if true, scan will be backward order
-
setAllowPartialResults
Description copied from class:ScanSetting whether the caller wants to see the partial results when server returns less-than-expected cells. It is helpful while scanning a huge row to prevent OOM at client. By default this value is false and the complete results will be assembled client side before being delivered to the caller.- Overrides:
setAllowPartialResultsin classScan- See Also:
-
setLoadColumnFamiliesOnDemand
Description copied from class:QuerySet the value indicating whether loading CFs on demand should be allowed (cluster default is false). On-demand CF loading doesn't load column families until necessary, e.g. if you filter on one column, the other column family data will be loaded only for the rows that are included in result, not all rows like in normal case. With column-specific filters, like SingleColumnValueFilter w/filterIfMissing == true, this can deliver huge perf gains when there's a cf with lots of data; however, it can also lead to some inconsistent results, as follows: - if someone does a concurrent update to both column families in question you may get a row that never existed, e.g. for { rowKey = 5, { cat_videos => 1 }, { video => "my cat" } } someone puts rowKey 5 with { cat_videos => 0 }, { video => "my dog" }, concurrent scan filtering on "cat_videos == 1" can get { rowKey = 5, { cat_videos => 1 }, { video => "my dog" } }. - if there's a concurrent split and you have more than 2 column families, some rows may be missing some column families.- Overrides:
setLoadColumnFamiliesOnDemandin classScan
-
setRaw
Description copied from class:ScanEnable/disable "raw" mode for this scan. If "raw" is enabled the scan will return all delete marker and deleted rows that have not been collected, yet. This is mostly useful for Scan on column families that have KEEP_DELETED_ROWS enabled. It is an error to specify any column when "raw" is set. -
setSmall
Deprecated.Description copied from class:ScanSet whether this scan is a small scanSmall scan should use pread and big scan can use seek + read seek + read is fast but can cause two problem (1) resource contention (2) cause too much network io [89-fb] Using pread for non-compaction read request https://issues.apache.org/jira/browse/HBASE-7266 On the other hand, if setting it true, we would do openScanner,next,closeScanner in one RPC call. It means the better performance for small scan. [HBASE-9488]. Generally, if the scan range is within one data block(64KB), it could be considered as a small scan.
-
setAttribute
Description copied from interface:AttributesSets an attribute. In case value = null attribute is removed from the attributes map. Attribute names starting with _ indicate system attributes.- Specified by:
setAttributein interfaceAttributes- Overrides:
setAttributein classScan- Parameters:
name- attribute namevalue- attribute value
-
setId
Description copied from class:OperationWithAttributesThis method allows you to set an identifier on an operation. The original motivation for this was to allow the identifier to be used in slow query logging, but this could obviously be useful in other places. One use of this could be to put a class.method identifier in here to see where the slow query is coming from. id to set for the scan -
setAuthorizations
Description copied from class:QuerySets the authorizations to be used by this Query- Overrides:
setAuthorizationsin classScan
-
setACL
Description copied from class:QuerySet the ACL for the operation. -
setACL
Description copied from class:QuerySet the ACL for the operation. -
setConsistency
Description copied from class:QuerySets the consistency level for this operation- Overrides:
setConsistencyin classScan- Parameters:
consistency- the consistency level
-
setReplicaId
Description copied from class:QuerySpecify region replica id where Query will fetch data from. Use this together withQuery.setConsistency(Consistency)passingConsistency.TIMELINEto read data from a specific replicaId.
Expert: This is an advanced API exposed. Only use it if you know what you are doing- Overrides:
setReplicaIdin classScan
-
setIsolationLevel
Description copied from class:QuerySet the isolation level for this query. If the isolation level is set to READ_UNCOMMITTED, then this query will return data from committed and uncommitted transactions. If the isolation level is set to READ_COMMITTED, then this query will return data from committed transactions only. If a isolation level is not explicitly set on a Query, then it is assumed to be READ_COMMITTED.- Overrides:
setIsolationLevelin classScan- Parameters:
level- IsolationLevel for this query
-
setPriority
- Overrides:
setPriorityin classScan
-
setScanMetricsEnabled
Description copied from class:ScanEnable collection ofScanMetrics. For advanced users.- Overrides:
setScanMetricsEnabledin classScan- Parameters:
enabled- Set to true to enable accumulating scan metrics
-
setAsyncPrefetch
Deprecated.- Overrides:
setAsyncPrefetchin classScan
-
setLimit
Description copied from class:ScanSet the limit of rows for this scan. We will terminate the scan if the number of returned rows reaches this value.This condition will be tested at last, after all other conditions such as stopRow, filter, etc.
-
setOneRowLimit
Description copied from class:ScanCall this when you only want to get one row. It will setlimitto1, and also setreadTypetoScan.ReadType.PREAD.- Overrides:
setOneRowLimitin classScan
-
setReadType
Description copied from class:ScanSet the read type for this scan.Notice that we may choose to use pread even if you specific
Scan.ReadType.STREAMhere. For example, we will always use pread if this is a get scan.- Overrides:
setReadTypein classScan
-
setMvccReadPoint
Description copied from class:ScanSet the mvcc read point used to open a scanner.- Overrides:
setMvccReadPointin classScan
-
resetMvccReadPoint
Description copied from class:ScanSet the mvcc read point to -1 which means do not use it.- Overrides:
resetMvccReadPointin classScan
-
setNeedCursorResult
Description copied from class:ScanWhen the server is slow or we scan a table with many deleted data or we use a sparse filter, the server will response heartbeat to prevent timeout. However the scanner will return a Result only when client can do it. So if there are many heartbeats, the blocking time on ResultScanner#next() may be very long, which is not friendly to online services. Set this to true then you can get a special Result whose #isCursor() returns true and is not contains any real data. It only tells you where the server has scanned. You can call next to continue scanning or open a new scanner with this row key as start row whenever you want. Users can get a cursor when and only when there is a response from the server but we can not return a Result to users, for example, this response is a heartbeat or there are partial cells but users do not allow partial result. Now the cursor is in row level which means the special Result will only contains a row key.Result.isCursor()Result.getCursor()Cursor- Overrides:
setNeedCursorResultin classScan
-
getMaxResultSize
Description copied from class:ScanReturns the maximum result size in bytes. SeeScan.setMaxResultSize(long)- Overrides:
getMaxResultSizein classScan
-
getFamilyMap
Description copied from class:ScanGetting the familyMap- Overrides:
getFamilyMapin classScan
-
numFamilies
Description copied from class:ScanReturns the number of families in familyMap- Overrides:
numFamiliesin classScan
-
hasFamilies
Description copied from class:ScanReturns true if familyMap is non empty, false otherwise- Overrides:
hasFamiliesin classScan
-
getFamilies
Description copied from class:ScanReturns the keys of the familyMap- Overrides:
getFamiliesin classScan
-
getStartRow
Description copied from class:ScanReturns the startrow- Overrides:
getStartRowin classScan
-
includeStartRow
Description copied from class:ScanReturns if we should include start row when scan- Overrides:
includeStartRowin classScan
-
getStopRow
Description copied from class:ScanReturns the stoprow- Overrides:
getStopRowin classScan
-
includeStopRow
Description copied from class:ScanReturns if we should include stop row when scan- Overrides:
includeStopRowin classScan
-
getMaxVersions
Description copied from class:ScanReturns the max number of versions to fetch- Overrides:
getMaxVersionsin classScan
-
getBatch
Description copied from class:ScanReturns maximum number of values to return for a single call to next() -
getMaxResultsPerColumnFamily
Description copied from class:ScanReturns maximum number of values to return per row per CF- Overrides:
getMaxResultsPerColumnFamilyin classScan
-
getRowOffsetPerColumnFamily
Description copied from class:ScanMethod for retrieving the scan's offset per row per column family (#kvs to be skipped)- Overrides:
getRowOffsetPerColumnFamilyin classScan- Returns:
- row offset
-
getCaching
Description copied from class:ScanReturns caching the number of rows fetched when calling next on a scanner- Overrides:
getCachingin classScan
-
getTimeRange
Description copied from class:ScanReturns TimeRange- Overrides:
getTimeRangein classScan
-
getFilter
Description copied from class:ScanReturns RowFilter -
hasFilter
Description copied from class:ScanReturns true is a filter has been specified, false if not -
getCacheBlocks
Description copied from class:ScanGet whether blocks should be cached for this Scan.- Overrides:
getCacheBlocksin classScan- Returns:
- true if default caching should be used, false if blocks should not be cached
-
isReversed
Description copied from class:ScanGet whether this scan is a reversed one.- Overrides:
isReversedin classScan- Returns:
- true if backward scan, false if forward(default) scan
-
getAllowPartialResults
Description copied from class:ScanReturns true when the constructor of this scan understands that the results they will see may only represent a partial portion of a row. The entire row would be retrieved by subsequent calls toResultScanner.next()- Overrides:
getAllowPartialResultsin classScan
-
getACL
Description copied from class:QueryReturns The serialized ACL for this operation, or null if none -
getFingerprint
Description copied from class:ScanCompile the table and column family (i.e. schema) information into a String. Useful for parsing and aggregation by debugging, logging, and administration tools.- Overrides:
getFingerprintin classScan- Returns:
- a map containing fingerprint information (i.e. column families)
-
toMap
Description copied from class:ScanCompile the details beyond the scope of getFingerprint (row, columns, timestamps, etc.) into a Map along with the fingerprinted information. Useful for debugging, logging, and administration tools. -
isRaw
Description copied from class:ScanReturns True if this Scan is in "raw" mode. -
isSmall
Deprecated.Description copied from class:ScanGet whether this scan is a small scan -
isScanMetricsEnabled
Description copied from class:ScanReturns True if collection of scan metrics is enabled. For advanced users.- Overrides:
isScanMetricsEnabledin classScan
-
isAsyncPrefetch
- Overrides:
isAsyncPrefetchin classScan
-
getLimit
Description copied from class:ScanReturns the limit of rows for this scan -
getReadType
Description copied from class:ScanReturns the read type for this scan- Overrides:
getReadTypein classScan
-
getMvccReadPoint
long getMvccReadPoint()Description copied from class:ScanGet the mvcc read point used to open a scanner.- Overrides:
getMvccReadPointin classScan
-
isNeedCursorResult
- Overrides:
isNeedCursorResultin classScan
-
getAttribute
Description copied from interface:AttributesGets an attribute- Specified by:
getAttributein interfaceAttributes- Overrides:
getAttributein classOperationWithAttributes- Parameters:
name- attribute name- Returns:
- attribute value if attribute is set, null otherwise
-
getConsistency
Description copied from class:QueryReturns the consistency level for this operation- Overrides:
getConsistencyin classQuery- Returns:
- the consistency level
-
getAttributeSize
- Overrides:
getAttributeSizein classOperationWithAttributes
-
getAttributesMap
Description copied from interface:AttributesGets all attributes- Specified by:
getAttributesMapin interfaceAttributes- Overrides:
getAttributesMapin classOperationWithAttributes- Returns:
- unmodifiable map of all attributes
-
getLoadColumnFamiliesOnDemandValue
Description copied from class:QueryGet the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.- Overrides:
getLoadColumnFamiliesOnDemandValuein classQuery
-
getPriority
- Overrides:
getPriorityin classOperationWithAttributes
-
getColumnFamilyTimeRange
Description copied from class:QueryReturns A map of column families to time ranges- Overrides:
getColumnFamilyTimeRangein classQuery
-
getReplicaId
Description copied from class:QueryReturns region replica id where Query will fetch data from.- Overrides:
getReplicaIdin classQuery- Returns:
- region replica id or -1 if not set.
-
doLoadColumnFamiliesOnDemand
Description copied from class:QueryGet the logical value indicating whether on-demand CF loading should be allowed.- Overrides:
doLoadColumnFamiliesOnDemandin classQuery
-
getId
Description copied from class:OperationWithAttributesThis method allows you to retrieve the identifier for the operation if one was set.- Overrides:
getIdin classOperationWithAttributes- Returns:
- the id or null if not set
-
isGetScan
-
getIsolationLevel
Description copied from class:QueryReturns The isolation level of this query. If no isolation level was set for this query object, then it returns READ_COMMITTED.- Overrides:
getIsolationLevelin classQuery
-
getAuthorizations
Description copied from class:QueryReturns The authorizations this Query is associated with. n- Overrides:
getAuthorizationsin classQuery- Throws:
DeserializationException
-
toString
Description copied from class:OperationProduces a string representation of this Operation. It defaults to a JSON representation, but falls back to a string representation of the fingerprint and details in the case of a JSON encoding failure. -
toString
Description copied from class:OperationProduces a string representation of this Operation. It defaults to a JSON representation, but falls back to a string representation of the fingerprint and details in the case of a JSON encoding failure. -
toMap
Description copied from class:OperationProduces a Map containing a full summary of a query. -
toJSON
Description copied from class:OperationProduces a JSON object for fingerprint and details exposure in a parseable format.- Overrides:
toJSONin classOperation- Parameters:
maxCols- a limit on the number of columns to include in the JSON- Returns:
- a JSONObject containing this Operation's information, as a string
- Throws:
IOException
-
toJSON
Description copied from class:OperationProduces a JSON object sufficient for description of a query in a debugging or logging context.- Overrides:
toJSONin classOperation- Returns:
- the produced JSON object, as a string
- Throws:
IOException
-