This project has retired. For details please refer to its Attic page.
Uses of Class org.apache.lens.api.LensException (Lens 2.1.0-beta-incubating API)

Uses of Class
org.apache.lens.api.LensException

Packages that use LensException
org.apache.lens.client   
org.apache.lens.cube.metadata   
org.apache.lens.cube.metadata.timeline   
org.apache.lens.driver.cube   
org.apache.lens.driver.hive   
org.apache.lens.driver.hive.priority   
org.apache.lens.driver.jdbc   
org.apache.lens.ml.algo.api   
org.apache.lens.ml.algo.lib   
org.apache.lens.ml.algo.spark   
org.apache.lens.ml.algo.spark.kmeans   
org.apache.lens.ml.api   
org.apache.lens.ml.impl   
org.apache.lens.ml.server   
org.apache.lens.rdd   
org.apache.lens.server   
org.apache.lens.server.api.driver   
org.apache.lens.server.api.events   
org.apache.lens.server.api.metastore   
org.apache.lens.server.api.priority   
org.apache.lens.server.api.query   
org.apache.lens.server.api.session   
org.apache.lens.server.metastore   
org.apache.lens.server.query   
org.apache.lens.server.session   
org.apache.lens.server.ui   
 

Uses of LensException in org.apache.lens.client
 

Methods in org.apache.lens.client that throw LensException
 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.
 

Uses of LensException in org.apache.lens.cube.metadata
 

Methods in org.apache.lens.cube.metadata that throw LensException
 void CubeMetastoreClient.addPartition(StoragePartitionDesc partSpec, String storageName)
          Add a partition specified by the storage partition desc on the storage passed.
 void CubeMetastoreClient.addPartitions(List<StoragePartitionDesc> storagePartitionDescs, String storageName)
          batch addition
 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.
 boolean CubeMetastoreClient.factPartitionExists(CubeFactTable fact, FactPartition part, String storageTableName)
          extract storage name and check in timeline cache for existance
 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.
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()
           
 

Constructors in org.apache.lens.cube.metadata that throw LensException
TimePartitionRange(TimePartition begin, TimePartition end)
           
 

Uses of LensException in org.apache.lens.cube.metadata.timeline
 

Methods in org.apache.lens.cube.metadata.timeline that throw LensException
 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 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)
           
 

Uses of LensException in org.apache.lens.driver.cube
 

Methods in org.apache.lens.driver.cube that throw LensException
static Map<LensDriver,RewriteUtil.DriverRewriterRunnable> RewriteUtil.rewriteQuery(AbstractQueryContext ctx)
          Rewrite query.
 

Uses of LensException in org.apache.lens.driver.hive
 

Methods in org.apache.lens.driver.hive that throw LensException
 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()
           
 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)
           
 int HivePersistentResultSet.size()
           
 int HiveInMemoryResultSet.size()
           
 void HiveDriver.updateStatus(QueryContext context)
           
 

Constructors in org.apache.lens.driver.hive that throw LensException
HiveDriver()
          Instantiates a new hive driver.
 

Uses of LensException in org.apache.lens.driver.hive.priority
 

Methods in org.apache.lens.driver.hive.priority that throw LensException
 Priority DurationBasedQueryPriorityDecider.decidePriority(AbstractQueryContext abstractQueryContext)
          The Implementation
 

Uses of LensException in org.apache.lens.driver.jdbc
 

Methods in org.apache.lens.driver.jdbc that throw LensException
 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)
           
 void JDBCResultSet.setFetchSize(int size)
           
 int 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
 

Uses of LensException in org.apache.lens.ml.algo.api
 

Methods in org.apache.lens.ml.algo.api that throw LensException
 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.
 

Uses of LensException in org.apache.lens.ml.algo.lib
 

Methods in org.apache.lens.ml.algo.lib that throw LensException
 MLAlgo Algorithms.getAlgoForName(String name)
          Gets the algo for name.
 

Uses of LensException in org.apache.lens.ml.algo.spark
 

Methods in org.apache.lens.ml.algo.spark that throw LensException
 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)
           
 

Uses of LensException in org.apache.lens.ml.algo.spark.kmeans
 

