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 |
class |
NoCandidateDimAvailableException |
class |
NoCandidateFactAvailableException
Note: This class is mainly meant for test cases to assert the detailed reasons (stored in
NoCandidateFactAvailableException.briefAndDetailedError leading to "No Candidate was found" |
Modifier and Type | Method and Description |
---|---|
int |
NoCandidateFactAvailableException.compareTo(LensException e) |
int |
NoCandidateDimAvailableException.compareTo(LensException e) |
Modifier and Type | Method and Description |
---|---|
void |
ExprColumn.addExpression(ExprColumn.ExprSpec expression)
Add an expression to existing set of expressions for this column
|
List<org.apache.hadoop.hive.ql.metadata.Partition> |
CubeMetastoreClient.addPartition(StoragePartitionDesc partSpec,
String storageName,
CubeTableType type)
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,
CubeTableType type)
batch addition
|
void |
CubeMetastoreClient.addStorage(CubeDimensionTable dim,
String storage,
UpdatePeriod dumpPeriod,
StorageTableDesc storageTableDesc)
Adds storage to dimension and creates corresponding storage table
|
void |
CubeMetastoreClient.addStorage(CubeFactTable fact,
String storage,
Set<UpdatePeriod> updatePeriods,
Map<String,StorageTableDesc> storageTableDescs,
Map<UpdatePeriod,String> updatePeriodStoragePrefix)
Adds storage to fact and creates corresponding storage table
|
void |
CubeMetastoreClient.alterCube(String cubeName,
CubeInterface cube)
Alter cube specified by the name to new definition
|
void |
CubeMetastoreClient.alterCube(XCube cube) |
void |
CubeMetastoreClient.alterCubeDimensionTable(String dimTableName,
CubeDimensionTable cubeDimensionTable,
Map<String,StorageTableDesc> storageTableDescs)
Alter dimension table with new dimension definition and underlying storage tables as well
|
void |
CubeMetastoreClient.alterCubeDimensionTable(XDimensionTable dimensionTable) |
void |
CubeMetastoreClient.alterCubeFactTable(String factTableName,
FactTable cubeFactTable,
Map<String,StorageTableDesc> storageTableDescs,
Map<String,String> props)
Alter a cubefact with new definition and alter underlying storage tables as well.
|
void |
CubeMetastoreClient.alterCubeFactTable(XFact fact) |
void |
CubeMetastoreClient.alterDimension(String dimName,
Dimension newDim) |
void |
CubeMetastoreClient.alterDimension(XDimension newDim)
Alter dimension specified by the dimension name to new definition
|
void |
CubeMetastoreClient.alterHiveTable(String table,
org.apache.hadoop.hive.ql.metadata.Table hiveTable) |
void |
CubeMetastoreClient.alterSegmentation(String segName,
Segmentation seg) |
void |
CubeMetastoreClient.alterSegmentation(XSegmentation cubeSeg) |
void |
CubeFactTable.alterStorage(String storage,
Set<UpdatePeriod> updatePeriods)
Alter a storage with specified update periods
|
void |
CubeMetastoreClient.alterStorage(String storageName,
Storage storage) |
void |
CubeMetastoreClient.alterStorage(XStorage storage)
Alter storage specified by the name to new definition
|
void |
CubeMetastoreClient.alterVirtualCubeFactTable(CubeVirtualFactTable cubeVirtualFactTable)
Alter a virtual cube fact with new definition
|
static TimePartitionRange |
TimePartitionRange.between(Date from,
Date to,
UpdatePeriod period) |
org.apache.hadoop.hive.ql.parse.ASTNode |
ExprColumn.ExprSpec.copyASTNode() |
void |
CubeMetastoreClient.createCube(CubeInterface cube)
Create cube in metastore defined by
Cube or DerivedCube object |
void |
CubeMetastoreClient.createCube(String name,
Set<CubeMeasure> measures,
Set<CubeDimAttribute> dimensions)
Create cube defined by measures and dimensions
|
void |
CubeMetastoreClient.createCube(String name,
Set<CubeMeasure> measures,
Set<CubeDimAttribute> dimensions,
Map<String,String> properties)
Create cube defined by measures, dimensions and properties
|
void |
CubeMetastoreClient.createCube(String name,
Set<CubeMeasure> measures,
Set<CubeDimAttribute> dimensions,
Set<ExprColumn> expressions,
Map<String,String> properties)
Create cube defined by measures, dimensions and properties
|
void |
CubeMetastoreClient.createCube(String name,
Set<CubeMeasure> measures,
Set<CubeDimAttribute> dimensions,
Set<ExprColumn> expressions,
Set<JoinChain> chains,
Map<String,String> properties)
Create cube defined by measures, dimensions and properties
|
void |
CubeMetastoreClient.createCube(XCube cube) |
void |
CubeMetastoreClient.createCubeDimensionTable(String dimName,
String dimTblName,
List<org.apache.hadoop.hive.metastore.api.FieldSchema> columns,
double weight,
Map<String,UpdatePeriod> dumpPeriods,
Map<String,String> properties,
Map<String,StorageTableDesc> storageTableDescs)
Create a cube dimension table
|
void |
CubeMetastoreClient.createCubeDimensionTable(String dimName,
String dimTblName,
List<org.apache.hadoop.hive.metastore.api.FieldSchema> columns,
double weight,
Set<String> storageNames,
Map<String,String> properties,
Map<String,StorageTableDesc> storageTableDescs)
Create a cube dimension table
|
void |
CubeMetastoreClient.createCubeDimensionTable(XDimensionTable xDimTable) |
void |
CubeMetastoreClient.createCubeFactTable(String cubeName,
String factName,
List<org.apache.hadoop.hive.metastore.api.FieldSchema> columns,
Map<String,Set<UpdatePeriod>> storageAggregatePeriods,
double weight,
Map<String,String> properties,
Map<String,StorageTableDesc> storageTableDescs)
Create a cube fact table
|
void |
CubeMetastoreClient.createCubeFactTable(String cubeName,
String factName,
List<org.apache.hadoop.hive.metastore.api.FieldSchema> columns,
Map<String,Set<UpdatePeriod>> storageAggregatePeriods,
double weight,
Map<String,String> properties,
Map<String,StorageTableDesc> storageTableDescs,
Map<String,Map<UpdatePeriod,String>> storageUpdatePeriodMap) |
void |
CubeMetastoreClient.createCubeTable(AbstractCubeTable cubeTable,
Map<String,StorageTableDesc> storageTableDescs)
Create cube table defined and create all the corresponding storage tables
|
void |
CubeMetastoreClient.createDerivedCube(String parent,
String name,
Set<String> measures,
Set<String> dimensions,
Map<String,String> properties,
double weight)
Create derived cube defined by measures, dimensions and properties
|
void |
CubeMetastoreClient.createDimension(Dimension dim)
Create dimension in metastore defined by
Dimension object |
void |
CubeMetastoreClient.createDimension(String name,
Set<CubeDimAttribute> attributes,
Map<String,String> properties,
double weight)
Create dimension defined by attributes and properties
|
void |
CubeMetastoreClient.createDimension(XDimension dim) |
<T extends org.jvnet.jaxb2_commons.lang.Equals & org.jvnet.jaxb2_commons.lang.HashCode & org.jvnet.jaxb2_commons.lang.ToString> |
CubeMetastoreClient.createEntity(T entity) |
void |
CubeMetastoreClient.createFactTable(XFact fact) |
void |
CubeMetastoreClient.createSegmentation(Segmentation cubeSeg) |
void |
CubeMetastoreClient.createSegmentation(String baseCubeName,
String segmentationName,
Set<Segment> segments,
double weight,
Map<String,String> properties) |
void |
CubeMetastoreClient.createSegmentation(XSegmentation cubeSeg) |
void |
CubeMetastoreClient.createStorage(Storage storage) |
void |
CubeMetastoreClient.createStorage(XStorage storage) |
void |
CubeMetastoreClient.createVirtualFactTable(String cubeName,
String virtualFactName,
String sourceFactName,
Double weight,
Map<String,String> properties) |
static CubeDimensionTable |
JAXBUtils.cubeDimTableFromDimTable(XDimensionTable dimensionTable) |
static CubeFactTable |
JAXBUtils.cubeFactFromFactTable(XFactTable fact) |
static CubeVirtualFactTable |
JAXBUtils.cubeVirtualFactFromFactTable(XVirtualFactTable fact,
FactTable sourceFactTable) |
static Dimension |
JAXBUtils.dimensionFromXDimension(XDimension dimension) |
void |
CubeMetastoreClient.dropCube(String cubeName)
Drop a cube
|
void |
CubeMetastoreClient.dropDimension(String dimName)
Drop a dimension
|
void |
CubeMetastoreClient.dropDimensionTable(String dimTblName,
boolean cascade)
Drop the dimension table
|
void |
CubeMetastoreClient.dropFact(String factName,
boolean cascade)
Drop a fact with cascade flag
|
void |
CubeMetastoreClient.dropHiveTable(String table) |
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.
|
void |
CubeMetastoreClient.dropSegmentation(String segName) |
void |
CubeMetastoreClient.dropStorage(String storageName)
Drop a storage
|
void |
CubeMetastoreClient.dropStorageFromDim(String dimTblName,
String storage)
Drop a storage from dimension
|
void |
CubeMetastoreClient.dropStorageFromFact(String factName,
String storage)
Drop a storage from fact
|
void |
CubeMetastoreClient.dropVirtualFact(String virtualFactName)
Drop a virtual fact
|
TimePartitionRange |
TimePartition.emptyRange() |
boolean |
CubeMetastoreClient.factPartitionExists(FactTable fact,
FactPartition part,
String storageTableName)
extract storage name and check in timeline cache for existance
|
boolean |
CubeMetastoreClient.factPartitionExists(String factName,
String storageName,
UpdatePeriod updatePeriod,
Map<String,Date> partitionTimestamp,
Map<String,String> partSpec) |
static UpdatePeriod |
UpdatePeriod.fromUnitName(String unitName) |
Collection<CubeInterface> |
CubeMetastoreClient.getAllCubes()
Get all cubes in metastore
|
List<DerivedCube> |
CubeMetastoreClient.getAllDerivedQueryableCubes(CubeInterface cube)
Get all derived cubes of the cube, that have all fields queryable together
|
Collection<Dimension> |
CubeMetastoreClient.getAllDimensions()
Get all cubes in metastore
|
Collection<CubeDimensionTable> |
CubeMetastoreClient.getAllDimensionTables()
Get all dimension tables in metastore
|
List<CubeDimensionTable> |
CubeMetastoreClient.getAllDimensionTables(Dimension dim)
Get all dimension tables of the dimension.
|
Collection<FactTable> |
CubeMetastoreClient.getAllFacts()
Get all facts in metastore
|
Collection<FactTable> |
CubeMetastoreClient.getAllFacts(boolean includeVirtualFacts)
Get all facts in metastore (virtual facts optional)
|
List<FactTable> |
CubeMetastoreClient.getAllFacts(CubeInterface cube)
Get all fact tables of the cube.
|
List<FactTable> |
CubeMetastoreClient.getAllFacts(CubeInterface cube,
boolean includeVirtualFacts)
Get all facts of cube (optional virtual facts)
|
List<org.apache.hadoop.hive.ql.metadata.Partition> |
CubeMetastoreClient.getAllParts(String storageTableName) |
Collection<Segmentation> |
CubeMetastoreClient.getAllSegmentations()
Get all segmentations in metastore
|
List<Segmentation> |
CubeMetastoreClient.getAllSegmentations(CubeInterface cube) |
Collection<Storage> |
CubeMetastoreClient.getAllStorages()
Get all storages in metastore
|
org.apache.hadoop.hive.ql.parse.ASTNode |
ExprColumn.getAst()
Get the AST corresponding to the expression
|
CubeInterface |
CubeMetastoreClient.getCube(String tableName)
Get
Cube object corresponding to the name |
CubeFactTable |
CubeMetastoreClient.getCubeFactTable(String factName) |
CubeVirtualFactTable |
CubeMetastoreClient.getCubeVirtualFactTable(String factName) |
Dimension |
CubeMetastoreClient.getDimension(String tableName)
Get
Cube object corresponding to the name |
CubeDimensionTable |
CubeMetastoreClient.getDimensionTable(String tableName)
Get
CubeDimensionTable object corresponding to the name |
List<org.apache.hadoop.hive.ql.parse.ASTNode> |
ExprColumn.getExpressionASTList() |
FactTable |
CubeMetastoreClient.getFactTable(String tableName)
Get
Cube object corresponding to the name |
org.apache.hadoop.hive.ql.metadata.Table |
CubeMetastoreClient.getHiveTable(String tableName)
Get the hive
Table corresponding to the name |
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<JoinPath> |
JoinChain.getRelationEdges(CubeMetastoreClient client)
Convert join chain paths to JoinPath objects
|
Segmentation |
CubeMetastoreClient.getSegmentation(String segName) |
Segmentation |
CubeMetastoreClient.getSegmentation(String segName,
boolean throwException) |
Segmentation |
CubeMetastoreClient.getSegmentationTable(String tableName) |
Storage |
CubeMetastoreClient.getStorage(String storageName)
Get
Storage object corresponding to the name |
Storage |
CubeMetastoreClient.getStorage(String storageName,
boolean throwException) |
Date |
CubeMetastoreClient.getStorageTableEndDate(String storageTable,
FactTable factTableName) |
String |
CubeMetastoreClient.getStorageTableName(String factOrDimTableName,
String storage,
UpdatePeriod updatePeriod) |
Set<String> |
CubeMetastoreClient.getStorageTables(FactTable factTable,
String storage)
Returns storage table names for a storage.
|
Date |
CubeMetastoreClient.getStorageTableStartDate(String storageTable,
FactTable factTableName) |
org.apache.hadoop.hive.ql.metadata.Table |
CubeMetastoreClient.getTable(String tableName) |
org.apache.hadoop.hive.ql.metadata.Table |
CubeMetastoreClient.getTable(String tableName,
boolean throwException) |
org.apache.hadoop.hive.ql.metadata.Table |
CubeMetastoreClient.getTableWithType(String tableName,
CubeTableType type,
boolean throwException) |
org.apache.hadoop.hive.ql.metadata.Table |
CubeMetastoreClient.getTableWithTypeFailFast(String tableName,
CubeTableType type) |
List<PartitionTimeline> |
CubeMetastoreClient.getTimelines(String factName,
String storage,
String updatePeriodStr,
String timeDimension) |
List<String> |
CubeMetastoreClient.getTimePartColNamesOfTable(String storageTableName) |
TimePartition |
FactPartition.getTimePartition() |
XDimensionTable |
CubeMetastoreClient.getXDimensionTable(CubeDimensionTable dimTable) |
XDimensionTable |
CubeMetastoreClient.getXDimensionTable(String dimTable) |
XFact |
CubeMetastoreClient.getXFactTable(FactTable ft) |
XFact |
CubeMetastoreClient.getXFactTable(String tableName) |
static CubeInterface |
JAXBUtils.hiveCubeFromXCube(XCube cube,
Cube parent)
Create a hive ql cube object from corresponding JAXB object
|
static CubeDimAttribute |
JAXBUtils.hiveDimAttrFromXDimAttr(XDimAttribute xd)
Create a hive ql CubeDimension from JAXB counterpart
|
static ExprColumn |
JAXBUtils.hiveExprColumnFromXExprColumn(XExprColumn xe) |
boolean |
CubeMetastoreClient.isCube(String tableName)
Is the table name passed a cube?
|
boolean |
CubeMetastoreClient.isDimension(String tableName)
Is the table name passed a dimension?
|
boolean |
CubeMetastoreClient.isDimensionTable(String tableName)
Is the table name passed a dimension table?
|
boolean |
CubeMetastoreClient.isFactTable(String tableName)
Is the table name passed a fact table?
|
boolean |
CubeMetastoreClient.isStorageTableCandidateForRange(String storageTableName,
Date fromDate,
Date toDate) |
boolean |
CubeMetastoreClient.isStorageTableCandidateForRange(String storageTableName,
String fromDate,
String toDate) |
boolean |
CubeMetastoreClient.isStorageTablePartitionACandidate(String storageTableName,
Date partDate) |
boolean |
CubeMetastoreClient.isVirtualFactTable(String virtualTableName)
Is the table name passed a virtual fact table?
|
FactPartition |
FactPartition.next() |
static TimePartition |
TimePartition.of(UpdatePeriod updatePeriod,
Date date) |
static TimePartition |
TimePartition.of(UpdatePeriod updatePeriod,
String dateString) |
static DateUtil.TimeDiff |
DateUtil.TimeDiff.parseFrom(String diffStr) |
static TimePartitionRange |
TimePartitionRange.parseFrom(UpdatePeriod updatePeriod,
String from,
String to) |
boolean |
CubeMetastoreClient.partColExists(FactTable factTable,
String storage,
String partCol) |
boolean |
CubeMetastoreClient.partitionExists(String storageTableName,
UpdatePeriod updatePeriod,
Map<String,Date> partitionTimestamps) |
boolean |
CubeMetastoreClient.partitionExistsByFilter(String storageTableName,
String filter) |
boolean |
CubeMetastoreClient.partitionExistsByFilter(String cubeTableName,
String storageName,
UpdatePeriod updatePeriod,
String filter) |
FactPartition |
FactPartition.previous() |
void |
CubeMetastoreClient.pushHiveTable(org.apache.hadoop.hive.ql.metadata.Table hiveTable) |
TimePartitionRange |
TimePartition.rangeFrom(TimePartition from) |
TimePartitionRange |
TimePartition.rangeUpto(TimePartition to) |
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) |
static Segmentation |
JAXBUtils.segmentationFromXSegmentation(XSegmentation seg) |
TimePartitionRange |
TimePartition.singletonRange() |
TimeRange |
TimeRange.truncate(UpdatePeriod updatePeriod)
Truncate time range using the update period.
|
<T extends org.jvnet.jaxb2_commons.lang.Equals & org.jvnet.jaxb2_commons.lang.HashCode & org.jvnet.jaxb2_commons.lang.ToString> |
CubeMetastoreClient.updateEntity(String name,
T entity) |
void |
CubeMetastoreClient.updatePartition(String fact,
String storageName,
org.apache.hadoop.hive.ql.metadata.Partition partition,
UpdatePeriod updatePeriod) |
void |
CubeMetastoreClient.updatePartitions(String factOrDimtableName,
String storageName,
Map<UpdatePeriod,List<org.apache.hadoop.hive.ql.metadata.Partition>> partitions) |
void |
TimeRange.validate() |
void |
DerivedCube.validate() |
void |
CubeMetastoreClient.verifyStorageExists(AbstractCubeTable cdt,
String storage) |
TimePartition |
TimePartition.withUpdatePeriod(UpdatePeriod period) |
Constructor and Description |
---|
DerivedCube(String name,
Set<String> measures,
Set<String> dimensions,
Cube parent) |
DerivedCube(String name,
Set<String> measures,
Set<String> dimensions,
Map<String,String> properties,
double weight,
Cube parent) |
ExprColumn(org.apache.hadoop.hive.metastore.api.FieldSchema column,
String displayString,
ExprColumn.ExprSpec... expressions) |
ExprColumn(org.apache.hadoop.hive.metastore.api.FieldSchema column,
String displayString,
Map<String,String> tags,
ExprColumn.ExprSpec... expressions) |
ExprColumn(org.apache.hadoop.hive.metastore.api.FieldSchema column,
String displayString,
String expression) |
ExprSpec(String expr,
Date startTime,
Date endTime) |
ReferencedDimAtrribute(String name,
Map<String,String> props) |
ReferencedDimAttribute(org.apache.hadoop.hive.metastore.api.FieldSchema column,
String displayString,
List<ReferencedDimAttribute.ChainRefCol> chainRefCols,
Date startTime,
Date endTime,
Double cost,
Long numOfDistinctValues) |
ReferencedDimAttribute(org.apache.hadoop.hive.metastore.api.FieldSchema column,
String displayString,
List<ReferencedDimAttribute.ChainRefCol> chainRefCols,
Date startTime,
Date endTime,
Double cost,
Long numOfDistinctValues,
List<String> values,
Map<String,String> tags) |
ReferencedDimAttribute(org.apache.hadoop.hive.metastore.api.FieldSchema column,
String displayString,
String chainName,
String refColumn,
Date startTime,
Date endTime,
Double cost) |
ReferencedDimAttribute(org.apache.hadoop.hive.metastore.api.FieldSchema column,
String displayString,
String chainName,
String refColumn,
Date startTime,
Date endTime,
Double cost,
Long numOfDistinctValues) |
ReferencedDimAttribute(String name,
Map<String,String> props)
This is used only for serializing
|
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 |
---|---|
LensException |
CandidateTablePruneCause.getInnerException() |
Modifier and Type | Method and Description |
---|---|
static CandidateTablePruneCause |
CandidateTablePruneCause.segmentationPruned(LensException e) |
void |
CandidateTablePruneCause.setInnerException(LensException innerException) |
Modifier and Type | Method and Description |
---|---|
void |
PartitionRangesForPartitionColumns.add(FactPartition part) |
void |
PartitionRangesForPartitionColumns.add(String partCol,
TimePartition partition) |
void |
QueryWriterContext.addAutoJoinDims() |
void |
MultiCandidateQueryWriterContext.addAutoJoinDims() |
void |
DimHQLContext.addAutoJoinDims() |
void |
QueryWriterContext.addDenormDims() |
void |
MultiCandidateQueryWriterContext.addDenormDims() |
void |
DimHQLContext.addDenormDims() |
void |
QueryWriterContext.addExpressionDims() |
void |
MultiCandidateQueryWriterContext.addExpressionDims() |
void |
DimHQLContext.addExpressionDims() |
static void |
HQLParser.bft(org.apache.hadoop.hive.ql.parse.ASTNode root,
HQLParser.ASTNodeVisitor visitor)
Breadth first traversal of AST
|
StorageCandidate |
StorageCandidate.copy() |
Candidate |
SegmentationCandidate.copy() |
default Candidate |
Candidate.copy()
Clones this candidate
|
default Set<org.apache.lens.cube.parse.QueriedPhraseContext> |
Candidate.coveredPhrases(Set<org.apache.lens.cube.parse.QueriedPhraseContext> phrases)
Filters phrases that are covered by this candidate
|
Set<Integer> |
JoinCandidate.decideMeasurePhrasesToAnswer(Set<Integer> measureIndices) |
default Set<Integer> |
Candidate.decideMeasurePhrasesToAnswer(Set<Integer> measurePhraseIndices) |
boolean |
UnionCandidate.evaluateCompleteness(TimeRange timeRange,
TimeRange parentTimeRange,
boolean failOnPartialData) |
boolean |
StorageCandidate.evaluateCompleteness(TimeRange timeRange,
TimeRange queriedTimeRange,
boolean failOnPartialData) |
boolean |
SegmentationCandidate.evaluateCompleteness(TimeRange timeRange,
TimeRange queriedTimeRange,
boolean failOnPartialData) |
boolean |
JoinCandidate.evaluateCompleteness(TimeRange timeRange,
TimeRange parentTimeRange,
boolean failOnPartialData) |
boolean |
Candidate.evaluateCompleteness(TimeRange timeRange,
TimeRange queriedTimeRange,
boolean failOnPartialData)
Calculates if this candidate can answer the query for given time range based on actual data registered with
the underlying candidate storages.
|
UnionCandidate |
UnionCandidate.explode() |
Candidate |
StorageCandidate.explode() |
SegmentationCandidate |
SegmentationCandidate.explode() |
JoinCandidate |
JoinCandidate.explode() |
Candidate |
Candidate.explode()
Explode this candidate into another candidate.
|
static DefaultQueryAST |
DefaultQueryAST.fromStorageCandidate(DimHQLContext sc) |
static Set<String> |
HQLParser.getColsInExpr(String tableAlias,
org.apache.hadoop.hive.ql.parse.ASTNode expr) |
static TimeRange |
StorageUtil.getFallbackRange(TimeRange range,
String factName,
CubeQueryContext cubeql)
Get fallback range
|
QueryWriterContext |
CubeQueryContext.getQueryWriterContext(Candidate cand,
Map<Dimension,CandidateDim> dimsToQuery) |
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
|
boolean |
UnionCandidate.isDimAttributeEvaluable(String dim) |
boolean |
StorageCandidate.isDimAttributeEvaluable(String dim) |
boolean |
SegmentationCandidate.isDimAttributeEvaluable(String dim) |
boolean |
JoinCandidate.isDimAttributeEvaluable(String dim) |
boolean |
Candidate.isDimAttributeEvaluable(String dim)
Checks whether a dim attribute is evaluable by this candidate
|
boolean |
UnionCandidate.isPhraseAnswerable(org.apache.lens.cube.parse.QueriedPhraseContext phrase) |
boolean |
StorageCandidate.isPhraseAnswerable(org.apache.lens.cube.parse.QueriedPhraseContext phrase) |
boolean |
JoinCandidate.isPhraseAnswerable(org.apache.lens.cube.parse.QueriedPhraseContext phrase) |
boolean |
Candidate.isPhraseAnswerable(org.apache.lens.cube.parse.QueriedPhraseContext phrase)
Checks whether the given queries phrase is evaluable by this candidate
|
boolean |
UnionCandidate.isTimeRangeCoverable(TimeRange timeRange) |
boolean |
StorageCandidate.isTimeRangeCoverable(TimeRange timeRange)
Is time range coverable based on valid update periods of this storage candidate
|
boolean |
SegmentationCandidate.isTimeRangeCoverable(TimeRange timeRange) |
boolean |
JoinCandidate.isTimeRangeCoverable(TimeRange timeRange) |
boolean |
Candidate.isTimeRangeCoverable(TimeRange timeRange)
Is time range coverable based on start and end times configured in schema for the composing storage candidates
and valid update periods.
|
static org.apache.hadoop.hive.ql.parse.ASTNode |
HQLParser.parseExpr(String expr) |
static org.apache.hadoop.hive.ql.parse.ASTNode |
HQLParser.parseExpr(String expr,
org.apache.hadoop.conf.Configuration conf) |
static org.apache.hadoop.hive.ql.parse.ASTNode |
HQLParser.parseHQL(String query,
org.apache.hadoop.hive.conf.HiveConf conf) |
CubeQueryContext |
CubeQueryRewriter.rewrite(org.apache.hadoop.hive.ql.parse.ASTNode astnode) |
CubeQueryContext |
CubeQueryRewriter.rewrite(String command) |
void |
SegmentationInnerRewriter.rewriteContext(CubeQueryContext cubeql) |
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
|
void |
ColumnLifetimeChecker.rewriteContext(CubeQueryContext cubeql) |
void |
CandidateExploder.rewriteContext(CubeQueryContext cubeql)
Replacing all candidates with their exploded versions in cubeql.getCandidates()
|
void |
CandidateCoveringSetsResolver.rewriteContext(CubeQueryContext cubeql) |
Collection<StorageCandidate> |
StorageCandidate.splitAtUpdatePeriodLevelIfReq()
Splits the Storage Candidates into multiple Storage Candidates if storage candidate has multiple
storage tables (one per update period)
|
org.apache.hadoop.hive.ql.parse.ASTNode |
CubeQueryContext.toAST(org.apache.hadoop.hive.ql.Context ctx) |
String |
SimpleHQLContext.toHQL() |
String |
QueryWriter.toHQL()
Get the HQL query.
|
String |
CubeQueryContext.toHQL() |
QueryWriter |
QueryWriterContext.toQueryWriter() |
UnionQueryWriter |
MultiCandidateQueryWriterContext.toQueryWriter() |
QueryWriter |
DimHQLContext.toQueryWriter() |
StorageCandidateHQLContext |
StorageCandidate.toQueryWriterContext(Map<Dimension,CandidateDim> dimsToQuery,
CubeQueryContext rootCubeQueryContext) |
default QueryWriterContext |
Candidate.toQueryWriterContext(Map<Dimension,CandidateDim> dimsToQuery,
CubeQueryContext rootCubeQueryContext)
Get query writer context from the candidate.
|
void |
StorageCandidateHQLContext.updateDimFilterWithFactFilter() |
void |
QueryWriterContext.updateDimFilterWithFactFilter() |
void |
MultiCandidateQueryWriterContext.updateDimFilterWithFactFilter() |
void |
DimOnlyHQLContext.updateDimFilterWithFactFilter() |
void |
StorageCandidateHQLContext.updateFromString() |
void |
QueryWriterContext.updateFromString() |
void |
MultiCandidateQueryWriterContext.updateFromString() |
void |
DimOnlyHQLContext.updateFromString() |
default void |
Candidate.updateStorageCandidateQueriablePhraseIndices(List<org.apache.lens.cube.parse.QueriedPhraseContext> qpcList)
Default method to update querieble phrase indices in candidate
|
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) |
SegmentationCandidate(SegmentationCandidate segmentationCandidate) |
StorageCandidate(CubeInterface cube,
FactTable fact,
String storageName,
CubeQueryContext cubeQueryContext) |
StorageCandidate(StorageCandidate sc) |
Modifier and Type | Method and Description |
---|---|
String |
BridgeTableJoinContext.generateJoinClause(String joinTypeStr,
String toAlias) |
String |
AutoJoinContext.getFromString(String fromTable,
DimHQLContext sc,
Map<Dimension,CandidateDim> dimsToQuery,
CubeQueryContext cubeql) |
String |
AutoJoinContext.getMergedJoinClause(CubeQueryContext cubeql,
DimHQLContext sc,
JoinClause joinClause,
Map<Dimension,CandidateDim> dimsToQuery) |
Set<Dimension> |
AutoJoinContext.pickOptionalTables(DimHQLContext sc,
Set<Dimension> qdims,
CubeQueryContext cubeql) |
void |
AutoJoinContext.pruneAllPaths(CubeInterface cube,
Collection<String> candColumns,
Map<Dimension,CandidateDim> dimsToQuery)
Prunes the join chains defined in Cube whose starting column is not there in any of the candidate facts.
|
void |
AutoJoinContext.pruneAllPathsForCandidateDims(Map<Dimension,Set<CandidateDim>> candidateDims)
Prunes allPaths by removing paths which contain columns that are not present in any candidate dims.
|
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,
String driverType,
String driverName) |
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 | 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,
String driverType,
String driverName) |
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) |
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 |
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 |
---|---|
void |
DruidSQLRewriter.buildDruidQuery(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hive.conf.HiveConf hconf)
Builds the query.
|
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,
String driverType,
String driverName) |
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.
|
LensResultSetMetadata |
JDBCResultSet.getMetadata() |
boolean |
JDBCResultSet.hasNext() |
void |
JDBCDriver.init()
Inits the.
|
ResultRow |
JDBCResultSet.next() |
void |
JDBCDriver.prepare(PreparedQueryContext pContext)
Prepare the given query.
|
String |
DruidSQLRewriter.rewrite(org.apache.hadoop.hive.ql.parse.ASTNode currNode,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hive.conf.HiveConf metastoreConf,
boolean resolveNativeTables) |
String |
JDBCDriver.DummyQueryRewriter.rewrite(String query,
org.apache.hadoop.conf.Configuration queryConf,
org.apache.hadoop.hive.conf.HiveConf metastoreConf) |
String |
DruidSQLRewriter.rewrite(String query,
org.apache.hadoop.conf.Configuration conf,
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) |
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.closeSession() |
void |
SessionHelper.closeSession(String sessionHandleString) |
void |
SessionHelper.closeSession(String sessionHandleString,
String outputMediaType)
Close a Session
|
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<QueryCostTO> |
QueryHelper.estimateQuery(String queryString) |
LensAPIResult<QueryCostTO> |
QueryHelper.estimateQuery(String queryString,
String sessionHandleString) |
LensAPIResult<QueryCostTO> |
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) |
LensAPIResult |
QueryHelper.executeQuery(String queryString,
String queryName,
String user,
String sessionHandleString,
LensConf conf)
Execute the query
|
LensAPIResult |
QueryHelper.executeQuery(String queryString,
String queryName,
String sessionHandleString,
String conf,
String outputMediaType)
Execute with conf
|
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,
LensConf conf) |
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<QueryPlan> |
QueryHelper.explainQuery(String queryString) |
LensAPIResult<QueryPlan> |
QueryHelper.explainQuery(String queryString,
String sessionHandleString) |
LensAPIResult<QueryPlan> |
QueryHelper.explainQuery(String queryString,
String sessionHandleString,
String conf)
Explain the query
|
StringList |
MetastoreHelper.getAllFactsOfCube(String cubeName,
String sessionHandleString) |
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
|
String |
QueryHelper.getInmemoryResultSetJson(QueryHandle queryHandle,
String fromIndex,
String fetchSize,
String sessionHandleString) |
LensQuery |
QueryHelper.getLensQuery(String sessionHandleString,
QueryHandle queryHandle) |
String |
QueryHelper.getPersistentResultSetJson(QueryHandle queryHandle) |
String |
QueryHelper.getPersistentResultSetJson(QueryHandle queryHandle,
String fromIndex,
String fetchSize) |
String |
QueryHelper.getPersistentResultSetJson(QueryHandle queryHandle,
String fromIndex,
String fetchSize,
String sessionHandleString)
Get the Result set for json
|
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) |
javax.ws.rs.core.Response |
QueryHelper.getResultSetResponse(QueryHandle queryHandle,
String fromIndex,
String fetchSize,
String sessionHandleString)
Get the Result set
|
SavedQuery |
SavedQueryResourceHelper.getSavedQuery(Long queryId) |
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.openSession() |
String |
SessionHelper.openSession(String database) |
String |
SessionHelper.openSession(String userName,
String password) |
String |
SessionHelper.openSession(String userName,
String password,
String database) |
String |
SessionHelper.openSession(String userName,
String password,
String database,
String outputMediaType) |
javax.ws.rs.core.Response |
SessionHelper.openSessionReturnResponse(String userName,
String password,
String database,
String outputMediaType)
Open a New Session
|
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
|
void |
LensServerHelper.start() |
void |
LensServerHelper.stop() |
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) |
LensQuery |
QueryHelper.waitForCompletion(String sessionHandleString,
QueryHandle queryHandle,
javax.ws.rs.core.MediaType inputMediaType,
String outputMediaType)
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 LensException |
LensServices.processLensException(LensException exc) |
Modifier and Type | Method and Description |
---|---|
static LensException |
LensServices.processLensException(LensException exc) |
Modifier and Type | Method and Description |
---|---|
void |
BaseLensService.closeSession(LensSessionHandle sessionHandle)
Close session.
|
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) |
void |
EventServiceImpl.notifyEventSync(LensEvent event) |
LensSessionHandle |
BaseLensService.openSession(String username,
String password,
Map<String,String> configuration)
Open session.
|
LensSessionHandle |
BaseLensService.openSession(String username,
String password,
Map<String,String> configuration,
boolean auth) |
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.
|
void |
BaseLensService.validateSession(LensSessionHandle handle) |
Modifier and Type | Method and Description |
---|---|
void |
SessionValidator.validateSession(LensSessionHandle handle) |
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,
String driverType,
String driverName)
Configure driver with
Configuration passed. |
void |
AbstractLensDriver.configure(org.apache.hadoop.conf.Configuration conf,
String driverType,
String driverName) |
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.
|
LensResultSet |
AbstractLensDriver.fetchResultSet(QueryContext ctx)
Default implementation for fetchResultSet for all drivers.
|
abstract Long |
PersistentResultSet.getFileSize()
Get the size of the result set file.
|
LensResultSetMetadata |
PartiallyFetchedInMemoryResultSet.getMetadata() |
abstract LensResultSetMetadata |
LensResultSet.getMetadata()
Get the result set metadata
|
abstract String |
LensResultSet.getOutputPath() |
String |
InMemoryResultSet.getOutputPath() |
boolean |
PartiallyFetchedInMemoryResultSet.hasNext() |
abstract boolean |
InMemoryResultSet.hasNext()
Whether there is another result row available.
|
boolean |
PersistentResultSet.isHttpResultAvailable() |
abstract boolean |
LensResultSet.isHttpResultAvailable() |
boolean |
InMemoryResultSet.isHttpResultAvailable() |
ResultRow |
PartiallyFetchedInMemoryResultSet.next() |
abstract ResultRow |
InMemoryResultSet.next()
Read the next result row.
|
void |
LensDriver.prepare(PreparedQueryContext pContext)
Prepare the given query.
|
void |
LensDriver.registerForCompletionNotification(QueryContext context,
long timeoutMillis,
QueryCompletionListener listener)
Register for query completion notification.
|
void |
PartiallyFetchedInMemoryResultSet.setFetchSize(int size) |
abstract void |
InMemoryResultSet.setFetchSize(int size)
Set number of rows to be fetched at time
|
Integer |
PartiallyFetchedInMemoryResultSet.size() |
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.
|
Constructor and Description |
---|
PartiallyFetchedInMemoryResultSet(InMemoryResultSet inMemoryRS,
int reqPreFetchSize)
Constructor
|
Modifier and Type | Method and Description |
---|---|
static ChainedDriverQueryHook |
ChainedDriverQueryHook.from(org.apache.hadoop.conf.Configuration conf,
String key) |
void |
NoOpDriverQueryHook.postDriverSelection(AbstractQueryContext ctx) |
void |
DriverQueryHook.postDriverSelection(AbstractQueryContext ctx)
Called just after driver has been selected to execute a query.
|
void |
ChainedDriverQueryHook.postDriverSelection(AbstractQueryContext ctx) |
void |
QueryCostBasedQueryHook.postEstimate(AbstractQueryContext ctx) |
void |
NoOpDriverQueryHook.postEstimate(AbstractQueryContext ctx) |
void |
DriverQueryHook.postEstimate(AbstractQueryContext ctx)
Called just after a successful estimate operation is tried on this driver
|
void |
ChainedDriverQueryHook.postEstimate(AbstractQueryContext ctx) |
void |
NoOpDriverQueryHook.postRewrite(AbstractQueryContext ctx) |
void |
DriverQueryHook.postRewrite(AbstractQueryContext ctx)
Called just after a successful rewrite operation is tried on this driver
|
void |
ChainedDriverQueryHook.postRewrite(AbstractQueryContext ctx) |
void |
NoOpDriverQueryHook.preEstimate(AbstractQueryContext ctx) |
void |
DriverQueryHook.preEstimate(AbstractQueryContext ctx)
Called just before estimate operation is tried on this driver
Note : Estimate operation will be skipped if rewrite operation fails for this driver
|
void |
ChainedDriverQueryHook.preEstimate(AbstractQueryContext ctx) |
void |
NoOpDriverQueryHook.preLaunch(QueryContext ctx) |
void |
DriverQueryHook.preLaunch(QueryContext ctx)
Called just before launching the query on the selected driver.
|
void |
ChainedDriverQueryHook.preLaunch(QueryContext ctx) |
void |
UserBasedQueryHook.preRewrite(AbstractQueryContext ctx) |
void |
NoOpDriverQueryHook.preRewrite(AbstractQueryContext ctx) |
void |
DriverQueryHook.preRewrite(AbstractQueryContext ctx)
Called just before rewrite operation is tried on this driver
|
void |
ChainedDriverQueryHook.preRewrite(AbstractQueryContext ctx) |
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 |
LensEventService.notifyEventSync(LensEvent event)
Process an event synchronously.
|
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,
XFact fact)
Create fact table
|
void |
CubeMetastoreService.createSegmentation(LensSessionHandle sessionid,
XSegmentation cubeSeg) |
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.dropSegmentation(LensSessionHandle sessionid,
String cubeSegName)
Update segmentation
|
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.getAllSegmentations(LensSessionHandle sessionid,
String cubeName)
Get all segmentations belong to Cube
|
List<String> |
CubeMetastoreService.getAllStorageNames(LensSessionHandle sessionid)
Get all storage names in current database
|
Map<String,Map<Date,Float>> |
DefaultChecker.getCompleteness(String factTag,
Date start,
Date end,
Set<String> measureTag) |
Map<String,Map<Date,Float>> |
DataCompletenessChecker.getCompleteness(String factTag,
Date start,
Date end,
Set<String> measureTag)
Get completeness of the set of measures in a fact based on the dataCompletenessTag for the given starttime and
endtime.
|
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
|
XFact |
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) |
XSegmentation |
CubeMetastoreService.getSegmentation(LensSessionHandle sessionid,
String segName)
Create segmentation
|
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,
XFact 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) |
void |
CubeMetastoreService.updateSegmentation(LensSessionHandle sessionid,
XSegmentation cubeSeg)
Get segmentation given by name
|
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,
String fromDate,
String toDate)
Returns all the prepared queries for the specified user.
|
List<QueryHandle> |
QueryExecutionService.getAllQueries(LensSessionHandle sessionHandle,
String states,
String user,
String driver,
String queryName,
String fromDate,
String toDate)
Returns all the queries in the specified state, for the given user and matching query name.
|
List<LensQuery> |
QueryExecutionService.getAllQueryDetails(LensSessionHandle sessionHandle,
String states,
String user,
String driver,
String queryName,
String fromDate,
String 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 |
QueryContext.registerDriverResult(LensResultSet result) |
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) |
void |
QueryContext.updateDriverStatus(BackOffRetryHandler statusUpdateRetryHandler)
Update status from selected driver
|
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(LensSessionHandle handle,
long id)
Deletes the saved query specified.
|
SavedQuery |
SavedQueryService.get(LensSessionHandle handle,
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(LensSessionHandle handle,
long id,
String sharingUser,
String targetUserPath,
String[] privileges)
Grant permissions for users to do actions on the saved query.
|
ListResponse |
SavedQueryService.list(LensSessionHandle handle,
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(LensSessionHandle handle,
long id,
String sharingUser,
String targetUserPath,
String[] privileges)
Revoke permissions from users to do actions on the saved query.
|
long |
SavedQueryService.save(LensSessionHandle handle,
SavedQuery query)
Saves a query
|
void |
SavedQueryService.update(LensSessionHandle handle,
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 |
---|---|
static <FC extends FailureContext> |
ChainedRetryPolicyDecider.from(org.apache.hadoop.conf.Configuration conf,
String key) |
Modifier and Type | Method and Description |
---|---|
void |
SchedulerService.deleteJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
Delete a job.
|
void |
SchedulerService.expireJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
End a job by specifying an expiry time.
|
List<SchedulerJobHandle> |
SchedulerService.getAllJobs(String user,
SchedulerJobState state,
Long start,
Long end)
Get all jobs matching the filter parameters.
|
Collection<SchedulerJobStats> |
SchedulerService.getAllJobStats(String state,
String user,
String jobName,
long startTime,
long endTime) |
SchedulerJobInstanceInfo |
SchedulerService.getInstanceDetails(SchedulerJobInstanceHandle instanceHandle)
Instance details for an instance.
|
XJob |
SchedulerService.getJobDefinition(SchedulerJobHandle jobHandle)
Returns the definition of a job.
|
SchedulerJobInfo |
SchedulerService.getJobDetails(SchedulerJobHandle jobHandle)
Returns the details of a job.
|
List<SchedulerJobInstanceInfo> |
SchedulerService.getJobInstances(SchedulerJobHandle jobHandle,
Long numResults)
Returns handles for last
numResults instances for the job. |
SchedulerJobStats |
SchedulerService.getJobStats(SchedulerJobHandle handle,
String state,
long startTime,
long endTime)
Returns stats for a job.
|
boolean |
SchedulerService.killInstance(LensSessionHandle sessionHandle,
SchedulerJobInstanceHandle instanceHandle)
Kills a running job instance.
|
LensSessionHandle |
SchedulerService.openSessionAsUser(String user)
Create session as user for scheduling the job with no auth.
|
void |
SchedulerService.rerunInstance(LensSessionHandle sessionHandle,
SchedulerJobInstanceHandle instanceHandle)
Reruns a failed/killed/completed job instance.
|
void |
SchedulerService.resumeJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
Resume a job from a given time.
|
void |
SchedulerService.scheduleJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
Schedule a job.
|
SchedulerJobHandle |
SchedulerService.submitAndScheduleJob(LensSessionHandle sessionHandle,
XJob job)
Submit a job and also schedule it.
|
SchedulerJobHandle |
SchedulerService.submitJob(LensSessionHandle sessionHandle,
XJob job)
Submit a job.
|
void |
SchedulerService.suspendJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
Suspend a job.
|
void |
SchedulerService.updateJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle,
XJob newJobDefinition)
Update a job with new definition.
|
Modifier and Type | Method and Description |
---|---|
void |
SessionService.cleanupIdleSessions()
Close idle sessions.
|
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 |
UnSupportedOpException |
Modifier and Type | Method and Description |
---|---|
void |
CubeMetastoreServiceImpl.addDimTableStorage(LensSessionHandle sessionid,
String dimTblName,
XStorageTableElement storageTable) |
APIResult |
MetastoreResource.addPartitionsToDimStorage(LensSessionHandle sessionid,
String dimTableName,
String storage,
XPartitionList partitions)
Add new partitions for a storage of dimension
|
int |
CubeMetastoreServiceImpl.addPartitionsToDimStorage(LensSessionHandle sessionid,
String dimTblName,
String storageName,
XPartitionList partitions) |
APIResult |
MetastoreResource.addPartitionsToFactStorage(LensSessionHandle sessionid,
String factName,
String storage,
XPartitionList partitions)
Batch Add partitions for a storage of fact
|
int |
CubeMetastoreServiceImpl.addPartitionsToFactStorage(LensSessionHandle sessionid,
String fact,
String storageName,
XPartitionList partitions) |
APIResult |
MetastoreResource.addPartitionToDimStorage(LensSessionHandle sessionid,
String dimTableName,
String storage,
XPartition partition)
Add a new partition for a storage of dimension
|
int |
CubeMetastoreServiceImpl.addPartitionToDimStorage(LensSessionHandle sessionid,
String dimTblName,
String storageName,
XPartition partition) |
APIResult |
MetastoreResource.addPartitionToFactStorage(LensSessionHandle sessionid,
String factName,
String storage,
XPartition partition)
Add a new partition for a storage of fact
|
int |
CubeMetastoreServiceImpl.addPartitionToFactStorage(LensSessionHandle sessionid,
String fact,
String storageName,
XPartition partition) |
APIResult |
MetastoreResource.addStorageToFact(LensSessionHandle sessionid,
String factName,
XStorageTableElement storageTable)
Add storage to fact table
|
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
|
APIResult |
MetastoreResource.createDatabase(LensSessionHandle sessionid,
boolean ignoreIfExisting,
String dbName)
Create a new database
|
void |
CubeMetastoreServiceImpl.createDatabase(LensSessionHandle sessionid,
String database,
boolean ignore)
Create a database in Hive metastore
|
APIResult |
MetastoreResource.createDimension(LensSessionHandle sessionid,
XDimension dimension)
Create new dimension
|
void |
CubeMetastoreServiceImpl.createDimension(LensSessionHandle sessionid,
XDimension dimension) |
APIResult |
MetastoreResource.createDimensionStorage(LensSessionHandle sessionid,
String dimTableName,
XStorageTableElement storageTbl)
Add storage to dimension table
|
APIResult |
MetastoreResource.createDimensionTable(LensSessionHandle sessionid,
XDimensionTable dimensionTable)
Create a new dimension table
|
void |
CubeMetastoreServiceImpl.createDimensionTable(LensSessionHandle sessionid,
XDimensionTable xDimTable)
Create a cube dimension table based on JAXB object
|
APIResult |
MetastoreResource.createFactTable(LensSessionHandle sessionid,
XFact fact)
Create a new fact tabble
|
void |
CubeMetastoreServiceImpl.createFactTable(LensSessionHandle sessionid,
XFact fact) |
APIResult |
MetastoreResource.createNewCube(LensSessionHandle sessionid,
XCube cube)
Create a new cube
|
APIResult |
MetastoreResource.createNewStorage(LensSessionHandle sessionid,
XStorage storage)
Create new storage
|
APIResult |
MetastoreResource.createSegmentation(LensSessionHandle sessionid,
XSegmentation seg)
Create a new segmentation
|
void |
CubeMetastoreServiceImpl.createSegmentation(LensSessionHandle sessionid,
XSegmentation cubeSeg) |
void |
CubeMetastoreServiceImpl.createStorage(LensSessionHandle sessionid,
XStorage storage) |
APIResult |
MetastoreResource.Entity.delete(LensSessionHandle sessionid,
String entityName) |
APIResult |
MetastoreResource.Entity.delete(LensSessionHandle sessionid,
String entityName,
Boolean cascade) |
APIResult |
MetastoreResource.Entity.deleteAll(LensSessionHandle sessionid,
Boolean cascade) |
APIResult |
MetastoreResource.deleteAllCubes(LensSessionHandle sessionid)
Delete all cubes
|
APIResult |
MetastoreResource.deleteAllDimensions(LensSessionHandle sessionid)
Delete all dimensions in metastore
|
APIResult |
MetastoreResource.deleteAllFacts(LensSessionHandle sessionid,
boolean cascade)
Delete all fact tables
|
APIResult |
MetastoreResource.deleteAllSegmentations(LensSessionHandle sessionid)
Delete all segmentations
|
APIResult |
MetastoreResource.deleteAllStorages(LensSessionHandle sessionid)
Delete all storages in metastore
|
abstract void |
MetastoreResource.Entity.doDelete(LensSessionHandle sessionid,
String entityName,
Boolean cascade) |
abstract List<String> |
MetastoreResource.Entity.doGetAll(LensSessionHandle sessionid) |
APIResult |
MetastoreResource.dropAllStoragesOfDim(LensSessionHandle sessionid,
String dimTableName)
Drop all the storage tables of a dimension table
|
void |
CubeMetastoreServiceImpl.dropAllStoragesOfDimTable(LensSessionHandle sessionid,
String dimTblName) |
APIResult |
MetastoreResource.dropAllStoragesOfFact(LensSessionHandle sessionid,
String factName)
Drop all the storage tables of a fact table
|
void |
CubeMetastoreServiceImpl.dropAllStoragesOfFact(LensSessionHandle sessionid,
String factName) |
APIResult |
MetastoreResource.dropCube(LensSessionHandle sessionid,
String cubeName)
Drop the cube, specified by name
|
void |
CubeMetastoreServiceImpl.dropCube(LensSessionHandle sessionid,
String cubeName)
Drop a cube from the metastore in the currently deleted database
|
APIResult |
MetastoreResource.dropDatabase(LensSessionHandle sessionid,
String dbName,
boolean cascade)
Delete the db specified by name.
|
void |
CubeMetastoreServiceImpl.dropDatabase(LensSessionHandle sessionid,
String database,
boolean cascade)
Drop a database from cube metastore
|
APIResult |
MetastoreResource.dropDimension(LensSessionHandle sessionid,
String dimName)
Drop the dimension, specified by name
|
void |
CubeMetastoreServiceImpl.dropDimension(LensSessionHandle sessionid,
String dimName) |
APIResult |
MetastoreResource.dropDimensionTable(LensSessionHandle sessionid,
String dimension,
boolean cascade)
Drop the dimension table, specified by name
|
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) |
APIResult |
MetastoreResource.dropPartitionOfFactStorageByValues(LensSessionHandle sessionid,
String factName,
String storage,
String values)
Drop the partitions in the storage of a fact table, specified by exact values
|
APIResult |
MetastoreResource.dropPartitionsOfDimStorageByFilter(LensSessionHandle sessionid,
String dimTableName,
String storage,
String filter)
Drop the partitions in the storage of a dimension table; can specified filter as well
|
APIResult |
MetastoreResource.dropPartitionsOfDimStorageByValue(LensSessionHandle sessionid,
String dimTableName,
String storage,
String values)
Drop the partitions in the storage of a dimension table, specified by exact values
|
APIResult |
MetastoreResource.dropPartitionsOfFactStorageByFilter(LensSessionHandle sessionid,
String factName,
String storage,
String filter)
Drop the partitions in the storage of a fact; can specified filter as well
|
APIResult |
MetastoreResource.dropSegmentation(LensSessionHandle sessionid,
String segmentationName)
Drop the segmentation, specified by name
|
void |
CubeMetastoreServiceImpl.dropSegmentation(LensSessionHandle sessionid,
String cubeSegName) |
APIResult |
MetastoreResource.dropStorage(LensSessionHandle sessionid,
String storageName)
Drop the storage, specified by name
|
void |
CubeMetastoreServiceImpl.dropStorage(LensSessionHandle sessionid,
String storageName) |
APIResult |
MetastoreResource.dropStorageFromFact(LensSessionHandle sessionid,
String factName,
String storage)
Drop the storage of a fact, specified by name
|
APIResult |
MetastoreResource.dropStorageOfDim(LensSessionHandle sessionid,
String dimTableName,
String storage)
Drop the storage of a dimension table, specified by name
|
void |
CubeMetastoreServiceImpl.dropStorageOfDimTable(LensSessionHandle sessionid,
String dimTblName,
String storage) |
void |
CubeMetastoreServiceImpl.dropStorageOfFact(LensSessionHandle sessionid,
String fact,
String storage) |
StringList |
MetastoreResource.Entity.getAll(LensSessionHandle sessionid) |
List<String> |
CubeMetastoreServiceImpl.getAllBaseCubeNames(LensSessionHandle sessionid) |
List<String> |
CubeMetastoreServiceImpl.getAllCubeNames(LensSessionHandle sessionid)
Get list of all cubes names in the current database
|
StringList |
MetastoreResource.getAllCubes(LensSessionHandle sessionid,
String cubeTypes)
Get all cubes in the metastores, of the specified type
|
StringList |
MetastoreResource.getAllDatabases(LensSessionHandle sessionid)
Get all databases in the metastore
|
List<String> |
CubeMetastoreServiceImpl.getAllDatabases(LensSessionHandle sessionid) |
List<String> |
CubeMetastoreServiceImpl.getAllDerivedCubeNames(LensSessionHandle sessionid) |
StringList |
MetastoreResource.getAllDimensionNames(LensSessionHandle sessionid)
Get all dimensions in the metastore
|
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) |
StringList |
MetastoreResource.getAllNativeTables(LensSessionHandle sessionid,
String dbOption,
String dbName)
Get all native tables.
|
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 dimTable,
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) |
StringList |
MetastoreResource.getAllSegmentations(LensSessionHandle sessionid)
Get all segmentations in the current database
|
List<String> |
CubeMetastoreServiceImpl.getAllSegmentations(LensSessionHandle sessionid,
String cubeName) |
StringList |
MetastoreResource.getAllSegmentationsOfCube(LensSessionHandle sessionid,
String cubeName)
Get all segmentations that belong to a cube in the metastore
|
List<String> |
CubeMetastoreServiceImpl.getAllStorageNames(LensSessionHandle sessionid) |
StringList |
MetastoreResource.getAllStorages(LensSessionHandle sessionid)
Get all storages in the metastore
|
JAXBElement<XCube> |
MetastoreResource.getCube(LensSessionHandle sessionid,
String cubeName)
Get the cube specified by name
|
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
|
String |
MetastoreResource.getDatabase(LensSessionHandle sessionid)
Get the current database
|
JAXBElement<XDimension> |
MetastoreResource.getDimension(LensSessionHandle sessionid,
String dimName)
Get the dimension specified by name
|
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<XFact> |
MetastoreResource.getFactTable(LensSessionHandle sessionid,
String factName)
Get the fact table specified by name
|
XFact |
CubeMetastoreServiceImpl.getFactTable(LensSessionHandle sessionid,
String fact) |
JAXBElement<XFlattenedColumns> |
MetastoreResource.getFlattenedColumns(LensSessionHandle sessionid,
String tableName,
boolean addChains)
Get flattened list of columns reachable from a cube or a dimension
|
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) |
JAXBElement<XNativeTable> |
MetastoreResource.getNativeTable(LensSessionHandle sessionid,
String tableName)
Get the native table passed in name
|
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) |
JAXBElement<XSegmentation> |
MetastoreResource.getSegmentation(LensSessionHandle sessionid,
String segmentationName)
Get the segmentation specified by name
|
XSegmentation |
CubeMetastoreServiceImpl.getSegmentation(LensSessionHandle sessionid,
String cubeSegName) |
JAXBElement<XStorage> |
MetastoreResource.getStorage(LensSessionHandle sessionid,
String storageName)
Get the storage specified by 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
|
APIResult |
MetastoreResource.setDatabase(LensSessionHandle sessionid,
String dbName)
Set the current db
|
APIResult |
MetastoreResource.updateCube(LensSessionHandle sessionid,
String cubeName,
XCube cube)
Update cube definition
|
void |
CubeMetastoreServiceImpl.updateCube(LensSessionHandle sessionid,
XCube cube)
Update cube
|
APIResult |
MetastoreResource.updateCubeDimension(LensSessionHandle sessionid,
String dimTableName,
XDimensionTable dimensionTable)
Update dimension table definition
|
APIResult |
MetastoreResource.updateDimension(LensSessionHandle sessionid,
String dimName,
XDimension dimension)
Update dimension definition
|
void |
CubeMetastoreServiceImpl.updateDimension(LensSessionHandle sessionid,
String dimName,
XDimension dimension) |
void |
CubeMetastoreServiceImpl.updateDimensionTable(LensSessionHandle sessionid,
XDimensionTable dimensionTable) |
APIResult |
MetastoreResource.updateFactTable(LensSessionHandle sessionid,
String factName,
XFact fact)
Update fact table definition
|
void |
CubeMetastoreServiceImpl.updateFactTable(LensSessionHandle sessionid,
XFact fact) |
void |
CubeMetastoreServiceImpl.updatePartition(LensSessionHandle sessionid,
String tblName,
String storageName,
XPartition xPartition) |
APIResult |
MetastoreResource.updatePartitionOfDimStorage(LensSessionHandle sessionid,
String dimTableName,
String storage,
XPartition partition)
Updates an existing partition for a storage of dimension
|
APIResult |
MetastoreResource.updatePartitionOfFactStorage(LensSessionHandle sessionid,
String factName,
String storage,
XPartition partition)
updates an existing partition for a storage of fact
|
void |
CubeMetastoreServiceImpl.updatePartitions(LensSessionHandle sessionid,
String tblName,
String storageName,
XPartitionList xPartitions) |
APIResult |
MetastoreResource.updatePartitionsOfDimStorage(LensSessionHandle sessionid,
String dimTableName,
String storage,
XPartitionList partitions)
Add new partitions for a storage of dimension
|
APIResult |
MetastoreResource.updatePartitionsOfFactStorage(LensSessionHandle sessionid,
String factName,
String storage,
XPartitionList partitions)
Batch Update partitions for a storage of fact
|
APIResult |
MetastoreResource.updateSegmentation(LensSessionHandle sessionid,
String segmentationName,
XSegmentation seg)
Update segmentation
|
void |
CubeMetastoreServiceImpl.updateSegmentation(LensSessionHandle sessionid,
XSegmentation cubeSeg) |
APIResult |
MetastoreResource.updateStorage(LensSessionHandle sessionid,
String storageName,
XStorage storage)
Update storage definition
|
Modifier and Type | Method and Description |
---|---|
LensException |
QueryExecutionServiceImpl.RewriteEstimateRunnable.getCause() |
Modifier and Type | Method and Description |
---|---|
APIResult |
QueryServiceResource.cancelAllQueries(LensSessionHandle sessionid,
String state,
String user,
String queryName,
String driver,
String fromDate,
String toDate)
Cancel all the queries in query server; can be filtered with state and user.
|
boolean |
QueryExecutionServiceImpl.cancelQuery(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
APIResult |
QueryServiceResource.cancelQuery(LensSessionHandle sessionid,
String queryHandle)
Cancel the query specified by the handle.
|
void |
QueryExecutionServiceImpl.closeResultSet(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
APIResult |
QueryServiceResource.closeResultSet(LensSessionHandle sessionid,
String queryHandle)
Close the result set once fetching is done.
|
void |
QueryExecutionServiceImpl.deleteResource(LensSessionHandle sessionHandle,
String type,
String path) |
boolean |
QueryExecutionServiceImpl.destroyPrepared(LensSessionHandle sessionHandle,
QueryPrepareHandle prepared) |
APIResult |
QueryServiceResource.destroyPrepared(LensSessionHandle sessionid,
String prepareHandle)
Destroy the prepared query specified by handle.
|
APIResult |
QueryServiceResource.destroyPreparedQueries(LensSessionHandle sessionid,
String user,
String queryName,
String fromDate,
String toDate)
Destroy all the prepared queries; Can be filtered with user.
|
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) |
QuerySubmitResult |
QueryServiceResource.executePrepared(LensSessionHandle sessionid,
String prepareHandle,
String operation,
LensConf conf,
Long timeoutmillis,
String queryName)
Submit prepared query for execution.
|
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(List<QueryStatus.Status> states,
String user,
String driverName,
String queryName,
long fromDate,
long toDate)
Find finished queries.
|
List<FinishedLensQuery> |
LensServerDAO.findFinishedQueryDetails(List<QueryStatus.Status> states,
String user,
String driverName,
String queryName,
long fromDate,
long toDate)
Find finished queries.
|
List<QueryPrepareHandle> |
QueryServiceResource.getAllPreparedQueries(LensSessionHandle sessionid,
String user,
String queryName,
String fromDate,
String toDate)
Get all prepared queries in the query server; can be filtered with user.
|
List<QueryPrepareHandle> |
QueryExecutionServiceImpl.getAllPreparedQueries(LensSessionHandle sessionHandle,
String user,
String queryName,
String fromDate,
String toDate) |
List<QueryHandle> |
QueryServiceResource.getAllQueries(LensSessionHandle sessionid,
String states,
String queryName,
String user,
String driver,
String fromDate,
String toDate)
Get all the queries in the query server; can be filtered with state and queryName.
|
List<QueryHandle> |
QueryExecutionServiceImpl.getAllQueries(LensSessionHandle sessionHandle,
String states,
String userName,
String driver,
String queryName,
String fromDate,
String toDate) |
List<LensQuery> |
QueryServiceResource.getAllQueryDetails(LensSessionHandle sessionid,
String states,
String queryName,
String user,
String driver,
String fromDate,
String toDate)
Get all the queries in the query server; can be filtered with state and queryName.
|
List<LensQuery> |
QueryExecutionServiceImpl.getAllQueryDetails(LensSessionHandle sessionHandle,
String states,
String userName,
String driver,
String queryName,
String fromDate,
String toDate) |
Long |
LensPersistentResult.getFileSize() |
javax.ws.rs.core.Response |
QueryExecutionServiceImpl.getHttpResultSet(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
javax.ws.rs.core.Response |
QueryServiceResource.getHttpResultSet(LensSessionHandle sessionid,
String queryHandle)
Get the http endpoint for result set.
|
LensResultSetMetadata |
LensPersistentResult.getMetadata() |
String |
LensPersistentResult.getOutputPath() |
LensPreparedQuery |
QueryExecutionServiceImpl.getPreparedQuery(LensSessionHandle sessionHandle,
QueryPrepareHandle prepareHandle) |
LensPreparedQuery |
QueryServiceResource.getPreparedQuery(LensSessionHandle sessionid,
String prepareHandle)
Get a prepared query specified by handle.
|
LensQuery |
QueryExecutionServiceImpl.getQuery(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
QueryResult |
QueryServiceResource.getResultSet(LensSessionHandle sessionid,
String queryHandle,
long startIndex,
int fetchSize)
Fetch the result set.
|
QueryResultSetMetadata |
QueryExecutionServiceImpl.getResultSetMetadata(LensSessionHandle sessionHandle,
QueryHandle queryHandle) |
QueryResultSetMetadata |
QueryServiceResource.getResultSetMetadata(LensSessionHandle sessionid,
String queryHandle)
Get resultset metadata of the query.
|
LensQuery |
QueryServiceResource.getStatus(LensSessionHandle sessionid,
String queryHandle)
Get lens query and its current status.
|
void |
QueryExecutionServiceImpl.QueryStatusLogger.onEvent(StatusChange event) |
QueryPrepareHandle |
QueryExecutionServiceImpl.prepare(LensSessionHandle sessionHandle,
String query,
LensConf lensConf,
String queryName) |
LensAPIResult<QuerySubmitResult> |
QueryServiceResource.prepareQuery(LensSessionHandle sessionid,
String query,
String operation,
LensConf conf,
String queryName)
Prepare a query or 'explain and prepare' the query.
|
LensAPIResult<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() |
APIResult |
QueryServiceResource.updateConf(LensSessionHandle sessionid,
String queryHandle,
LensConf conf)
Modify query configuration if it is not running yet.
|
APIResult |
QueryServiceResource.updatePreparedConf(LensSessionHandle sessionid,
String prepareHandle,
LensConf conf)
Modify prepared query's configuration.
|
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(LensSessionHandle handle,
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(LensSessionHandle handle,
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(LensSessionHandle handle,
long id,
String sharingUser,
String targetUserPath,
String[] privileges)
Grant permissions for users to do actions on the saved query.
|
ListResponse |
SavedQueryServiceImpl.list(LensSessionHandle handle,
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(LensSessionHandle handle,
long id,
String sharingUser,
String targetUserPath,
String[] privileges)
Revoke permissions from users to do actions on the saved query.
|
LensAPIResult<QueryHandle> |
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(LensSessionHandle handle,
SavedQuery savedQuery)
Saves a query
|
long |
SavedQueryDao.saveQuery(SavedQuery savedQuery)
Saves the query passed
|
void |
SavedQueryServiceImpl.update(LensSessionHandle handle,
long id,
SavedQuery savedQuery)
Updates the specified saved query with the new object.
|
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 |
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 |
---|---|
static CubeMetastoreClient |
RewriteUtil.getClient(org.apache.hadoop.hive.conf.HiveConf conf) |
void |
UserQueryToCubeQueryRewriter.rewrite(AbstractQueryContext ctx) |
String |
CubeKeywordRemover.rewrite(String query,
org.apache.hadoop.conf.Configuration queryConf,
org.apache.hadoop.hive.conf.HiveConf metastoreConf) |
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 |
---|---|
boolean |
AlarmService.checkExists(SchedulerJobHandle handle) |
void |
SchedulerServiceImpl.deleteJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
Delete a job.
|
LensAPIResult |
ScheduleResource.deleteJob(LensSessionHandle sessionId,
SchedulerJobHandle jobHandle)
Marks the job for deletion.
|
void |
SchedulerServiceImpl.expireJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
End a job by specifying an expiry time.
|
List<SchedulerJobHandle> |
ScheduleResource.getAllJobs(LensSessionHandle sessionHandle,
String user,
SchedulerJobState state,
Long start,
Long end)
Get all job handles matching user, state and end_time >job_submission_time >=start time.
|
List<SchedulerJobHandle> |
SchedulerServiceImpl.getAllJobs(String user,
SchedulerJobState state,
Long start,
Long end) |
Collection<SchedulerJobStats> |
ScheduleResource.getAllJobStats(LensSessionHandle sessionId,
String status,
String jobName,
String user,
long start,
long end)
Get all job stats
|
Collection<SchedulerJobStats> |
SchedulerServiceImpl.getAllJobStats(String state,
String user,
String jobName,
long startTime,
long endTime) |
LensAPIResult<SchedulerJobInstanceInfo> |
ScheduleResource.getInstanceDetails(LensSessionHandle sessionId,
SchedulerJobInstanceHandle instanceHandle)
Returns a SchedulerInstanceInfo for a given instance handle.
|
SchedulerJobInstanceInfo |
SchedulerServiceImpl.getInstanceDetails(SchedulerJobInstanceHandle instanceHandle)
Instance details for an instance.
|
LensAPIResult<XJob> |
ScheduleResource.getJobDefinition(LensSessionHandle sessionId,
SchedulerJobHandle jobHandle)
Get XJob definition for a given job handle.
|
XJob |
SchedulerServiceImpl.getJobDefinition(SchedulerJobHandle jobHandle)
Returns the definition of a job.
|
LensAPIResult<SchedulerJobInfo> |
ScheduleResource.getJobDetails(LensSessionHandle sessionId,
SchedulerJobHandle jobHandle)
Returns the SchedulerJobInfo of a given job handle.
|
SchedulerJobInfo |
SchedulerServiceImpl.getJobDetails(SchedulerJobHandle jobHandle)
Returns the details of a job.
|
List<SchedulerJobInstanceInfo> |
ScheduleResource.getJobInstances(LensSessionHandle sessionId,
SchedulerJobHandle jobHandle,
Long numResults)
Returns all the instances of a job.
|
List<SchedulerJobInstanceInfo> |
SchedulerServiceImpl.getJobInstances(SchedulerJobHandle jobHandle,
Long numResults)
Returns handles for last
numResults instances for the job. |
SchedulerJobStats |
SchedulerServiceImpl.getJobStats(SchedulerJobHandle handle,
String state,
long startTime,
long endTime)
Returns stats for a job.
|
boolean |
SchedulerServiceImpl.killInstance(LensSessionHandle sessionHandle,
SchedulerJobInstanceHandle instanceHandle) |
LensSessionHandle |
SchedulerServiceImpl.openSessionAsUser(String user)
Create session as user for scheduling the job with no auth.
|
void |
AlarmService.pauseJob(SchedulerJobHandle jobHandle) |
void |
SchedulerServiceImpl.rerunInstance(LensSessionHandle sessionHandle,
SchedulerJobInstanceHandle instanceHandle)
Reruns a failed/killed/completed job instance.
|
void |
SchedulerServiceImpl.resumeJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
Resume a job from a given time.
|
void |
AlarmService.resumeJob(SchedulerJobHandle jobHandle) |
void |
AlarmService.schedule(org.joda.time.DateTime start,
org.joda.time.DateTime end,
XFrequency frequency,
String jobHandle)
This method can be used by any consumer who wants to receive notifications during a time range at a given
frequency.
|
void |
SchedulerServiceImpl.scheduleJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
Schedule a job.
|
SchedulerJobHandle |
SchedulerServiceImpl.submitAndScheduleJob(LensSessionHandle sessionHandle,
XJob job) |
LensAPIResult<SchedulerJobHandle> |
ScheduleResource.submitJob(LensSessionHandle sessionId,
String action,
XJob job)
Submits a job to be scheduled at later point of time or submit and schedule simultaneously.
|
SchedulerJobHandle |
SchedulerServiceImpl.submitJob(LensSessionHandle sessionHandle,
XJob job)
Submit a job.
|
void |
SchedulerServiceImpl.suspendJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle)
Suspend a job.
|
boolean |
AlarmService.unSchedule(SchedulerJobHandle jobHandle) |
LensAPIResult |
ScheduleResource.updateInstance(LensSessionHandle sessionId,
SchedulerJobInstanceHandle instanceHandle,
String action)
Updates an instance
|
LensAPIResult |
ScheduleResource.updateJob(LensSessionHandle sessionId,
SchedulerJobHandle jobHandle,
String action)
Changes the job state
|
void |
SchedulerServiceImpl.updateJob(LensSessionHandle sessionHandle,
SchedulerJobHandle jobHandle,
XJob newJobDefinition)
Update a job with new definition.
|
LensAPIResult |
ScheduleResource.updateJob(LensSessionHandle sessionId,
SchedulerJobHandle jobHandle,
XJob job)
Updates job definition of an existing job.
|
Constructor and Description |
---|
SchedulerDAO(org.apache.hadoop.conf.Configuration conf) |
SchedulerServiceImpl(org.apache.hive.service.cli.CLIService cliService)
Instantiates a new scheduler service.
|
Modifier and Type | Method and Description |
---|---|
void |
HiveSessionService.cleanupIdleSessions() |
APIResult |
SessionResource.clearIdleSessions()
Clears idle sessions.
|
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 |
SessionResource.openSession(String username,
String password,
String database,
LensConf sessionconf)
Create a new session with Lens server.
|
LensSessionHandle |
HiveSessionService.openSession(String username,
String password,
String database,
Map<String,String> configuration)
Open session.
|
Constructor and Description |
---|
SessionResource()
Instantiates a new session resource.
|
Copyright © 2014–2018 Apache Software Foundation. All rights reserved.