Modifier and Type | Method and Description |
---|---|
void |
LensMLClient.deleteModel(String algorithm,
String modelID)
Permanently delete a model instance.
|
void |
LensMLClient.deleteTestReport(String algorithm,
String reportID)
Permanently delete a test report instance.
|
MLAlgo |
LensMLClient.getAlgoForName(String algorithm)
Get a algo object instance which could be used to generate a model of the given algorithm.
|
MLModel |
LensMLClient.getModel(String algorithm,
String modelId)
Get a model instance given the algorithm name and model ID.
|
List<String> |
LensMLClient.getModels(String algorithm)
Get model IDs for the given algorithm.
|
MLTestReport |
LensMLClient.getTestReport(String algorithm,
String reportID)
Get a test report by ID.
|
List<String> |
LensMLClient.getTestReports(String algorithm)
Get test reports for an algorithm.
|
Object |
LensMLClient.predict(String algorithm,
String modelID,
Object[] features)
Online predict call given a model ID, algorithm name and sample feature values.
|
MLTestReport |
LensMLClient.testModel(LensSessionHandle session,
String table,
String algorithm,
String modelID,
String outputTable)
Evaluate model by running it against test data contained in the given table.
|
String |
LensMLClient.train(String table,
String algorithm,
String[] args)
Create a model using the given HCatalog table as input.
|
Modifier and Type | Class and Description |
---|---|
class |
ColUnAvailableInTimeRangeException |
class |
FieldsCannotBeQueriedTogetherException |
Modifier and Type | Method and Description |
---|---|
List<org.apache.hadoop.hive.ql.metadata.Partition> |
CubeMetastoreClient.addPartition(StoragePartitionDesc partSpec,
String storageName)
Add a partition specified by the storage partition desc on the storage passed.
|
List<org.apache.hadoop.hive.ql.metadata.Partition> |
CubeMetastoreClient.addPartitions(List<StoragePartitionDesc> storagePartitionDescs,
String storageName)
batch addition
|
static TimePartitionRange |
TimePartitionRange.between(Date from,
Date to,
UpdatePeriod period) |
void |
CubeMetastoreClient.dropPartition(String cubeTableName,
String storageName,
Map<String,Date> timePartSpec,
Map<String,String> nonTimePartSpec,
UpdatePeriod updatePeriod)
Add a partition specified by the storage partition desc on the storage passed.
|
TimePartitionRange |
TimePartition.emptyRange() |
boolean |
CubeMetastoreClient.factPartitionExists(CubeFactTable fact,
FactPartition part,
String storageTableName)
extract storage name and check in timeline cache for existance
|
static UpdatePeriod |
UpdatePeriod.fromUnitName(String unitName) |
Date |
CubeMetastoreClient.getLatestDateOfCube(Cube cube,
String timeDimension)
get latest date for timeDimension from all fact-storage tables belonging to the given cube having timeDimension,
return the most recent of all.
|
List<PartitionTimeline> |
CubeMetastoreClient.getTimelines(String factName,
String storage,
String updatePeriodStr,
String timeDimension) |
TimePartition |
FactPartition.getTimePartition() |
static TimePartition |
TimePartition.of(UpdatePeriod updatePeriod,
Date date) |
static TimePartition |
TimePartition.of(UpdatePeriod updatePeriod,
String dateString) |
static TimePartitionRange |
TimePartitionRange.parseFrom(UpdatePeriod updatePeriod,
String from,
String to) |
TimePartitionRange |
TimePartition.rangeFrom(TimePartition from) |
TimePartitionRange |
TimePartition.rangeUpto(TimePartition to) |
TimePartitionRange |
TimePartition.singletonRange() |
TimePartition |
TimePartition.withUpdatePeriod(UpdatePeriod period) |
Constructor and Description |
---|
TimePartitionRange(TimePartition begin,
TimePartition end) |
Modifier and Type | Method and Description |
---|---|
boolean |
StoreAllPartitionTimeline.add(Collection<TimePartition> partitions) |
boolean |
PartitionTimeline.add(Collection<TimePartition> partitions)
Add multiple partitions to timeline
|
boolean |
StoreAllPartitionTimeline.add(TimePartition partition) |
boolean |
RangesPartitionTimeline.add(TimePartition partition) |
abstract boolean |
PartitionTimeline.add(TimePartition partition)
Add partition to timeline
|
boolean |
EndsAndHolesPartitionTimeline.add(TimePartition partition) |
boolean |
RangesPartitionTimeline.add(TimePartitionRange partitionRange) |
boolean |
PartitionTimeline.commitBatchAdditions()
Commit all partitions that were added to batch addition queue.
|
boolean |
StoreAllPartitionTimeline.drop(TimePartition toDrop) |
boolean |
RangesPartitionTimeline.drop(TimePartition toDrop) |
abstract boolean |
PartitionTimeline.drop(TimePartition toDrop)
drop partition.
|
boolean |
EndsAndHolesPartitionTimeline.drop(TimePartition toDrop) |
void |
PartitionTimeline.init(org.apache.hadoop.hive.ql.metadata.Table table)
Extracts timeline implementation class from table params and instantiates it with other arguments, also in table
params.
|
boolean |
StoreAllPartitionTimeline.initFromProperties(Map<String,String> properties) |
boolean |
RangesPartitionTimeline.initFromProperties(Map<String,String> properties) |
abstract boolean |
PartitionTimeline.initFromProperties(Map<String,String> properties)
deserialize member variables from given map
|
boolean |
EndsAndHolesPartitionTimeline.initFromProperties(Map<String,String> properties) |
Modifier and Type | Method and Description |
---|---|
void |
PartitionRangesForPartitionColumns.add(FactPartition part) |
void |
PartitionRangesForPartitionColumns.add(String partCol,
TimePartition partition) |
void |
CubeQueryContext.addOptionalDimTable(String alias,
CandidateTable candidate,
boolean isRequiredInJoin,
String cubeCol,
boolean isRef,
String... cols) |
void |
CubeQueryContext.addOptionalExprDimTable(String dimAlias,
String queriedExpr,
String srcTableAlias,
CandidateTable candidate,
String... cols) |
void |
CubeQueryContext.addOptionalJoinDimTable(String alias,
boolean isRequired) |
boolean |
CubeQueryContext.addQueriedTable(String alias) |
static void |
HQLParser.bft(org.apache.hadoop.hive.ql.parse.ASTNode root,
HQLParser.ASTNodeVisitor visitor)
Breadth first traversal of AST
|
void |
CandidateFact.copyASTs(CubeQueryContext cubeql) |
Set<String> |
CandidateFact.getTimePartCols(CubeQueryContext query) |
String |
TimeRangeWriter.getTimeRangeWhereClause(CubeQueryContext cubeQueryContext,
String tableName,
Set<FactPartition> parts) |
String |
BetweenTimeRangeWriter.getTimeRangeWhereClause(CubeQueryContext cubeQueryContext,
String tableName,
Set<FactPartition> rangeParts) |
String |
AbridgedTimeRangeWriter.getTimeRangeWhereClause(CubeQueryContext cubeQueryContext,
String tableName,
Set<FactPartition> parts)
Return IN clause for the partitions selected in the cube query
|
static org.apache.hadoop.hive.ql.parse.ASTNode |
HQLParser.parseHQL(String query,
org.apache.hadoop.hive.conf.HiveConf conf) |
static String |
DateUtil.relativeToAbsolute(String relative) |
static String |
DateUtil.relativeToAbsolute(String relative,
Date now) |
static Date |
DateUtil.resolveAbsoluteDate(String str) |
static Date |
DateUtil.resolveDate(String str,
Date now) |
static Date |
DateUtil.resolveRelativeDate(String str,
Date now) |
CubeQueryContext |
CubeQueryRewriter.rewrite(org.apache.hadoop.hive.ql.parse.ASTNode astnode) |
CubeQueryContext |
CubeQueryRewriter.rewrite(String command) |
void |
LightestFactResolver.rewriteContext(CubeQueryContext cubeql) |
void |
FieldValidator.rewriteContext(CubeQueryContext cubeql) |
void |
DenormalizationResolver.rewriteContext(CubeQueryContext cubeql)
Find all de-normalized columns, if these columns are not directly available in candidate tables, query will be
replaced with the corresponding table reference
|
Set<Dimension> |
DenormalizationResolver.DenormalizationContext.rewriteDenormctx(CandidateFact cfact,
Map<Dimension,CandidateDim> dimsToQuery,
boolean replaceFact) |
org.apache.hadoop.hive.ql.parse.ASTNode |
CubeQueryContext.toAST(org.apache.hadoop.hive.ql.Context ctx) |
String |
UnionHQLContext.toHQL() |
String |
SimpleHQLContext.toHQL() |
String |
HQLContextInterface.toHQL()
Get the HQL query.
|
String |
CubeQueryContext.toHQL() |
void |
CandidateFact.updateASTs(CubeQueryContext cubeql)
Update the ASTs to include only the fields queried from this fact, in all the expressions
|
void |
CandidateFact.updateTimeranges(CubeQueryContext cubeql) |
void |
TimeRange.validate() |
abstract boolean |
ValidationRule.validate(CubeQueryContext ctx) |
boolean |
CheckTableNames.validate(CubeQueryContext ctx) |
boolean |
CheckColumnMapping.validate(CubeQueryContext ctx) |
void |
FieldValidator.validateFields(CubeQueryContext cubeql) |
void |
HQLParser.ASTNodeVisitor.visit(HQLParser.TreeNode node) |
Constructor and Description |
---|
CubeQueryContext(org.apache.hadoop.hive.ql.parse.ASTNode ast,
org.apache.hadoop.hive.ql.parse.QB qb,
org.apache.hadoop.conf.Configuration queryConf,
org.apache.hadoop.hive.conf.HiveConf metastoreConf) |
Modifier and Type | Method and Description |
---|---|
QueryCost |
FactPartitionBasedQueryCostCalculator.calculateCost(AbstractQueryContext queryContext,
LensDriver driver) |
Modifier and Type | Method and Description |
---|---|
boolean |
ESDriver.cancelQuery(QueryHandle handle) |
void |
ESDriver.close() |
void |
ESDriver.closeQuery(QueryHandle handle) |
void |
ESDriver.closeResultSet(QueryHandle handle)
removing the result set as soon as the fetch is done
|
void |
ESDriver.configure(org.apache.hadoop.conf.Configuration conf) |
LensResultSet |
ESDriver.execute(QueryContext context)
Elastic search does not have a concept of prepared query.
|
DriverQueryPlan |
ESDriver.explain(AbstractQueryContext context) |
DriverQueryPlan |
ESDriver.explainAndPrepare(PreparedQueryContext pContext) |
LensResultSet |
ESDriver.fetchResultSet(QueryContext context) |
void |
ESDriver.prepare(PreparedQueryContext pContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
ESResultSet.seekToStart() |
Modifier and Type | Class and Description |
---|---|
class |
ESClientException |
class |
InvalidQueryException |
Modifier and Type | Method and Description |
---|---|
static ESQuery |
ESVisitor.rewrite(ESDriverConfig config,
org.apache.hadoop.hive.ql.parse.ASTNode rootQueryNode) |
static ESQuery |
ESVisitor.rewrite(ESDriverConfig config,
String hql) |
Modifier and Type | Method and Description |
---|---|
boolean |
HiveDriver.cancelQuery(QueryHandle handle) |
void |
HiveDriver.closePreparedQuery(QueryPrepareHandle handle) |
void |
HiveDriver.closeQuery(QueryHandle handle) |
void |
HiveDriver.closeResultSet(QueryHandle handle) |
void |
HiveDriver.configure(org.apache.hadoop.conf.Configuration conf) |
QueryCost |
HiveDriver.estimate(AbstractQueryContext qctx) |
LensResultSet |
HiveDriver.execute(QueryContext ctx) |
void |
HiveDriver.executeAsync(QueryContext ctx) |
HiveQueryPlan |
HiveDriver.explain(AbstractQueryContext explainCtx) |
DriverQueryPlan |
HiveDriver.explainAndPrepare(PreparedQueryContext pContext) |
LensResultSet |
HiveDriver.fetchResultSet(QueryContext ctx) |
org.apache.hive.service.cli.CLIServiceClient |
ThriftConnection.getClient()
Gets the client.
|
org.apache.hive.service.cli.CLIServiceClient |
RemoteThriftConnection.getClient() |
org.apache.hive.service.cli.thrift.ThriftCLIServiceClient |
EmbeddedThriftConnection.getClient() |
Long |
HivePersistentResultSet.getFileSize() |
LensResultSetMetadata |
HivePersistentResultSet.getMetadata() |
LensResultSetMetadata |
HiveInMemoryResultSet.getMetadata() |
String |
HivePersistentResultSet.getOutputPath() |
boolean |
HiveInMemoryResultSet.hasNext() |
ResultRow |
HiveInMemoryResultSet.next() |
void |
HiveDriver.prepare(PreparedQueryContext pContext) |
void |
HiveDriver.registerForCompletionNotification(QueryHandle handle,
long timeoutMillis,
QueryCompletionListener listener) |
void |
HiveInMemoryResultSet.setFetchSize(int size) |
Integer |
HivePersistentResultSet.size() |
Integer |
HiveInMemoryResultSet.size() |
void |
HiveDriver.updateStatus(QueryContext context) |
Constructor and Description |
---|
HiveDriver()
Instantiates a new hive driver.
|
Modifier and Type | Method and Description |
---|---|
boolean |
JDBCDriver.cancelQuery(QueryHandle handle)
Cancel the execution of the query, specified by the handle.
|
void |
JDBCDriver.close()
Close the driver, releasing all resouces used up by the driver.
|
void |
JDBCDriver.closePreparedQuery(QueryPrepareHandle handle)
Close the prepare query specified by the prepared handle, releases all the resources held by the prepared query.
|
void |
JDBCDriver.closeQuery(QueryHandle handle)
Close the query specified by the handle, releases all the resources held by the query.
|
void |
JDBCDriver.closeResultSet(QueryHandle handle)
Close the resultset for the query.
|
void |
JDBCDriver.configure(org.apache.hadoop.conf.Configuration conf)
Configure driver with
Configuration passed |
QueryCost |
JDBCDriver.estimate(AbstractQueryContext qctx) |
LensResultSet |
JDBCDriver.execute(QueryContext context)
Blocking execute of the query.
|
void |
JDBCDriver.executeAsync(QueryContext context)
Asynchronously execute the query.
|
DriverQueryPlan |
JDBCDriver.explain(AbstractQueryContext explainCtx)
Explain the given query.
|
DriverQueryPlan |
JDBCDriver.explainAndPrepare(PreparedQueryContext pContext)
Explain and prepare the given query.
|
LensResultSet |
JDBCDriver.fetchResultSet(QueryContext context)
Fetch the results of the query, specified by the handle.
|
LensResultSetMetadata |
JDBCResultSet.getMetadata() |
boolean |
JDBCResultSet.hasNext() |
ResultRow |
JDBCResultSet.next() |
void |
JDBCDriver.prepare(PreparedQueryContext pContext)
Prepare the given query.
|
void |
JDBCDriver.registerForCompletionNotification(QueryHandle handle,
long timeoutMillis,
QueryCompletionListener listener)
Register for query completion notification.
|
String |
JDBCDriver.DummyQueryRewriter.rewrite(String query,
org.apache.hadoop.conf.Configuration queryConf,
org.apache.hadoop.hive.conf.HiveConf metastoreConf) |
String |
ColumnarSQLRewriter.rewrite(String query,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hive.conf.HiveConf metastoreConf) |
boolean |
JDBCResultSet.seekToStart() |
void |
JDBCResultSet.setFetchSize(int size) |
Integer |
JDBCResultSet.size() |
void |
JDBCDriver.updateStatus(QueryContext context)
Get status of the query, specified by the handle.
|
void |
JDBCDriver.validate(AbstractQueryContext pContext)
Validate query using prepare
|
Constructor and Description |
---|
JDBCResultSet(org.apache.lens.driver.jdbc.JDBCDriver.QueryResult queryResult,
ResultSet resultSet,
boolean closeAfterFetch)
Instantiates a new JDBC result set.
|
Modifier and Type | Method and Description |
---|---|
MLAlgo |
MLDriver.getAlgoInstance(String algo)
Gets the algo instance.
|
void |
MLDriver.init(LensConf conf)
Inits the.
|
void |
MLDriver.start()
Start.
|
void |
MLDriver.stop()
Stop.
|
MLModel |
MLAlgo.train(LensConf conf,
String db,
String table,
String modelId,
String... params)
Train.
|
Modifier and Type | Method and Description |
---|---|
MLAlgo |
Algorithms.getAlgoForName(String name)
Gets the algo for name.
|
Modifier and Type | Method and Description |
---|---|
void |
SparkMLDriver.checkStarted()
Check started.
|
void |
TableTrainingSpec.createRDDs(org.apache.spark.api.java.JavaSparkContext sparkContext)
Creates the rd ds.
|
MLAlgo |
SparkMLDriver.getAlgoInstance(String name) |
void |
SparkMLDriver.init(LensConf conf) |
void |
SparkMLDriver.start() |
void |
SparkMLDriver.stop() |
MLModel<?> |
BaseSparkAlgo.train(LensConf conf,
String db,
String table,
String modelId,
String... params) |
Modifier and Type | Method and Description |
---|---|
MLModel |
KMeansAlgo.train(LensConf conf,
String db,
String table,
String modelId,
String... params) |
Modifier and Type | Method and Description |
---|---|
void |
LensML.deleteModel(String algorithm,
String modelID)
Permanently delete a model instance.
|
void |
LensML.deleteTestReport(String algorithm,
String reportID)
Permanently delete a test report instance.
|
MLAlgo |
LensML.getAlgoForName(String algorithm)
Get a algo object instance which could be used to generate a model of the given algorithm.
|
MLModel |
LensML.getModel(String algorithm,
String modelId)
Get a model instance given the algorithm name and model ID.
|
List<String> |
LensML.getModels(String algorithm)
Get model IDs for the given algorithm.
|
MLTestReport |
LensML.getTestReport(String algorithm,
String reportID)
Get a test report by ID.
|
List<String> |
LensML.getTestReports(String algorithm)
Get test reports for an algorithm.
|
Object |
LensML.predict(String algorithm,
String modelID,
Object[] features)
Online predict call given a model ID, algorithm name and sample feature values.
|
MLTestReport |
LensML.testModel(LensSessionHandle session,
String table,
String algorithm,
String modelID,
String outputTable)
Evaluate model by running it against test data contained in the given table.
|
String |
LensML.train(String table,
String algorithm,
String[] args)
Create a model using the given HCatalog table as input.
|
Modifier and Type | Method and Description |
---|---|
void |
LensMLImpl.deleteModel(String algorithm,
String modelID) |
void |
LensMLImpl.deleteTestReport(String algorithm,
String reportID) |
MLAlgo |
LensMLImpl.getAlgoForName(String algorithm) |
MLModel |
LensMLImpl.getModel(String algorithm,
String modelId) |
List<String> |
LensMLImpl.getModels(String algorithm) |
MLTestReport |
LensMLImpl.getTestReport(String algorithm,
String reportID) |
List<String> |
LensMLImpl.getTestReports(String algorithm) |
Object |
LensMLImpl.predict(String algorithm,
String modelID,
Object[] features) |
abstract QueryHandle |
QueryRunner.runQuery(String query)
Run query.
|
MLTestReport |
LensMLImpl.testModel(LensSessionHandle sessionHandle,
String table,
String algorithm,
String modelID,
QueryRunner queryRunner,
String outputTable)
Evaluate a model.
|
MLTestReport |
LensMLImpl.testModel(LensSessionHandle session,
String table,
String algorithm,
String modelID,
String outputTable) |
MLTestReport |
LensMLImpl.testModelRemote(LensSessionHandle sessionHandle,
String table,
String algorithm,
String modelID,
String queryApiUrl,
String outputTable)
Test a model in embedded mode.
|
String |
LensMLImpl.train(String table,
String algorithm,
String[] args) |
Modifier and Type | Method and Description |
---|---|
String |
MLServiceResource.deleteModel(String algorithm,
String modelID)
Delete a model given model ID and algorithm name.
|
void |
MLServiceImpl.deleteModel(String algorithm,
String modelID) |
String |
MLServiceResource.deleteTestReport(String algorithm,
String reportID)
DELETE a report given the algorithm name and report ID.
|
void |
MLServiceImpl.deleteTestReport(String algorithm,
String reportID) |
MLAlgo |
MLServiceImpl.getAlgoForName(String algorithm) |
MLModel |
MLServiceImpl.getModel(String algorithm,
String modelId) |
ModelMetadata |
MLServiceResource.getModelMetadata(String algorithm,
String modelID)
Get metadata of the model given algorithm and model ID.
|
List<String> |
MLServiceImpl.getModels(String algorithm) |
StringList |
MLServiceResource.getModelsForAlgo(String algorithm)
Get model ID list for a given algorithm.
|
StringList |
MLServiceResource.getReportsForAlgorithm(String algoritm)
Get list of reports for a given algorithm.
|
TestReport |
MLServiceResource.getTestReport(String algorithm,
String reportID)
Get a single test report given the algorithm name and report id.
|
MLTestReport |
MLServiceImpl.getTestReport(String algorithm,
String reportID) |
List<String> |
MLServiceImpl.getTestReports(String algorithm) |
Object |
MLServiceImpl.predict(String algorithm,
String modelID,
Object[] features) |
String |
MLServiceResource.predict(String algorithm,
String modelID,
javax.ws.rs.core.UriInfo uriInfo)
Predict.
|
String |
MLServiceResource.test(String algorithm,
String modelID,
String table,
LensSessionHandle session,
String outputTable)
Run a test on a model for an algorithm.
|
MLTestReport |
MLServiceImpl.testModel(LensSessionHandle sessionHandle,
String table,
String algorithm,
String modelID,
String outputTable) |
String |
MLServiceResource.train(String algorithm,
javax.ws.rs.core.MultivaluedMap<String,String> form)
Train a model given an algorithm name and algorithm parameters
|
String |
MLServiceImpl.train(String table,
String algorithm,
String[] args) |
Modifier and Type | Method and Description |
---|---|
void |
LensRDDClient.cancelRDD(QueryHandle queryHandle)
Allow cancelling underlying query in case of non blocking RDD creation.
|
LensRDDClient.LensRDDResult |
LensRDDClient.createLensRDD(String query)
Blocking call to create an RDD from a Lens query.
|
void |
LensRDDClient.LensRDDResult.deleteTempTable()
Delete temp table.
|
LensRDDClient.LensRDDResult |
LensRDDClient.getRDD(QueryHandle queryHandle)
Get the RDD created for the query.
|
boolean |
LensRDDClient.isReadyForRDD(QueryHandle queryHandle)
Check if the RDD is created.
|
org.apache.spark.rdd.RDD<List<Object>> |
LensRDDClient.LensRDDResult.recreateRDD(org.apache.spark.api.java.JavaSparkContext sparkContext)
Recreate RDD.
|
Modifier and Type | Method and Description |
---|---|
void |
SessionHelper.addResourcesJar(String path) |
void |
SessionHelper.addResourcesJar(String path,
String sessionHandleString)
Add resources to a session
|
void |
SessionHelper.closeNewSession(String sessionHandleString)
Close a Session
|
void |
ServiceManagerHelper.closeSession() |
void |
MetastoreHelper.createDatabase(String dbName) |
void |
MetastoreHelper.createDatabase(String dbName,
String sessionHandleString)
Create a database
|
void |
QueryHelper.destoryPreparedQueryByHandle(QueryPrepareHandle queryPreparedHandle) |
void |
QueryHelper.destoryPreparedQueryByHandle(QueryPrepareHandle queryPreparedHandle,
String sessionHandleString)
Destroy prepared Query
|
void |
QueryHelper.destroyPreparedQuery() |
void |
QueryHelper.destroyPreparedQuery(String queryName) |
void |
QueryHelper.destroyPreparedQuery(String queryName,
String user) |
void |
QueryHelper.destroyPreparedQuery(String queryName,
String user,
String sessionHandleString) |
void |
QueryHelper.destroyPreparedQuery(String queryName,
String user,
String sessionHandleString,
String fromDate,
String toDate)
Destroy prepared Query
|
void |
MetastoreHelper.dropCube(String cubeName) |
void |
MetastoreHelper.dropCube(String cubeName,
String sessionHandleString) |
void |
MetastoreHelper.dropDatabase(String dbName) |
void |
MetastoreHelper.dropDatabase(String dbName,
String sessionHandleString)
Drop a DB
|
void |
MetastoreHelper.dropStorage(String storageName) |
void |
MetastoreHelper.dropStorage(String storageName,
String sessionHandleString) |
LensAPIResult |
QueryHelper.estimateQuery(String queryString) |
LensAPIResult |
QueryHelper.estimateQuery(String queryString,
String sessionHandleString) |
LensAPIResult |
QueryHelper.estimateQuery(String queryString,
String sessionHandleString,
String conf)
Estimate the query
|
QueryHandle |
QueryHelper.executePreparedQuery(QueryPrepareHandle queryHandle) |
QueryHandle |
QueryHelper.executePreparedQuery(QueryPrepareHandle queryHandle,
String sessionHandleString) |
QueryHandle |
QueryHelper.executePreparedQuery(QueryPrepareHandle queryHandle,
String sessionHandleString,
String conf)
Execute prepared Query
|
QueryHandleWithResultSet |
QueryHelper.executePreparedQueryTimeout(QueryPrepareHandle queryHandle) |
QueryHandleWithResultSet |
QueryHelper.executePreparedQueryTimeout(QueryPrepareHandle queryHandle,
String timeout) |
QueryHandleWithResultSet |
QueryHelper.executePreparedQueryTimeout(QueryPrepareHandle queryHandle,
String timeout,
String sessionHandleString) |
QueryHandleWithResultSet |
QueryHelper.executePreparedQueryTimeout(QueryPrepareHandle queryHandle,
String timeout,
String sessionHandleString,
String conf)
Execute prepared Query with timeout
|
LensAPIResult |
QueryHelper.executeQuery(String queryString) |
LensAPIResult |
QueryHelper.executeQuery(String queryString,
String queryName) |
LensAPIResult |
QueryHelper.executeQuery(String queryString,
String queryName,
String sessionHandleString) |
LensAPIResult |
QueryHelper.executeQuery(String queryString,
String queryName,
String sessionHandleString,
String conf)
Execute with conf
|
LensAPIResult |
QueryHelper.executeQuery(String queryString,
String queryName,
String user,
String sessionHandleString,
LensConf conf)
Execute the query
|
LensAPIResult |
QueryHelper.executeQueryTimeout(String queryString) |
LensAPIResult |
QueryHelper.executeQueryTimeout(String queryString,
String timeout) |
LensAPIResult |
QueryHelper.executeQueryTimeout(String queryString,
String timeout,
String queryName) |
LensAPIResult |
QueryHelper.executeQueryTimeout(String queryString,
String timeout,
String queryName,
String sessionHandleString) |
LensAPIResult |
QueryHelper.executeQueryTimeout(String queryString,
String timeout,
String queryName,
String sessionHandleString,
String conf)
Execute with timeout
|
QueryPlan |
QueryHelper.explainAndPrepareQuery(String queryString) |
QueryPlan |
QueryHelper.explainAndPrepareQuery(String queryString,
String sessionHandleString) |
QueryPlan |
QueryHelper.explainAndPrepareQuery(String queryString,
String sessionHandleString,
String conf)
Prepare and Explain the query
|
LensAPIResult |
QueryHelper.explainQuery(String queryString) |
LensAPIResult |
QueryHelper.explainQuery(String queryString,
String sessionHandleString) |
LensAPIResult |
QueryHelper.explainQuery(String queryString,
String sessionHandleString,
String conf)
Explain the query
|
XCube |
MetastoreHelper.getCube(String cubeName) |
XCube |
MetastoreHelper.getCube(String cubeName,
String sessionHandleString) |
String |
MetastoreHelper.getCurrentDatabase() |
String |
MetastoreHelper.getCurrentDatabase(String sessionHandleString)
Get Current Database for a Session
|
XDimension |
MetastoreHelper.getDimension(String dimName) |
XDimension |
MetastoreHelper.getDimension(String dimName,
String sessionHandleString) |
XDimensionTable |
MetastoreHelper.getDimensionTable(String dimName) |
XDimensionTable |
MetastoreHelper.getDimensionTable(String dimName,
String sessionHandleString) |
XFactTable |
MetastoreHelper.getFact(String factName) |
XFactTable |
MetastoreHelper.getFact(String factName,
String sessionHandleString) |
QueryResult |
QueryHelper.getHttpResultSet(QueryHandle queryHandle)
Get the HTTP result set
|
QueryStatus |
QueryHelper.getQueryStatus(QueryHandle queryHandle) |
QueryStatus |
QueryHelper.getQueryStatus(String sessionHandleString,
QueryHandle queryHandle)
Get Query Status
|
QueryResult |
QueryHelper.getResultSet(QueryHandle queryHandle) |
QueryResult |
QueryHelper.getResultSet(QueryHandle queryHandle,
String fromIndex,
String fetchSize) |
QueryResult |
QueryHelper.getResultSet(QueryHandle queryHandle,
String fromIndex,
String fetchSize,
String sessionHandleString)
Get the Result set
|
void |
QueryHelper.killQuery() |
void |
QueryHelper.killQuery(String queryName) |
void |
QueryHelper.killQuery(String queryName,
String state) |
void |
QueryHelper.killQuery(String queryName,
String state,
String user) |
void |
QueryHelper.killQuery(String queryName,
String state,
String user,
String sessionHandleString) |
void |
QueryHelper.killQuery(String queryName,
String state,
String user,
String sessionHandleString,
String fromDate,
String toDate)
Kill Query
|
void |
QueryHelper.killQueryByQueryHandle(QueryHandle queryHandle) |
void |
QueryHelper.killQueryByQueryHandle(String sessionHandleString,
QueryHandle queryHandle)
Kill Query by QueryHandle
|
StringList |
MetastoreHelper.listDatabases() |
StringList |
MetastoreHelper.listDatabases(String sessionHandleString)
Get list of databases
|
StringList |
MetastoreHelper.listStorages() |
StringList |
MetastoreHelper.listStorages(String sessionHandleString) |
String |
SessionHelper.openNewSession(String userName,
String password) |
String |
SessionHelper.openNewSession(String userName,
String password,
String database)
Open a New Session
|
String |
ServiceManagerHelper.openSession() |
String |
ServiceManagerHelper.openSession(String database) |
void |
SessionHelper.removeResourcesJar(String path) |
void |
SessionHelper.removeResourcesJar(String path,
String sessionHandleString)
Remove resources from a session
|
void |
LensServerHelper.restart()
Restart Lens server
|
void |
MetastoreHelper.setCurrentDatabase(String currentDBName) |
void |
MetastoreHelper.setCurrentDatabase(String sessionHandleString,
String currentDBName)
Set Current Database for a Session
|
QueryPrepareHandle |
QueryHelper.submitPreparedQuery(String queryString) |
QueryPrepareHandle |
QueryHelper.submitPreparedQuery(String queryString,
String queryName) |
QueryPrepareHandle |
QueryHelper.submitPreparedQuery(String queryString,
String queryName,
String sessionHandleString) |
QueryPrepareHandle |
QueryHelper.submitPreparedQuery(String queryString,
String queryName,
String sessionHandleString,
String conf)
Submit prepared Query
|
LensQuery |
QueryHelper.waitForCompletion(QueryHandle queryHandle) |
LensQuery |
QueryHelper.waitForCompletion(String sessionHandleString,
QueryHandle queryHandle)
Wait for Completion
|
QueryStatus |
QueryHelper.waitForQueryToRun(QueryHandle queryHandle) |
QueryStatus |
QueryHelper.waitForQueryToRun(QueryHandle queryHandle,
String sessionHandleString)
Wait for Query to run
|
Modifier and Type | Method and Description |
---|---|
static void |
AssertUtil.assertFailed(javax.ws.rs.core.Response response)
Checks that Response status is status FAILED with status code 400
|
static void |
AssertUtil.assertFailedResponse(javax.ws.rs.core.Response response)
Checks that Response status is NOT FOUND
|
static void |
AssertUtil.assertGoneResponse(javax.ws.rs.core.Response response) |
static void |
AssertUtil.assertInternalServerError(javax.ws.rs.core.Response response)
Checks that Response status is status FAILED with status code 500
|
static void |
AssertUtil.assertStatusFailed(javax.ws.rs.core.Response response)
Checks that Response status is status FAILED with status code 200
|
static void |
AssertUtil.assertSucceeded(javax.ws.rs.core.Response response)
Checks that Response status is SUCCEEDED
|
static void |
AssertUtil.assertSucceededResponse(javax.ws.rs.core.Response response)
Checks that Response status is SUCCEEDED
|
static void |
AssertUtil.assertSucceededResponse(javax.ws.rs.core.Response response,
int expected) |
static void |
AssertUtil.validateFailedResponse(int errorCode,
String errorMessage,
boolean payLoad,
javax.ws.rs.core.Response response,
int httpResponseCode) |
Modifier and Type | Method and Description |
---|---|
void |
BaseLensService.addResource(LensSessionHandle sessionHandle,
String type,
String path)
Adds the resource.
|
void |
BaseLensService.closeSession(LensSessionHandle sessionHandle)
Close session.
|
void |
BaseLensService.deleteResource(LensSessionHandle sessionHandle,
String type,
String path)
Delete resource.
|
org.apache.hadoop.conf.Configuration |
BaseLensService.getLensConf(LensConf conf)
Gets the lens conf.
|
org.apache.hadoop.conf.Configuration |
BaseLensService.getLensConf(LensSessionHandle sessionHandle,
LensConf conf)
Gets the lens conf.
|
void |
EventServiceImpl.notifyEvent(LensEvent evt) |
LensSessionHandle |
BaseLensService.openSession(String username,
String password,
Map<String,String> configuration)
Open session.
|
void |
BaseLensService.release(String sessionHandle)
Releases a lens session specified by the public UUID.
|
void |
BaseLensService.restoreSession(LensSessionHandle sessionHandle,
String userName,
String password)
Restore session from previous instance of lens server.
|
Modifier and Type | Method and Description |
---|---|
boolean |
LensDriver.cancelQuery(QueryHandle handle)
Cancel the execution of the query, specified by the handle.
|
void |
LensDriver.close()
Close the driver, releasing all resouces used up by the driver.
|
void |
LensDriver.closePreparedQuery(QueryPrepareHandle handle)
Close the prepare query specified by the prepared handle, releases all the resources held by the prepared query.
|
void |
LensDriver.closeQuery(QueryHandle handle)
Close the query specified by the handle, releases all the resources held by the query.
|
void |
LensDriver.closeResultSet(QueryHandle handle)
Close the resultset for the query.
|
void |
LensDriver.configure(org.apache.hadoop.conf.Configuration conf)
Configure driver with
Configuration passed. |
QueryCost |
LensDriver.estimate(AbstractQueryContext qctx)
Estimate the cost of execution for given query.
|
LensResultSet |
LensDriver.execute(QueryContext context)
Blocking execute of the query
|
void |
LensDriver.executeAsync(QueryContext context)
Asynchronously execute the query.
|
DriverQueryPlan |
LensDriver.explain(AbstractQueryContext explainCtx)
Explain the given query.
|
DriverQueryPlan |
LensDriver.explainAndPrepare(PreparedQueryContext pContext)
Explain and prepare the given query.
|
LensResultSet |
LensDriver.fetchResultSet(QueryContext context)
Fetch the results of the query, specified by the handle.
|
abstract Long |
PersistentResultSet.getFileSize()
Get the size of the result set file.
|
abstract LensResultSetMetadata |
LensResultSet.getMetadata()
Get the result set metadata
|
abstract String |
LensResultSet.getOutputPath() |
String |
InMemoryResultSet.getOutputPath() |
abstract boolean |
InMemoryResultSet.hasNext()
Whether there is another result row available.
|
boolean |
PersistentResultSet.isHttpResultAvailable() |
abstract boolean |
LensResultSet.isHttpResultAvailable() |
boolean |
InMemoryResultSet.isHttpResultAvailable() |
abstract ResultRow |
InMemoryResultSet.next()
Read the next result row.
|
void |
LensDriver.prepare(PreparedQueryContext pContext)
Prepare the given query.
|
void |
LensDriver.registerForCompletionNotification(QueryHandle handle,
long timeoutMillis,
QueryCompletionListener listener)
Register for query completion notification.
|
abstract boolean |
InMemoryResultSet.seekToStart() |
abstract void |
InMemoryResultSet.setFetchSize(int size)
Set number of rows to be fetched at time
|
abstract Integer |
LensResultSet.size()
Get the size of the result set.
|
PersistentQueryResult |
PersistentResultSet.toQueryResult() |
abstract QueryResult |
LensResultSet.toQueryResult()
Get the corresponding query result object.
|
InMemoryQueryResult |
InMemoryResultSet.toQueryResult() |
void |
LensDriver.updateStatus(QueryContext context)
Update driver query status in the context object.
|
Modifier and Type | Class and Description |
---|---|
class |
LensMultiCauseException
Thrown when there are more than one independent failures in the same computation.
|
Modifier and Type | Method and Description |
---|---|
static LensException |
LensMultiCauseException.getAppropriateError(com.google.common.collect.ImmutableList<LensException> excpList) |
static LensException |
LensException.wrap(Exception e) |
Modifier and Type | Method and Description |
---|---|
int |
LensException.compareTo(LensException e) |
Modifier and Type | Method and Description |
---|---|
static LensException |
LensMultiCauseException.getAppropriateError(com.google.common.collect.ImmutableList<LensException> excpList) |
Constructor and Description |
---|
LensException(LensException e)
Copy Constructor
|
Constructor and Description |
---|
LensMultiCauseException(com.google.common.collect.ImmutableList<LensException> excpList) |
Modifier and Type | Method and Description |
---|---|
void |
LensEventService.notifyEvent(LensEvent event)
Process an event, and notify all listeners interested in this event.
|
void |
LensEventListener.onEvent(T event)
On event.
|
void |
AsyncEventListener.onEvent(T event)
Creates a new runnable and calls the process method in it.
|
Modifier and Type | Method and Description |
---|---|
void |
CubeMetastoreService.addDimTableStorage(LensSessionHandle sessionid,
String dimTblName,
XStorageTableElement storageTable)
Add a storage to dimension table
|
int |
CubeMetastoreService.addPartitionsToDimStorage(LensSessionHandle sessionid,
String dimTblName,
String storageName,
XPartitionList partitions)
Add partitions to dimension table on a storage.
|
int |
CubeMetastoreService.addPartitionsToFactStorage(LensSessionHandle sessionid,
String fact,
String storageName,
XPartitionList partitions)
Add partitions to fact on a storage
|
int |
CubeMetastoreService.addPartitionToDimStorage(LensSessionHandle sessionid,
String dimTblName,
String storageName,
XPartition partition)
Add partition to dimension table on a storage.
|
int |
CubeMetastoreService.addPartitionToFactStorage(LensSessionHandle sessionid,
String fact,
String storageName,
XPartition partition)
Add partition to fact on a storage
|
void |
CubeMetastoreService.addStorageToFact(LensSessionHandle sessionid,
String fact,
XStorageTableElement storageTable)
Add storage to fact table
|
void |
CubeMetastoreService.alterStorage(LensSessionHandle sessionid,
String storageName,
XStorage storage)
Alter storage specified by name, with new definition
|
void |
CubeMetastoreService.createCube(LensSessionHandle sessionid,
XCube cube)
Create a cube based on JAXB Cube object
|
void |
CubeMetastoreService.createDatabase(LensSessionHandle sessionid,
String database,
boolean ignore)
Create a database in the metastore
|
void |
CubeMetastoreService.createDimension(LensSessionHandle sessionid,
XDimension dimension)
Create a dimension based on JAXB Dimension object
|
void |
CubeMetastoreService.createDimensionTable(LensSessionHandle sessionid,
XDimensionTable xDimTable)
Create dimension table
|
void |
CubeMetastoreService.createFactTable(LensSessionHandle sessionid,
XFactTable fact)
Create fact table
|
void |
CubeMetastoreService.createStorage(LensSessionHandle sessionid,
XStorage storage)
Create a storage
|
void |
CubeMetastoreService.dropAllStoragesOfDimTable(LensSessionHandle sessionid,
String dimTblName)
Drop all storages of dimension table.
|
void |
CubeMetastoreService.dropAllStoragesOfFact(LensSessionHandle sessionid,
String factName)
Drop all storages of fact
|
void |
CubeMetastoreService.dropCube(LensSessionHandle sessionid,
String cubeName)
Drop a cube from the metastore in the currently deleted database.
|
void |
CubeMetastoreService.dropDatabase(LensSessionHandle sessionid,
String database,
boolean cascade)
Drop a database from cube metastore
|
void |
CubeMetastoreService.dropDimension(LensSessionHandle sessionid,
String dimName)
Drop a dimension from the metastore in the currently deleted database.
|
void |
CubeMetastoreService.dropDimensionTable(LensSessionHandle sessionid,
String dimTblName,
boolean cascade)
Drop a dimension table from the cube metastore
|
void |
CubeMetastoreService.dropFactTable(LensSessionHandle sessionid,
String fact,
boolean cascade)
Drop fact table.
|
void |
CubeMetastoreService.dropPartitionFromStorageByFilter(LensSessionHandle sessionid,
String cubeTableName,
String storageName,
String filter)
Drop partition from storage with spec specified by filter
|
void |
CubeMetastoreService.dropPartitionFromStorageByValues(LensSessionHandle sessionid,
String cubeTableName,
String storageName,
String values)
Drop partition from storage with spec specified as comma separated string
|
void |
CubeMetastoreService.dropStorage(LensSessionHandle sessionid,
String storageName)
Drop a storage specified by name
|
void |
CubeMetastoreService.dropStorageOfDimTable(LensSessionHandle sessionid,
String dimTblName,
String storage)
Drop storage of dimension table specified by name.
|
void |
CubeMetastoreService.dropStorageOfFact(LensSessionHandle sessionid,
String fact,
String storage)
Drop storage of fact specified by fact name, storage name
|
List<String> |
CubeMetastoreService.getAllBaseCubeNames(LensSessionHandle sessionid)
Get names of all base cube names in the current database
|
List<String> |
CubeMetastoreService.getAllCubeNames(LensSessionHandle sessionid)
Get names of all cubes in the current database, includes both base cubes and derived cubes
|
List<String> |
CubeMetastoreService.getAllDatabases(LensSessionHandle sessionid)
Get names of all databases in this metastore
|
List<String> |
CubeMetastoreService.getAllDerivedCubeNames(LensSessionHandle sessionid)
Get names of all derived cubes in the current database
|
List<String> |
CubeMetastoreService.getAllDimensionNames(LensSessionHandle sessionid)
Get all dimension names in the current session
|
List<String> |
CubeMetastoreService.getAllDimTableNames(LensSessionHandle sessionid,
String dimensionName)
Get all dimension tables.
|
List<String> |
CubeMetastoreService.getAllFactNames(LensSessionHandle sessionid,
String cubeName)
Get all fact names
|
XJoinChains |
CubeMetastoreService.getAllJoinChains(LensSessionHandle sessionid,
String table) |
List<String> |
CubeMetastoreService.getAllNativeTableNames(LensSessionHandle sessionid,
String dboption,
String dbName)
Get names of all native tables
|
XPartitionList |
CubeMetastoreService.getAllPartitionsOfDimTableStorage(LensSessionHandle sessionid,
String dimension,
String storageName,
String filter)
Get all partitions of a dimension table in a storage
|
XPartitionList |
CubeMetastoreService.getAllPartitionsOfFactStorage(LensSessionHandle sessionid,
String fact,
String storageName,
String filter)
Get all partitions of fact on a storage
|
List<String> |
CubeMetastoreService.getAllQueryableCubeNames(LensSessionHandle sessionid)
Get names of all cubes, which can be queried in the current database
|
List<String> |
CubeMetastoreService.getAllStorageNames(LensSessionHandle sessionid)
Get all storage names in current database
|
XCube |
CubeMetastoreService.getCube(LensSessionHandle sessionid,
String cubeName)
Get a cube from the metastore
|
String |
CubeMetastoreService.getCurrentDatabase(LensSessionHandle sessionid)
Get current database used by the CubeMetastoreClient
|
XDimension |
CubeMetastoreService.getDimension(LensSessionHandle sessionid,
String dimName)
Get a dimension from the metastore
|
XDimensionTable |
CubeMetastoreService.getDimensionTable(LensSessionHandle sessionid,
String dimTblName)
Get the dimension table from metastore
|
List<String> |
CubeMetastoreService.getDimTableStorages(LensSessionHandle sessionid,
String dimTblName)
Get all storages of dimension table
|
XFactTable |
CubeMetastoreService.getFactTable(LensSessionHandle sessionid,
String fact)
Get fact table given by name
|
XFlattenedColumns |
CubeMetastoreService.getFlattenedColumns(LensSessionHandle sessionHandle,
String tableName,
boolean addChains)
Get flattened columns - all columns of table + all reachable columns
|
Date |
CubeMetastoreService.getLatestDateOfCube(LensSessionHandle sessionid,
String cubeName,
String timeDimension)
Get the latest available date upto which data is available for the base cubes, for the time dimension
|
XNativeTable |
CubeMetastoreService.getNativeTable(LensSessionHandle sessionid,
String name)
Get native table for the given name
|
List<String> |
CubeMetastoreService.getPartitionTimelines(LensSessionHandle sessionid,
String factName,
String storage,
String updatePeriod,
String timeDimension) |
XStorage |
CubeMetastoreService.getStorage(LensSessionHandle sessionid,
String storageName)
Get Storage specified by name
|
XStorageTableElement |
CubeMetastoreService.getStorageOfDim(LensSessionHandle sessionid,
String dimTblName,
String storageName)
Get storage table element associated with dimension table for storage name specified
|
XStorageTableElement |
CubeMetastoreService.getStorageOfFact(LensSessionHandle sessionid,
String fact,
String storageName)
Get storage table of fact specifed by fact name, storage name
|
List<String> |
CubeMetastoreService.getStoragesOfFact(LensSessionHandle sessionid,
String fact)
Get all storages of fact
|
void |
CubeMetastoreService.setCurrentDatabase(LensSessionHandle sessionid,
String database)
Change the current database used by the CubeMetastoreClient
|
void |
CubeMetastoreService.updateCube(LensSessionHandle sessionid,
XCube cube)
Update an existing cube
|
void |
CubeMetastoreService.updateDimension(LensSessionHandle sessionid,
String dimName,
XDimension dimension)
Update an existing dimension
|
void |
CubeMetastoreService.updateDimensionTable(LensSessionHandle sessionid,
XDimensionTable dimensionTable)
Update/Alter the dimension table
|
void |
CubeMetastoreService.updateFactTable(LensSessionHandle sessionid,
XFactTable fact)
Update/Alter fact table
|
void |
CubeMetastoreService.updatePartition(LensSessionHandle sessionid,
String tblName,
String storageName,
XPartition partition) |
void |
CubeMetastoreService.updatePartitions(LensSessionHandle sessionid,
String tblName,
String storageName,
XPartitionList partitions) |
Modifier and Type | Method and Description |
---|---|
LensException |
AbstractQueryContext.DriverEstimateRunnable.getCause() |
Modifier and Type | Method and Description |
---|---|
String |
QueryAcceptor.accept(String query,
org.apache.hadoop.conf.Configuration conf,
SubmitOp submitOp)
Whether to accept the query or not.
|
boolean |
QueryExecutionService.cancelQuery(LensSessionHandle sessionHandle,
QueryHandle queryHandle)
Cancel the execution of the query, specified by the handle.
|
void |
QueryExecutionService.closeResultSet(LensSessionHandle sessionHandle,
QueryHandle queryHandle)
Closes result set by releasing any resources used in serving the resultset.
|
boolean |
QueryExecutionService.destroyPrepared(LensSessionHandle sessionHandle,
QueryPrepareHandle prepared)
Destroy a prepared query.
|
QueryCost |
QueryExecutionService.estimate(String requestId,
LensSessionHandle sessionHandle,
String query,
LensConf conf)
Estimate the cost of given query.
|
void |
AbstractQueryContext.estimateCostForDrivers()
Estimate cost for each driver and set in context
|
QueryHandleWithResultSet |
QueryExecutionService.execute(LensSessionHandle sessionHandle,
String query,
long timeoutmillis,
LensConf conf,
String queryName)
Execute the query with a timeout.
|
QueryHandle |
QueryExecutionService.executeAsync(LensSessionHandle sessionHandle,
String query,
LensConf conf,
String queryName)
Asynchronously execute the query.
|
QueryHandleWithResultSet |
QueryExecutionService.executePrepare(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle,
long timeoutmillis,
LensConf conf,
String queryName)
Execute already prepared query with timeout.
|
QueryHandle |
QueryExecutionService.executePrepareAsync(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle,
LensConf conf,
String queryName)
Execute already prepared query asynchronously.
|
QueryPlan |
QueryExecutionService.explain(String requestId,
LensSessionHandle sessionHandle,
String query,
LensConf conf)
Explain the given query.
|
QueryPlan |
QueryExecutionService.explainAndPrepare(LensSessionHandle sessionHandle,
String query,
LensConf conf,
String queryName)
Explain the given query and prepare it as well.
|
QueryResult |
QueryExecutionService.fetchResultSet(LensSessionHandle sessionHandle,
QueryHandle queryHandle,
long startIndex,
int fetchSize)
Fetch the results of the query, specified by the handle.
|
List<QueryPrepareHandle> |
QueryExecutionService.getAllPreparedQueries(LensSessionHandle sessionHandle,
String user,
String queryName,
long fromDate,
long toDate)
Returns all the prepared queries for the specified user.
|
List<QueryHandle> |
QueryExecutionService.getAllQueries(LensSessionHandle sessionHandle,
String state,
String user,
String queryName,
long fromDate,
long toDate)
Returns all the queries in the specified state, for the given user and matching query name.
|
Map<LensDriver,AbstractQueryContext.DriverEstimateRunnable> |
AbstractQueryContext.getDriverEstimateRunnables()
Get runnables wrapping estimate computation, which could be processed offline
|
javax.ws.rs.core.Response |
QueryExecutionService.getHttpResultSet(LensSessionHandle sessionHandle,
QueryHandle queryHandle)
Get the http end point for the result set.
|
LensPreparedQuery |
QueryExecutionService.getPreparedQuery(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle)
Get prepared query.
|
LensQuery |
QueryExecutionService.getQuery(LensSessionHandle sessionHandle,
QueryHandle queryHandle)
Get the query, specified by the handle.
|
QueryResultSetMetadata |
QueryExecutionService.getResultSetMetadata(LensSessionHandle sessionHandle,
QueryHandle queryHandle)
Get the result set metadata - list of columns(names and types) and result size.
|
DriverQueryPlan |
DriverSelectorQueryContext.getSelectedDriverQueryPlan()
Return selected driver's query plan, but check for null conditions first.
|
DriverQueryPlan |
AbstractQueryContext.getSelectedDriverQueryPlan()
Wrapper method for convenience on driver context
|
QueryPrepareHandle |
QueryExecutionService.prepare(LensSessionHandle sessionHandle,
String query,
LensConf conf,
String queryName)
Prepare the query.
|
void |
AbstractQueryContext.setDriverQueries(Map<LensDriver,String> driverQueries)
Set driver queries
|
void |
DriverSelectorQueryContext.setDriverQueryPlans(Map<LensDriver,String> driverQueries,
AbstractQueryContext qctx)
Sets driver queries, generates plans for each driver by calling explain with respective queries,
Sets driverQueryPlans
|
void |
QueryContext.setStatus(QueryStatus newStatus) |
boolean |
QueryExecutionService.updateQueryConf(LensSessionHandle sessionHandle,
QueryHandle queryHandle,
LensConf newconf)
Update the query conf.
|
boolean |
QueryExecutionService.updateQueryConf(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle,
LensConf newconf)
Update configuration for prepared query.
|
void |
QueryContext.validateTransition(QueryStatus newStatus) |
Modifier and Type | Method and Description |
---|---|
QueryCost |
QueryCostCalculator.calculateCost(AbstractQueryContext queryContext,
LensDriver driver) |
Modifier and Type | Method and Description |
---|---|
Priority |
QueryPriorityDecider.decidePriority(QueryCost cost) |
Priority |
CostRangePriorityDecider.decidePriority(QueryCost cost) |
Modifier and Type | Method and Description |
---|---|
String |
QueryRewriter.rewrite(String query,
org.apache.hadoop.conf.Configuration queryConf,
org.apache.hadoop.hive.conf.HiveConf metastoreConf)
Rewrite.
|
Modifier and Type | Method and Description |
---|---|
void |
SavedQueryService.delete(long id)
Deletes the saved query specified.
|
SavedQuery |
SavedQueryService.get(long id)
Returns the saved query pointed out by the id.
|
static String |
SavedQueryHelper.getSampleResolvedQuery(SavedQuery savedQuery)
Gets a sample query for saved query by auto resolving the parameters
|
void |
SavedQueryService.grant(long id,
String sharingUser,
String targetUserPath,
String[] privileges)
Grant permissions for users to do actions on the saved query.
|
ListResponse |
SavedQueryService.list(javax.ws.rs.core.MultivaluedMap<String,String> criteria,
long start,
long count)
List the saved query from {start} to {count} matching filter denoted by criteria.
|
void |
SavedQueryService.revoke(long id,
String sharingUser,
String targetUserPath,
String[] privileges)
Revoke permissions from users to do actions on the saved query.
|
long |
SavedQueryService.save(SavedQuery query)
Saves a query
|
void |
SavedQueryService.update(long id,
SavedQuery query)
Updates the specified saved query with the new object.
|
Modifier and Type | Class and Description |
---|---|
class |
MissingParameterException
The class MissingParameterException.
|
class |
ParameterCollectionException
The class ParameterCollectionException.
|
class |
ParameterValueException
The class ParameterValueException.
|
class |
PrivilegeException
The class PrivilegeException.
|
class |
SavedQueryNotFound
The class SavedQueryNotFound.
|
class |
ValueEncodeException
The class ValueEncodeException.
|
Modifier and Type | Method and Description |
---|---|
void |
SessionService.closeSession(LensSessionHandle sessionHandle)
Close session.
|
List<String> |
SessionService.getAllSessionParameters(LensSessionHandle sessionHandle,
boolean verbose,
String key)
Gets the all session parameters.
|
LensSessionHandle |
SessionService.openSession(String username,
String password,
String database,
Map<String,String> configuration)
Open session.
|
void |
SessionService.restoreSession(LensSessionHandle sessionHandle,
String userName,
String password)
Restore session from previous instance of lens server.
|
Modifier and Type | Class and Description |
---|---|
class |
UnSupportedQuerySubmitOpException |
Modifier and Type | Method and Description |
---|---|
javax.ws.rs.core.Response |
LensExceptionMapper.toResponse(LensException exception) |
Modifier and Type | Method and Description |
---|---|
void |
CubeMetastoreServiceImpl.addDimTableStorage(LensSessionHandle sessionid,
String dimTblName,
XStorageTableElement storageTable) |
int |
CubeMetastoreServiceImpl.addPartitionsToDimStorage(LensSessionHandle sessionid,
String dimTblName,
String storageName,
XPartitionList partitions) |
int |
CubeMetastoreServiceImpl.addPartitionsToFactStorage(LensSessionHandle sessionid,
String fact,
String storageName,
XPartitionList partitions) |
int |
CubeMetastoreServiceImpl.addPartitionToDimStorage(LensSessionHandle sessionid,
String dimTblName,
String storageName,
XPartition partition) |
int |
CubeMetastoreServiceImpl.addPartitionToFactStorage(LensSessionHandle sessionid,
String fact,
String storageName,
XPartition partition) |
void |
CubeMetastoreServiceImpl.addStorageToFact(LensSessionHandle sessionid,
String fact,
XStorageTableElement storageTable) |
void |
CubeMetastoreServiceImpl.alterStorage(LensSessionHandle sessionid,
String storageName,
XStorage storage) |
void |
CubeMetastoreServiceImpl.createCube(LensSessionHandle sessionid,
XCube cube)
Create cube based on the JAXB cube object
|
void |
CubeMetastoreServiceImpl.createDatabase(LensSessionHandle sessionid,
String database,
boolean ignore)
Create a database in Hive metastore
|
void |
CubeMetastoreServiceImpl.createDimension(LensSessionHandle sessionid,
XDimension dimension) |
void |
CubeMetastoreServiceImpl.createDimensionTable(LensSessionHandle sessionid,
XDimensionTable xDimTable)
Create a cube dimension table based on JAXB object
|
APIResult |
MetastoreResource.createFactTable(LensSessionHandle sessionid,
XFactTable fact)
Create a new fact tabble
|
void |
CubeMetastoreServiceImpl.createFactTable(LensSessionHandle sessionid,
XFactTable fact) |
void |
CubeMetastoreServiceImpl.createStorage(LensSessionHandle sessionid,
XStorage storage) |
void |
CubeMetastoreServiceImpl.dropAllStoragesOfDimTable(LensSessionHandle sessionid,
String dimTblName) |
void |
CubeMetastoreServiceImpl.dropAllStoragesOfFact(LensSessionHandle sessionid,
String factName) |
void |
CubeMetastoreServiceImpl.dropCube(LensSessionHandle sessionid,
String cubeName)
Drop a cube from the metastore in the currently deleted database
|
void |
CubeMetastoreServiceImpl.dropDatabase(LensSessionHandle sessionid,
String database,
boolean cascade)
Drop a database from cube metastore
|
void |
CubeMetastoreServiceImpl.dropDimension(LensSessionHandle sessionid,
String dimName) |
void |
CubeMetastoreServiceImpl.dropDimensionTable(LensSessionHandle sessionid,
String dimTblName,
boolean cascade) |
APIResult |
MetastoreResource.dropFactTable(LensSessionHandle sessionid,
String factName,
boolean cascade)
Drop the fact table, specified by name
|
void |
CubeMetastoreServiceImpl.dropFactTable(LensSessionHandle sessionid,
String fact,
boolean cascade) |
void |
CubeMetastoreServiceImpl.dropPartitionFromStorageByFilter(LensSessionHandle sessionid,
String cubeTableName,
String storageName,
String filter) |
void |
CubeMetastoreServiceImpl.dropPartitionFromStorageByValues(LensSessionHandle sessionid,
String cubeTableName,
String storageName,
String values) |
void |
CubeMetastoreServiceImpl.dropStorage(LensSessionHandle sessionid,
String storageName) |
void |
CubeMetastoreServiceImpl.dropStorageOfDimTable(LensSessionHandle sessionid,
String dimTblName,
String storage) |
void |
CubeMetastoreServiceImpl.dropStorageOfFact(LensSessionHandle sessionid,
String fact,
String storage) |
List<String> |
CubeMetastoreServiceImpl.getAllBaseCubeNames(LensSessionHandle sessionid) |
List<String> |
CubeMetastoreServiceImpl.getAllCubeNames(LensSessionHandle sessionid)
Get list of all cubes names in the current database
|
List<String> |
CubeMetastoreServiceImpl.getAllDatabases(LensSessionHandle sessionid) |
List<String> |
CubeMetastoreServiceImpl.getAllDerivedCubeNames(LensSessionHandle sessionid) |
List<String> |
CubeMetastoreServiceImpl.getAllDimensionNames(LensSessionHandle sessionid) |
StringList |
MetastoreResource.getAllDimensionTablesOfDimension(LensSessionHandle sessionid,
String dimensionName)
Get all dimtables that belong to a dimension in the metastore
|
StringList |
MetastoreResource.getAllDims(LensSessionHandle sessionid)
Get all dimension tables in the metastore
|
List<String> |
CubeMetastoreServiceImpl.getAllDimTableNames(LensSessionHandle sessionid,
String dimensionName) |
List<String> |
CubeMetastoreServiceImpl.getAllFactNames(LensSessionHandle sessionid,
String cubeName) |
StringList |
MetastoreResource.getAllFacts(LensSessionHandle sessionid)
Get all fact tables in the metastore in the current database
|
StringList |
MetastoreResource.getAllFactsOfCube(LensSessionHandle sessionid,
String cubeName)
Get all facts that belong to a cube in the metastore
|
JAXBElement<XJoinChains> |
MetastoreResource.getAllJoinChains(LensSessionHandle sessionid,
String tableName)
Get all chains that belong to a table(cube or dimension) in the metastore
|
XJoinChains |
CubeMetastoreServiceImpl.getAllJoinChains(LensSessionHandle sessionHandle,
String tableName) |
List<String> |
CubeMetastoreServiceImpl.getAllNativeTableNames(LensSessionHandle sessionid,
String dbOption,
String dbName) |
JAXBElement<XPartitionList> |
MetastoreResource.getAllPartitionsOfDimStorage(LensSessionHandle sessionid,
String dimension,
String storage,
String filter)
Get all partition of the dimension table in the specified storage; can be filtered
|
XPartitionList |
CubeMetastoreServiceImpl.getAllPartitionsOfDimTableStorage(LensSessionHandle sessionid,
String dimension,
String storageName,
String filter) |
XPartitionList |
CubeMetastoreServiceImpl.getAllPartitionsOfFactStorage(LensSessionHandle sessionid,
String fact,
String storageName,
String filter) |
JAXBElement<XPartitionList> |
MetastoreResource.getAllPartitionsOfFactStorageByFilter(LensSessionHandle sessionid,
String factName,
String storage,
String filter)
Get all partitions of the fact table in the specified storage; can be filtered as well.
|
List<String> |
CubeMetastoreServiceImpl.getAllQueryableCubeNames(LensSessionHandle sessionid) |
List<String> |
CubeMetastoreServiceImpl.getAllStorageNames(LensSessionHandle sessionid) |
XCube |
CubeMetastoreServiceImpl.getCube(LensSessionHandle sessionid,
String cubeName)
Get a cube from the metastore
|
String |
CubeMetastoreServiceImpl.getCurrentDatabase(LensSessionHandle sessionid)
Get current database used by the CubeMetastoreClient
|
XDimension |
CubeMetastoreServiceImpl.getDimension(LensSessionHandle sessionid,
String dimName) |
StringList |
MetastoreResource.getDimensionStorages(LensSessionHandle sessionid,
String dimension)
Get all storages of the dimension table in the metastore
|
JAXBElement<XDimensionTable> |
MetastoreResource.getDimensionTable(LensSessionHandle sessionid,
String dimTableName)
Get the dimension table specified by name
|
XDimensionTable |
CubeMetastoreServiceImpl.getDimensionTable(LensSessionHandle sessionid,
String dimTblName) |
List<String> |
CubeMetastoreServiceImpl.getDimTableStorages(LensSessionHandle sessionid,
String dimension) |
JAXBElement<XFactTable> |
MetastoreResource.getFactTable(LensSessionHandle sessionid,
String factName)
Get the fact table specified by name
|
XFactTable |
CubeMetastoreServiceImpl.getFactTable(LensSessionHandle sessionid,
String fact) |
XFlattenedColumns |
CubeMetastoreServiceImpl.getFlattenedColumns(LensSessionHandle sessionHandle,
String tableName,
boolean addChains) |
DateTime |
MetastoreResource.getLatestDateOfCube(LensSessionHandle sessionid,
String cubeName,
String timeDimension)
Get the latest available date upto which data is available for the base cubes, for the time dimension.
|
Date |
CubeMetastoreServiceImpl.getLatestDateOfCube(LensSessionHandle sessionid,
String cubeName,
String timeDimension) |
XNativeTable |
CubeMetastoreServiceImpl.getNativeTable(LensSessionHandle sessionid,
String name) |
StringList |
MetastoreResource.getPartitionTimelines(LensSessionHandle sessionid,
String factName,
String storage,
String updatePeriod,
String timeDimension)
Get the partition timelines.
|
List<String> |
CubeMetastoreServiceImpl.getPartitionTimelines(LensSessionHandle sessionid,
String factName,
String storage,
String updatePeriod,
String timeDimension) |
XStorage |
CubeMetastoreServiceImpl.getStorage(LensSessionHandle sessionid,
String storageName) |
JAXBElement<XStorageTableElement> |
MetastoreResource.getStorageOfDim(LensSessionHandle sessionid,
String dimTableName,
String storage)
Get the dim storage table
|
XStorageTableElement |
CubeMetastoreServiceImpl.getStorageOfDim(LensSessionHandle sessionid,
String dimTblName,
String storageName) |
JAXBElement<XStorageTableElement> |
MetastoreResource.getStorageOfFact(LensSessionHandle sessionid,
String factName,
String storage)
Get the fact storage table
|
XStorageTableElement |
CubeMetastoreServiceImpl.getStorageOfFact(LensSessionHandle sessionid,
String fact,
String storageName) |
StringList |
MetastoreResource.getStoragesOfFact(LensSessionHandle sessionid,
String factName)
Get all storages of the fact table in the metastore
|
List<String> |
CubeMetastoreServiceImpl.getStoragesOfFact(LensSessionHandle sessionid,
String fact) |
void |
CubeMetastoreServiceImpl.setCurrentDatabase(LensSessionHandle sessionid,
String database)
Change the current database used by the CubeMetastoreClient
|
void |
CubeMetastoreServiceImpl.updateCube(LensSessionHandle sessionid,
XCube cube)
Update cube
|
void |
CubeMetastoreServiceImpl.updateDimension(LensSessionHandle sessionid,
String dimName,
XDimension dimension) |
void |
CubeMetastoreServiceImpl.updateDimensionTable(LensSessionHandle sessionid,
XDimensionTable dimensionTable) |
APIResult |
MetastoreResource.updateFactTable(LensSessionHandle sessionid,
String factName,
XFactTable fact)
Update fact table definition
|
void |
CubeMetastoreServiceImpl.updateFactTable(LensSessionHandle sessionid,
XFactTable fact) |
void |
CubeMetastoreServiceImpl.updatePartition(LensSessionHandle sessionid,
String tblName,
String storageName,
XPartition xPartition) |
void |
CubeMetastoreServiceImpl.updatePartitions(LensSessionHandle sessionid,
String tblName,
String storageName,
XPartitionList xPartitions) |
Modifier and Type | Method and Description |
---|---|
LensException |
QueryExecutionServiceImpl.RewriteEstimateRunnable.getCause() |
Modifier and Type | Method and Description |
---|---|
boolean |
QueryExecutionServiceImpl.cancelQuery(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
void |
QueryExecutionServiceImpl.closeResultSet(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
void |
QueryExecutionServiceImpl.closeSession(LensSessionHandle sessionHandle) |
void |
QueryExecutionServiceImpl.deleteResource(LensSessionHandle sessionHandle,
String type,
String path) |
boolean |
QueryExecutionServiceImpl.destroyPrepared(LensSessionHandle sessionHandle,
QueryPrepareHandle prepared) |
QueryCost |
QueryExecutionServiceImpl.estimate(String requestId,
LensSessionHandle sessionHandle,
String query,
LensConf lensConf) |
QueryHandleWithResultSet |
QueryExecutionServiceImpl.execute(LensSessionHandle sessionHandle,
String query,
long timeoutMillis,
LensConf conf,
String queryName) |
QueryHandle |
QueryExecutionServiceImpl.executeAsync(LensSessionHandle sessionHandle,
String query,
LensConf conf,
String queryName) |
QueryHandleWithResultSet |
QueryExecutionServiceImpl.executePrepare(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle,
long timeoutMillis,
LensConf conf,
String queryName) |
QueryHandle |
QueryExecutionServiceImpl.executePrepareAsync(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle,
LensConf conf,
String queryName) |
QueryPlan |
QueryExecutionServiceImpl.explain(String requestId,
LensSessionHandle sessionHandle,
String query,
LensConf lensConf) |
QueryPlan |
QueryExecutionServiceImpl.explainAndPrepare(LensSessionHandle sessionHandle,
String query,
LensConf lensConf,
String queryName) |
QueryResult |
QueryExecutionServiceImpl.fetchResultSet(LensSessionHandle sessionHandle,
QueryHandle queryHandle,
long startIndex,
int fetchSize) |
List<QueryHandle> |
LensServerDAO.findFinishedQueries(String state,
String user,
String queryName,
long fromDate,
long toDate)
Find finished queries.
|
List<QueryPrepareHandle> |
QueryExecutionServiceImpl.getAllPreparedQueries(LensSessionHandle sessionHandle,
String user,
String queryName,
long fromDate,
long toDate) |
List<QueryHandle> |
QueryExecutionServiceImpl.getAllQueries(LensSessionHandle sessionHandle,
String state,
String userName,
String queryName,
long fromDate,
long toDate) |
Long |
LensPersistentResult.getFileSize() |
javax.ws.rs.core.Response |
QueryExecutionServiceImpl.getHttpResultSet(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
LensResultSetMetadata |
LensPersistentResult.getMetadata() |
String |
LensPersistentResult.getOutputPath() |
LensPreparedQuery |
QueryExecutionServiceImpl.getPreparedQuery(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle) |
LensQuery |
QueryExecutionServiceImpl.getQuery(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
QueryResultSetMetadata |
QueryExecutionServiceImpl.getResultSetMetadata(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
void |
QueryExecutionServiceImpl.QueryStatusLogger.onEvent(StatusChange event) |
QueryPrepareHandle |
QueryExecutionServiceImpl.prepare(LensSessionHandle sessionHandle,
String query,
LensConf lensConf,
String queryName) |
LensAPIResult<? extends QuerySubmitResult> |
QueryServiceResource.prepareQuery(LensSessionHandle sessionid,
String query,
String operation,
LensConf conf,
String queryName)
Prepare a query or 'explain and prepare' the query.
|
LensAPIResult<? extends QuerySubmitResult> |
QueryServiceResource.query(LensSessionHandle sessionid,
String query,
String operation,
LensConf conf,
Long timeoutmillis,
String queryName)
Submit the query for explain or execute or execute with a timeout.
|
Integer |
LensPersistentResult.size() |
boolean |
QueryExecutionServiceImpl.updateQueryConf(LensSessionHandle sessionHandle,
QueryHandle queryHandle,
LensConf newconf) |
boolean |
QueryExecutionServiceImpl.updateQueryConf(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle,
LensConf newconf) |
Constructor and Description |
---|
QueryExecutionServiceImpl(org.apache.hive.service.cli.CLIService cliService)
Instantiates a new query execution service impl.
|
QueryServiceResource()
Instantiates a new query service resource.
|
Modifier and Type | Method and Description |
---|---|
ResourceModifiedResponse |
SavedQueryResource.create(LensSessionHandle sessionid,
SavedQuery savedQuery,
org.glassfish.grizzly.http.server.Response response)
Creates a new saved query.
|
void |
SavedQueryDao.createSavedQueryTableIfNotExists()
Creates the saved query table
|
void |
SavedQueryServiceImpl.delete(long id)
Deletes the saved query specified.
|
ResourceModifiedResponse |
SavedQueryResource.deleteById(LensSessionHandle sessionid,
long id)
Deletes the saved query with the given id.
|
void |
SavedQueryDao.deleteSavedQueryByID(long id)
Deletes the saved query with the given id
|
SavedQuery |
SavedQueryServiceImpl.get(long id)
Returns the saved query pointed out by the id.
|
SavedQuery |
SavedQueryResource.getByID(LensSessionHandle sessionid,
long id)
Gets the saved query with the given id.
|
ListResponse |
SavedQueryResource.getList(LensSessionHandle sessionid,
javax.ws.rs.core.UriInfo info,
int start,
String count)
Gets a list of saved queries matching the criteria (url parameters)
windowed by count and start.
|
ListResponse |
SavedQueryDao.getList(javax.ws.rs.core.MultivaluedMap<String,String> criteria,
long start,
long count)
Returns a list of saved queries
|
SavedQuery |
SavedQueryDao.getSavedQueryByID(long id)
Gets saved query with the given id
|
void |
SavedQueryServiceImpl.grant(long id,
String sharingUser,
String targetUserPath,
String[] privileges)
Grant permissions for users to do actions on the saved query.
|
ListResponse |
SavedQueryServiceImpl.list(javax.ws.rs.core.MultivaluedMap<String,String> criteria,
long start,
long count)
List the saved query from {start} to {count} matching filter denoted by criteria.
|
void |
SavedQueryServiceImpl.revoke(long id,
String sharingUser,
String targetUserPath,
String[] privileges)
Revoke permissions from users to do actions on the saved query.
|
LensAPIResult<? extends QuerySubmitResult> |
SavedQueryResource.run(long id,
javax.ws.rs.core.UriInfo info,
LensSessionHandle sessionid,
LensConf conf)
Runs the saved query with the given id and returns a query handle.
|
long |
SavedQueryServiceImpl.save(SavedQuery savedQuery)
Saves a query
|
long |
SavedQueryDao.saveQuery(SavedQuery savedQuery)
Saves the query passed
|
ResourceModifiedResponse |
SavedQueryResource.update(LensSessionHandle sessionid,
long id,
SavedQuery savedQuery,
org.glassfish.grizzly.http.server.Response response)
Updates the saved query {id} with the new payload.
|
void |
SavedQueryServiceImpl.update(long id,
SavedQuery savedQuery)
Updates the specified saved query with the new object.
|
void |
SavedQueryDao.updateQuery(long id,
SavedQuery savedQuery)
Updates the saved query id with new payload
|
Constructor and Description |
---|
SavedQueryServiceImpl(org.apache.hive.service.cli.CLIService cliService)
Instantiates a new lens service.
|
Modifier and Type | Method and Description |
---|---|
LensException |
RewriteUtil.DriverRewriterRunnable.getCause() |
Modifier and Type | Method and Description |
---|---|
void |
UserQueryToCubeQueryRewriter.rewrite(AbstractQueryContext ctx) |
static Map<LensDriver,RewriteUtil.DriverRewriterRunnable> |
RewriteUtil.rewriteQuery(AbstractQueryContext ctx)
Rewrite query.
|
String |
UserQueryToCubeQueryRewriter.rewriteToCubeQuery(String userQuery,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hive.conf.HiveConf hiveConf) |
Constructor and Description |
---|
UserQueryToCubeQueryRewriter(org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Method and Description |
---|---|
void |
HiveSessionService.closeSession(LensSessionHandle sessionHandle)
Close session.
|
List<String> |
HiveSessionService.getAllSessionParameters(LensSessionHandle sessionid,
boolean verbose,
String key)
Gets the all session parameters.
|
CubeMetastoreClient |
LensSessionImpl.getCubeMetastoreClient() |
LensSessionHandle |
HiveSessionService.openSession(String username,
String password,
String database,
Map<String,String> configuration)
Open session.
|
Constructor and Description |
---|
SessionResource()
Instantiates a new session resource.
|
Constructor and Description |
---|
SessionUIResource()
Instantiates a new session ui resource.
|
Copyright © 2014–2015 Apache Software Foundation. All rights reserved.