Methods in org.apache.lens.ml.algo.spark.kmeans that throw LensException
 MLModel KMeansAlgo.train(LensConf conf, String db, String table, String modelId, String... params)
           
 

Uses of LensException in org.apache.lens.ml.api
 

Methods in org.apache.lens.ml.api that throw LensException
 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.
 

Uses of LensException in org.apache.lens.ml.impl
 

Methods in org.apache.lens.ml.impl that throw LensException
 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)
           
 

Uses of LensException in org.apache.lens.ml.server
 

Methods in org.apache.lens.ml.server that throw LensException
 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)
           
 

Uses of LensException in org.apache.lens.rdd
 

Methods in org.apache.lens.rdd that throw LensException
 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.
 QueryHandle LensRDDClient.createLensRDDAsync(String query)
          API for non blocking use.
 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.
 

Uses of LensException in org.apache.lens.server
 

Methods in org.apache.lens.server that throw LensException
 void LensService.addResource(LensSessionHandle sessionHandle, String type, String path)
          Adds the resource.
 void LensService.closeSession(LensSessionHandle sessionHandle)
          Close session.
 void LensService.deleteResource(LensSessionHandle sessionHandle, String type, String path)
          Delete resource.
 org.apache.hadoop.conf.Configuration LensService.getLensConf(LensConf conf)
          Gets the lens conf.
 org.apache.hadoop.conf.Configuration LensService.getLensConf(LensSessionHandle sessionHandle, LensConf conf)
          Gets the lens conf.
 void EventServiceImpl.notifyEvent(LensEvent evt)
           
 LensSessionHandle LensService.openSession(String username, String password, Map<String,String> configuration)
          Open session.
 void LensService.release(String sessionHandle)
          Releases a lens session specified by the public UUID.
 void LensService.restoreSession(LensSessionHandle sessionHandle, String userName, String password)
          Restore session from previous instance of lens server.
 

Uses of LensException in org.apache.lens.server.api.driver
 

Methods in org.apache.lens.server.api.driver that throw LensException
 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

The driver would be closing the driver handle, once the results are fetched.

 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  LensResultSetMetadata LensResultSet.getMetadata()
          Get the result set metadata
abstract  String PersistentResultSet.getOutputPath()
           
abstract  boolean InMemoryResultSet.hasNext()
          Whether there is another result row available.
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  void InMemoryResultSet.setFetchSize(int size)
          Set number of rows to be fetched at time
abstract  int LensResultSet.size()
          Get the size of the result set.
 QueryResult PersistentResultSet.toQueryResult()
           
abstract  QueryResult LensResultSet.toQueryResult()
          Get the corresponding query result object.
 QueryResult InMemoryResultSet.toQueryResult()
           
 void LensDriver.updateStatus(QueryContext context)
          Update driver query status in the context object.
 

Uses of LensException in org.apache.lens.server.api.events
 

Methods in org.apache.lens.server.api.events that throw LensException
 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.
 

Uses of LensException in org.apache.lens.server.api.metastore
 

Methods in org.apache.lens.server.api.metastore that throw LensException
 void CubeMetastoreService.addDimTableStorage(LensSessionHandle sessionid, String dimTblName, XStorageTableElement storageTable)
          Add a storage to dimension table
 void CubeMetastoreService.addPartitionsToDimStorage(LensSessionHandle sessionid, String dimTblName, String storageName, XPartitionList partitions)
          Add partitions to dimension table on a storage.
 void CubeMetastoreService.addPartitionsToFactStorage(LensSessionHandle sessionid, String fact, String storageName, XPartitionList partitions)
          Add partitions to fact on a storage
 void CubeMetastoreService.addPartitionToDimStorage(LensSessionHandle sessionid, String dimTblName, String storageName, XPartition partition)
          Add partition to dimension table on a storage.
 void 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
 List<String> CubeMetastoreService.getAllNativeTableNames(LensSessionHandle sessionid, String dboption, String dbName)
          Get names of all native tables
 List<XPartition> CubeMetastoreService.getAllPartitionsOfDimTableStorage(LensSessionHandle sessionid, String dimTblName, String storage, String filter)
          Get all partitions of a dimension table in a storage
 List<XPartition> CubeMetastoreService.getAllPartitionsOfFactStorage(LensSessionHandle sessionid, String fact, String storage, 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)
          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
 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
 

