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
Fields inherited from class org.apache.hadoop.hbase.client.Scan
DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH, HBASE_CLIENT_SCANNER_ASYNC_PREFETCH, SCAN_ATTRIBUTES_TABLE_NAME
Fields inherited from class org.apache.hadoop.hbase.client.Query
colFamTimeRangeMap, consistency, filter, loadColumnFamiliesOnDemand, targetReplicaId
Fields inherited from class org.apache.hadoop.hbase.client.OperationWithAttributes
ID_ATRIBUTE
-
Constructor Summary
ConstructorDescriptionImmutableScan
(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.boolean
Get the logical value indicating whether on-demand CF loading should be allowed.byte[]
getACL()
Returns The serialized ACL for this operation, or null if noneboolean
Returns 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 attributelong
Gets all attributesReturns The authorizations this Query is associated with.int
getBatch()
Returns maximum number of values to return for a single call to next()boolean
Get whether blocks should be cached for this Scan.int
Returns 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.int
getLimit()
Returns the limit of rows for this scanGet the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.long
Returns the maximum result size in bytes.int
Returns maximum number of values to return per row per CFint
Returns the max number of versions to fetch(package private) long
Get the mvcc read point used to open a scanner.int
Returns the read type for this scanint
Returns region replica id where Query will fetch data from.int
Method for retrieving the scan's offset per row per column family (#kvs to be skipped)byte[]
Returns the startrowbyte[]
Returns the stoprowReturns TimeRangeboolean
Returns true if familyMap is non empty, false otherwiseboolean
Returns true is a filter has been specified, false if notboolean
Returns if we should include start row when scanboolean
Returns if we should include stop row when scanboolean
boolean
boolean
isRaw()
Returns True if this Scan is in "raw" mode.boolean
Get whether this scan is a reversed one.boolean
Returns True if collection of scan metrics is enabled.int
Returns 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) Scan
Set 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) Scan
setMvccReadPoint
(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
.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.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, setRowPrefixFilter
-
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:Scan
Get all columns from the specified family.Overrides previous calls to addColumn for this family.
-
addColumn
Description copied from class:Scan
Get the column from the specified family with the specified qualifier.Overrides previous calls to addFamily for this family.
-
setTimeRange
Description copied from class:Scan
Get 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:
setTimeRange
in classScan
- Parameters:
minStamp
- minimum timestamp value, inclusivemaxStamp
- maximum timestamp value, exclusive- See Also:
-
setTimestamp
Description copied from class:Scan
Get 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:
setTimestamp
in classScan
- Parameters:
timestamp
- version timestamp- See Also:
-
setColumnFamilyTimeRange
Description copied from class:Query
Get 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:
setColumnFamilyTimeRange
in 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:Scan
Set 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.
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:
withStartRow
in classScan
- Parameters:
startRow
- row to start scanner at or after
-
withStartRow
Description copied from class:Scan
Set the start row of the scan.If the specified row does not exist, or the
inclusive
isfalse
, 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:
withStartRow
in classScan
- Parameters:
startRow
- row to start scanner at or afterinclusive
- whether we should include the start row when scan
-
withStopRow
Description copied from class:Scan
Set the stop row of the scan.The scan will include rows that are lexicographically less than 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:
withStopRow
in classScan
- Parameters:
stopRow
- row to end at (exclusive)
-
withStopRow
Description copied from class:Scan
Set the stop row of the scan.The scan will include rows that are lexicographically less than (or equal to if
inclusive
istrue
) 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:
withStopRow
in classScan
- Parameters:
stopRow
- row to end atinclusive
- whether we should include the stop row when scan
-
setStartStopRowForPrefixScan
Description copied from class:Scan
Set 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:
setStartStopRowForPrefixScan
in classScan
- Parameters:
rowPrefix
- the prefix all rows must start with. (Set null to remove the filter.)
-
readAllVersions
Description copied from class:Scan
Get all available versions.- Overrides:
readAllVersions
in classScan
-
readVersions
Description copied from class:Scan
Get up to the specified number of versions of each column.- Overrides:
readVersions
in classScan
- Parameters:
versions
- specified number of versions for each column
-
setBatch
Description copied from class:Scan
Set 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:Scan
Set the maximum number of values to return per row per Column Family- Overrides:
setMaxResultsPerColumnFamily
in classScan
- Parameters:
limit
- the maximum number of values returned / row / CF
-
setRowOffsetPerColumnFamily
Description copied from class:Scan
Set offset for the row per Column Family.- Overrides:
setRowOffsetPerColumnFamily
in classScan
- Parameters:
offset
- is the number of kvs that will be skipped.
-
setCaching
Description copied from class:Scan
Set the number of rows for caching that will be passed to scanners. If not set, the Configuration settingHConstants.HBASE_CLIENT_SCANNER_CACHING
will apply. Higher caching values will enable faster scanners but will use more memory.- Overrides:
setCaching
in classScan
- Parameters:
caching
- the number of rows for caching
-
setMaxResultSize
Description copied from class:Scan
Set 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:
setMaxResultSize
in classScan
- Parameters:
maxResultSize
- The maximum result size in bytes.
-
setFilter
Description copied from class:Query
Apply 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:Scan
Setting the familyMap- Overrides:
setFamilyMap
in classScan
- Parameters:
familyMap
- map of family to qualifier
-
setCacheBlocks
Description copied from class:Scan
Set 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:
setCacheBlocks
in classScan
- Parameters:
cacheBlocks
- if false, default settings are overridden and blocks will not be cached
-
setReversed
Description copied from class:Scan
Set whether this scan is a reversed oneThis is false by default which means forward(normal) scan.
- Overrides:
setReversed
in classScan
- Parameters:
reversed
- if true, scan will be backward order
-
setAllowPartialResults
Description copied from class:Scan
Setting 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:
setAllowPartialResults
in classScan
- See Also:
-
setLoadColumnFamiliesOnDemand
Description copied from class:Query
Set 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:
setLoadColumnFamiliesOnDemand
in classScan
-
setRaw
Description copied from class:Scan
Enable/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. -
setAttribute
Description copied from interface:Attributes
Sets an attribute. In case value = null attribute is removed from the attributes map. Attribute names starting with _ indicate system attributes.- Specified by:
setAttribute
in interfaceAttributes
- Overrides:
setAttribute
in classScan
- Parameters:
name
- attribute namevalue
- attribute value
-
setId
Description copied from class:OperationWithAttributes
This 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:Query
Sets the authorizations to be used by this Query- Overrides:
setAuthorizations
in classScan
-
setACL
Description copied from class:Query
Set the ACL for the operation. -
setACL
Description copied from class:Query
Set the ACL for the operation. -
setConsistency
Description copied from class:Query
Sets the consistency level for this operation- Overrides:
setConsistency
in classScan
- Parameters:
consistency
- the consistency level
-
setReplicaId
Description copied from class:Query
Specify region replica id where Query will fetch data from. Use this together withQuery.setConsistency(Consistency)
passingConsistency.TIMELINE
to read data from a specific replicaId.
Expert: This is an advanced API exposed. Only use it if you know what you are doing- Overrides:
setReplicaId
in classScan
-
setIsolationLevel
Description copied from class:Query
Set 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:
setIsolationLevel
in classScan
- Parameters:
level
- IsolationLevel for this query
-
setPriority
- Overrides:
setPriority
in classScan
-
setScanMetricsEnabled
Description copied from class:Scan
Enable collection ofScanMetrics
. For advanced users.- Overrides:
setScanMetricsEnabled
in classScan
- Parameters:
enabled
- Set to true to enable accumulating scan metrics
-
setAsyncPrefetch
Deprecated.- Overrides:
setAsyncPrefetch
in classScan
-
setLimit
Description copied from class:Scan
Set 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:Scan
Call this when you only want to get one row. It will setlimit
to1
, and also setreadType
toScan.ReadType.PREAD
.- Overrides:
setOneRowLimit
in classScan
-
setReadType
Description copied from class:Scan
Set the read type for this scan.Notice that we may choose to use pread even if you specific
Scan.ReadType.STREAM
here. For example, we will always use pread if this is a get scan.- Overrides:
setReadType
in classScan
-
setMvccReadPoint
Description copied from class:Scan
Set the mvcc read point used to open a scanner.- Overrides:
setMvccReadPoint
in classScan
-
resetMvccReadPoint
Description copied from class:Scan
Set the mvcc read point to -1 which means do not use it.- Overrides:
resetMvccReadPoint
in classScan
-
setNeedCursorResult
Description copied from class:Scan
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. 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:
setNeedCursorResult
in classScan
-
getMaxResultSize
Description copied from class:Scan
Returns the maximum result size in bytes. SeeScan.setMaxResultSize(long)
- Overrides:
getMaxResultSize
in classScan
-
getFamilyMap
Description copied from class:Scan
Getting the familyMap- Overrides:
getFamilyMap
in classScan
-
numFamilies
Description copied from class:Scan
Returns the number of families in familyMap- Overrides:
numFamilies
in classScan
-
hasFamilies
Description copied from class:Scan
Returns true if familyMap is non empty, false otherwise- Overrides:
hasFamilies
in classScan
-
getFamilies
Description copied from class:Scan
Returns the keys of the familyMap- Overrides:
getFamilies
in classScan
-
getStartRow
Description copied from class:Scan
Returns the startrow- Overrides:
getStartRow
in classScan
-
includeStartRow
Description copied from class:Scan
Returns if we should include start row when scan- Overrides:
includeStartRow
in classScan
-
getStopRow
Description copied from class:Scan
Returns the stoprow- Overrides:
getStopRow
in classScan
-
includeStopRow
Description copied from class:Scan
Returns if we should include stop row when scan- Overrides:
includeStopRow
in classScan
-
getMaxVersions
Description copied from class:Scan
Returns the max number of versions to fetch- Overrides:
getMaxVersions
in classScan
-
getBatch
Description copied from class:Scan
Returns maximum number of values to return for a single call to next() -
getMaxResultsPerColumnFamily
Description copied from class:Scan
Returns maximum number of values to return per row per CF- Overrides:
getMaxResultsPerColumnFamily
in classScan
-
getRowOffsetPerColumnFamily
Description copied from class:Scan
Method for retrieving the scan's offset per row per column family (#kvs to be skipped)- Overrides:
getRowOffsetPerColumnFamily
in classScan
- Returns:
- row offset
-
getCaching
Description copied from class:Scan
Returns caching the number of rows fetched when calling next on a scanner- Overrides:
getCaching
in classScan
-
getTimeRange
Description copied from class:Scan
Returns TimeRange- Overrides:
getTimeRange
in classScan
-
getFilter
Description copied from class:Scan
Returns RowFilter -
hasFilter
Description copied from class:Scan
Returns true is a filter has been specified, false if not -
getCacheBlocks
Description copied from class:Scan
Get whether blocks should be cached for this Scan.- Overrides:
getCacheBlocks
in classScan
- Returns:
- true if default caching should be used, false if blocks should not be cached
-
isReversed
Description copied from class:Scan
Get whether this scan is a reversed one.- Overrides:
isReversed
in classScan
- Returns:
- true if backward scan, false if forward(default) scan
-
getAllowPartialResults
Description copied from class:Scan
Returns 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:
getAllowPartialResults
in classScan
-
getACL
Description copied from class:Query
Returns The serialized ACL for this operation, or null if none -
getFingerprint
Description copied from class:Scan
Compile the table and column family (i.e. schema) information into a String. Useful for parsing and aggregation by debugging, logging, and administration tools.- Overrides:
getFingerprint
in classScan
- Returns:
- a map containing fingerprint information (i.e. column families)
-
toMap
Description copied from class:Scan
Compile 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:Scan
Returns True if this Scan is in "raw" mode. -
isScanMetricsEnabled
Description copied from class:Scan
Returns True if collection of scan metrics is enabled. For advanced users.- Overrides:
isScanMetricsEnabled
in classScan
-
isAsyncPrefetch
- Overrides:
isAsyncPrefetch
in classScan
-
getLimit
Description copied from class:Scan
Returns the limit of rows for this scan -
getReadType
Description copied from class:Scan
Returns the read type for this scan- Overrides:
getReadType
in classScan
-
getMvccReadPoint
long getMvccReadPoint()Description copied from class:Scan
Get the mvcc read point used to open a scanner.- Overrides:
getMvccReadPoint
in classScan
-
isNeedCursorResult
- Overrides:
isNeedCursorResult
in classScan
-
getAttribute
Description copied from interface:Attributes
Gets an attribute- Specified by:
getAttribute
in interfaceAttributes
- Overrides:
getAttribute
in classOperationWithAttributes
- Parameters:
name
- attribute name- Returns:
- attribute value if attribute is set, null otherwise
-
getConsistency
Description copied from class:Query
Returns the consistency level for this operation- Overrides:
getConsistency
in classQuery
- Returns:
- the consistency level
-
getAttributeSize
- Overrides:
getAttributeSize
in classOperationWithAttributes
-
getAttributesMap
Description copied from interface:Attributes
Gets all attributes- Specified by:
getAttributesMap
in interfaceAttributes
- Overrides:
getAttributesMap
in classOperationWithAttributes
- Returns:
- unmodifiable map of all attributes
-
getLoadColumnFamiliesOnDemandValue
Description copied from class:Query
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.- Overrides:
getLoadColumnFamiliesOnDemandValue
in classQuery
-
getPriority
- Overrides:
getPriority
in classOperationWithAttributes
-
getColumnFamilyTimeRange
Description copied from class:Query
Returns A map of column families to time ranges- Overrides:
getColumnFamilyTimeRange
in classQuery
-
getReplicaId
Description copied from class:Query
Returns region replica id where Query will fetch data from.- Overrides:
getReplicaId
in classQuery
- Returns:
- region replica id or -1 if not set.
-
doLoadColumnFamiliesOnDemand
Description copied from class:Query
Get the logical value indicating whether on-demand CF loading should be allowed.- Overrides:
doLoadColumnFamiliesOnDemand
in classQuery
-
getId
Description copied from class:OperationWithAttributes
This method allows you to retrieve the identifier for the operation if one was set.- Overrides:
getId
in classOperationWithAttributes
- Returns:
- the id or null if not set
-
isGetScan
-
getIsolationLevel
Description copied from class:Query
Returns The isolation level of this query. If no isolation level was set for this query object, then it returns READ_COMMITTED.- Overrides:
getIsolationLevel
in classQuery
-
getAuthorizations
Description copied from class:Query
Returns The authorizations this Query is associated with. n- Overrides:
getAuthorizations
in classQuery
- Throws:
DeserializationException
-
toString
Description copied from class:Operation
Produces 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:Operation
Produces 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:Operation
Produces a Map containing a full summary of a query. -
toJSON
Description copied from class:Operation
Produces a JSON object for fingerprint and details exposure in a parseable format.- Overrides:
toJSON
in 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:Operation
Produces a JSON object sufficient for description of a query in a debugging or logging context.- Overrides:
toJSON
in classOperation
- Returns:
- the produced JSON object, as a string
- Throws:
IOException
-