Uses of LensException in org.apache.lens.server.api.priority
 

Methods in org.apache.lens.server.api.priority that throw LensException
 Priority QueryPriorityDecider.decidePriority(AbstractQueryContext queryContext)
           
 

Uses of LensException in org.apache.lens.server.api.query
 

Methods in org.apache.lens.server.api.query that throw LensException
 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.
 EstimateResult QueryExecutionService.estimate(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(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.
 QueryCost DriverSelectorQueryContext.getSelectedDriverQueryCost()
          Return selected driver's query plan, but check for null conditions first.
 QueryCost AbstractQueryContext.getSelectedDriverQueryCost()
          Get selected driver's cost
 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.
 String QueryRewriter.rewrite(String query, org.apache.hadoop.conf.Configuration queryConf, org.apache.hadoop.hive.conf.HiveConf metastoreConf)
          Rewrite.
 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)
           
 QueryContext FinishedLensQuery.toQueryContext(org.apache.hadoop.conf.Configuration conf, Collection<LensDriver> drivers)
           
 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.
 

Uses of LensException in org.apache.lens.server.api.session
 

Methods in org.apache.lens.server.api.session that throw LensException
 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.
 

Uses of LensException in org.apache.lens.server.metastore
 

Methods in org.apache.lens.server.metastore that throw LensException
 void CubeMetastoreServiceImpl.addDimTableStorage(LensSessionHandle sessionid, String dimTblName, XStorageTableElement storageTable)
           
 void CubeMetastoreServiceImpl.addPartitionsToDimStorage(LensSessionHandle sessionid, String dimTblName, String storageName, XPartitionList partitions)
           
 void CubeMetastoreServiceImpl.addPartitionsToFactStorage(LensSessionHandle sessionid, String fact, String storageName, XPartitionList partitions)
           
 void CubeMetastoreServiceImpl.addPartitionToDimStorage(LensSessionHandle sessionid, String dimTblName, String storageName, XPartition partition)
           
 void 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
 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
 List<XPartition> CubeMetastoreServiceImpl.getAllPartitionsOfDimTableStorage(LensSessionHandle sessionid, String dimension, String storageName, String filter)
           
 List<XPartition> 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)
           
 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)
           
 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)
           
 

Uses of LensException in org.apache.lens.server.query
 

Methods in org.apache.lens.server.query that throw LensException
 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)
           
 EstimateResult QueryExecutionServiceImpl.estimate(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(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)
           
 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)
           
 int LensPersistentResult.size()
           
 boolean QueryExecutionServiceImpl.updateQueryConf(LensSessionHandle sessionHandle, QueryHandle queryHandle, LensConf newconf)
           
 boolean QueryExecutionServiceImpl.updateQueryConf(LensSessionHandle sessionHandle, QueryPrepareHandle prepareHandle, LensConf newconf)
           
 

Constructors in org.apache.lens.server.query that throw LensException
QueryExecutionServiceImpl(org.apache.hive.service.cli.CLIService cliService)
          Instantiates a new query execution service impl.
QueryServiceResource()
          Instantiates a new query service resource.
 

Uses of LensException in org.apache.lens.server.session
 

Methods in org.apache.lens.server.session that throw LensException
 void HiveSessionService.closeSession(LensSessionHandle sessionHandle)
           
 List<String> HiveSessionService.getAllSessionParameters(LensSessionHandle sessionid, boolean verbose, String key)
           
 CubeMetastoreClient LensSessionImpl.getCubeMetastoreClient()
           
 void DatabaseResourceService.loadResources()
          Load DB specific resources
 LensSessionHandle HiveSessionService.openSession(String username, String password, String database, Map<String,String> configuration)
           
 

Constructors in org.apache.lens.server.session that throw LensException
SessionResource()
          Instantiates a new session resource.
 

Uses of LensException in org.apache.lens.server.ui
 

Constructors in org.apache.lens.server.ui that throw LensException
SessionUIResource()
          Instantiates a new session ui resource.
 



Copyright © 2014–2015 Apache Software Foundation. All rights reserved.