A B C D E F G H I J K L M N O P Q R S T U V W Y 
All Classes All Packages

A

AbstractSqlNode - Class in org.apache.calcite.sql
 
AbstractSqlNode(SqlParserPos) - Constructor for class org.apache.calcite.sql.AbstractSqlNode
 
accept(SqlVisitor<R>) - Method in class org.apache.calcite.sql.AbstractSqlNode
 
accessors(Expression, List<Integer>) - Method in class com.twilio.kudu.sql.KuduPhysType
 
addColumnValueGenerator(String, SingleColumnValueGenerator<T>) - Method in class com.twilio.kudu.dataloader.Scenario.ScenarioBuilder
 
addEquivalenceClass(RexTableInputRef, RexTableInputRef) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.EquivalenceClasses
 
addScannerMetricsList(List<ScannerMetrics>) - Method in class com.twilio.kudu.sql.KuduScanStats
Increments the scanner count and adds to the scanner metrics to the scannerMetricsList
aggregateProjectPullUpConstantsRule() - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule.Config
 
AGGREGATION_LIMIT_RULE - Static variable in class com.twilio.kudu.sql.rules.KuduAggregationLimitRule
 
apply(List<Object>) - Method in class com.twilio.kudu.sql.NestedJoinFactory
 
areAllFiltersApplied() - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
asQueryable(QueryProvider, SchemaPlus, String) - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
assignHints(Holder<SqlToRelConverter.Config>) - Method in class com.twilio.kudu.sql.schema.KuduSchema
 

B

BaseKuduSchemaFactory - Class in com.twilio.kudu.sql.schema
 
BaseKuduSchemaFactory(Map<String, KuduTableMetadata>) - Constructor for class com.twilio.kudu.sql.schema.BaseKuduSchemaFactory
 
BATCH_COMPLETED - com.twilio.kudu.sql.CalciteScannerMessage.MessageType
 
blockSize - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
build() - Method in class com.twilio.kudu.dataloader.Scenario.ScenarioBuilder
 
build() - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
build() - Method in class com.twilio.kudu.sql.metadata.KuduTableMetadata.KuduTableMetadataBuilder
 

C

CALCITE_MODEL_TEMPLATE - Static variable in class com.twilio.kudu.sql.JDBCUtil
 
CALCITE_MODEL_TEMPLATE_DML_DDL_ENABLED - Static variable in class com.twilio.kudu.sql.JDBCUtil
 
CalciteKuduEnumerable - Class in com.twilio.kudu.sql
Calcite implementation layer that represents a result set of a scan.
CalciteKuduEnumerable(BlockingQueue<CalciteScannerMessage<CalciteRow>>, AtomicBoolean) - Constructor for class com.twilio.kudu.sql.CalciteKuduEnumerable
Create Enumerable with a Queue of results, a shared integer for scans that have finished and a boolean switch indicating the scan should complete.
CalciteKuduPredicate - Class in com.twilio.kudu.sql
A simple "case" class / POJO to help with code generation in KuduToEnumerableConverter.
CalciteKuduPredicate() - Constructor for class com.twilio.kudu.sql.CalciteKuduPredicate
 
calciteKuduTable - Variable in class com.twilio.kudu.sql.KuduQuery
 
CalciteKuduTable - Class in com.twilio.kudu.sql
A CalciteKuduTable is responsible for returning rows of Objects back.
CalciteKuduTable(KuduTable, AsyncKuduClient, List<Integer>, int, List<CalciteKuduTable>, TableType, CubeTableInfo.EventTimeAggregationType, long) - Constructor for class com.twilio.kudu.sql.CalciteKuduTable
Create the CalciteKuduTable for a physical scan over the providedKuduTable.
CalciteKuduTable.KuduQueryable<T> - Class in com.twilio.kudu.sql
Implementation of Queryable based on a CalciteKuduTable.
CalciteKuduTableBuilder - Class in com.twilio.kudu.sql
 
CalciteKuduTableBuilder(KuduTable, AsyncKuduClient) - Constructor for class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
calciteModifiableKuduTable - Variable in class com.twilio.kudu.sql.mutation.MutationState
 
CalciteModifiableKuduTable - Class in com.twilio.kudu.sql
 
CalciteRow - Class in com.twilio.kudu.sql
A Plain Java Object that represents a Projected response from Kudu RPCs.
CalciteRow(Schema, Object[], List<Integer>, List<Integer>) - Constructor for class com.twilio.kudu.sql.CalciteRow
Create a Calcite row with provided rowData.
CalciteScannerMessage<T> - Class in com.twilio.kudu.sql
Message object represents a Message from an active scanner.
CalciteScannerMessage(ScannerCallback) - Constructor for class com.twilio.kudu.sql.CalciteScannerMessage
Constructs a Batch Completed Scanner Message.
CalciteScannerMessage(Exception) - Constructor for class com.twilio.kudu.sql.CalciteScannerMessage
Construct a Scanner Message that contains an exception.
CalciteScannerMessage(T) - Constructor for class com.twilio.kudu.sql.CalciteScannerMessage
Constructs a Scanner Message that contains a row.
CalciteScannerMessage.MessageType - Enum in com.twilio.kudu.sql
 
call(RowResultIterator) - Method in class com.twilio.kudu.sql.ScannerCallback
 
callback - Variable in class com.twilio.kudu.sql.CalciteScannerMessage
 
canApply(RelTraitSet, RexNode, KuduQuery, KuduTable, Optional<Filter>) - Method in class com.twilio.kudu.sql.rules.KuduSortRule
 
clear() - Method in class com.twilio.kudu.sql.mutation.CubeMutationState
 
clear() - Method in class com.twilio.kudu.sql.mutation.MutationState
Clears the cube mutation state (and thus frees up memory)
clearCachedTableMap() - Method in class com.twilio.kudu.sql.schema.KuduSchema
 
clearMutationState() - Method in class org.apache.calcite.jdbc.KuduMetaImpl
 
client - Variable in class com.twilio.kudu.sql.CalciteKuduTable
 
clone(List<List<CalciteKuduPredicate>>) - Method in interface com.twilio.kudu.sql.CloneableEnumerable
Clone this enumerable by merging the CalciteKuduPredicate into existing set.
clone(List<List<CalciteKuduPredicate>>) - Method in class com.twilio.kudu.sql.KuduEnumerable
 
clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlColumnDefInPkConstraintNode
 
clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlColumnDefNode
 
clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlColumnNameNode
 
clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlDataTypeNode
 
clone(SqlParserPos) - Method in class org.apache.calcite.sql.SqlOptionNode
 
CloneableEnumerable<T> - Interface in com.twilio.kudu.sql
An Enumerable that can be cloned with additional conjunctions.
CLOSE - com.twilio.kudu.sql.CalciteScannerMessage.MessageType
 
columnIdx - Variable in class com.twilio.kudu.sql.ComparisonPredicate
 
columnIdx - Variable in class com.twilio.kudu.sql.InListPredicate
 
columnIdx - Variable in class com.twilio.kudu.sql.NullPredicate
 
columnIndexes - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
columnName - Variable in class org.apache.calcite.sql.SqlColumnDefInPkConstraintNode
 
columnName - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
columnSchemaBuilder - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
ColumnValueGenerator - Class in com.twilio.kudu.dataloader.generator
 
ColumnValueGenerator() - Constructor for class com.twilio.kudu.dataloader.generator.ColumnValueGenerator
 
com.twilio.kudu.dataloader - package com.twilio.kudu.dataloader
 
com.twilio.kudu.dataloader.generator - package com.twilio.kudu.dataloader.generator
 
com.twilio.kudu.sql - package com.twilio.kudu.sql
 
com.twilio.kudu.sql.metadata - package com.twilio.kudu.sql.metadata
 
com.twilio.kudu.sql.mutation - package com.twilio.kudu.sql.mutation
 
com.twilio.kudu.sql.rel - package com.twilio.kudu.sql.rel
 
com.twilio.kudu.sql.rules - package com.twilio.kudu.sql.rules
 
com.twilio.kudu.sql.schema - package com.twilio.kudu.sql.schema
 
comment - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
commit(Meta.ConnectionHandle) - Method in class org.apache.calcite.jdbc.KuduMetaImpl
 
comparer() - Method in class com.twilio.kudu.sql.KuduPhysType
 
compareTo(CalciteRow) - Method in class com.twilio.kudu.sql.CalciteRow
 
ComparisonPredicate - Class in com.twilio.kudu.sql
An implementation of CalciteKuduPredicate that creates comparison KuduPredicate KuduPredicate.newComparisonPredicate(ColumnSchema, org.apache.kudu.client.KuduPredicate.ComparisonOp, Object)
ComparisonPredicate(int, KuduPredicate.ComparisonOp, Object) - Constructor for class com.twilio.kudu.sql.ComparisonPredicate
 
compensatePartial(Set<RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, Set<RexTableInputRef.RelTableRef>, Multimap<RexTableInputRef, RexTableInputRef>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
It checks whether the target can be rewritten using the source even though the source uses additional tables.
compensateViewPartial(RelBuilder, RexBuilder, RelMetadataQuery, RelNode, Project, RelNode, Set<RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, Project, RelNode, Set<RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
 
compensateViewPartial(RelBuilder, RexBuilder, RelMetadataQuery, RelNode, Project, RelNode, Set<RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, Project, RelNode, Set<RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
It checks whether the query can be rewritten using the view even though the query uses additional tables.
COMPLETE - org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.MatchModality
 
component(int) - Method in class com.twilio.kudu.sql.KuduPhysType
 
compression - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
computeCompensationPredicates(RexBuilder, RexSimplify, KuduMaterializedViewRule.EquivalenceClasses, Pair<RexNode, RexNode>, KuduMaterializedViewRule.EquivalenceClasses, Pair<RexNode, RexNode>, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
We check whether the predicates in the source are contained in the predicates in the target.
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class com.twilio.kudu.sql.rel.KuduFilterRel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class com.twilio.kudu.sql.rel.KuduLimitRel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class com.twilio.kudu.sql.rel.KuduNestedJoin
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class com.twilio.kudu.sql.rel.KuduSortRel
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class com.twilio.kudu.sql.rel.KuduToEnumerableRel
 
ConditionTranslationVisitor(int, Project) - Constructor for class com.twilio.kudu.sql.TranslationPredicate.ConditionTranslationVisitor
 
CONNECT_STRING_PREFIX - Static variable in class org.apache.calcite.jdbc.KuduDriver
 
connectionSync(Meta.ConnectionHandle, Meta.ConnectionProperties) - Method in class org.apache.calcite.jdbc.KuduMetaImpl
 
ConstantValueGenerator<T> - Class in com.twilio.kudu.dataloader.generator
 
ConstantValueGenerator(T) - Constructor for class com.twilio.kudu.dataloader.generator.ConstantValueGenerator
 
CONVENTION - Static variable in interface com.twilio.kudu.sql.KuduRelNode
 
convert(Sort) - Method in class com.twilio.kudu.sql.rules.KuduLimitRule
 
convert(RelNode) - Method in class com.twilio.kudu.sql.rules.KuduProjectValuesRule
 
convert(RelNode) - Method in class com.twilio.kudu.sql.rules.KuduToEnumerableConverter
 
convert(RelNode) - Method in class com.twilio.kudu.sql.rules.KuduValuesRule
 
convert(RelNode) - Method in class com.twilio.kudu.sql.rules.KuduWriteRule
 
convertTo(Expression, JavaRowFormat) - Method in class com.twilio.kudu.sql.KuduPhysType
 
convertTo(Expression, PhysType) - Method in class com.twilio.kudu.sql.KuduPhysType
 
copy(RelTraitSet, List<RelNode>) - Method in class com.twilio.kudu.sql.KuduQuery
 
copy(RelTraitSet, List<RelNode>) - Method in class com.twilio.kudu.sql.KuduWrite
 
copy(RelTraitSet, List<RelNode>) - Method in class com.twilio.kudu.sql.rel.KuduLimitRel
 
copy(RelTraitSet, List<RelNode>) - Method in class com.twilio.kudu.sql.rel.KuduToEnumerableRel
 
copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel
 
copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class com.twilio.kudu.sql.rel.KuduProjectValuesRel
 
copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class com.twilio.kudu.sql.rel.KuduSortRel
 
copy(RelTraitSet, RelNode, RexNode) - Method in class com.twilio.kudu.sql.rel.KuduFilterRel
 
copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class com.twilio.kudu.sql.rel.KuduNestedJoin
 
copy(KuduMaterializedViewRule.EquivalenceClasses) - Static method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.EquivalenceClasses
 
CORE_RULES - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
create(RelNode, RelNode, RexNode, JoinRelType, int, List<RelHint>) - Static method in class com.twilio.kudu.sql.rel.KuduNestedJoin
 
create(SchemaPlus, String, Map<String, Object>) - Method in class com.twilio.kudu.sql.schema.BaseKuduSchemaFactory
 
CREATE_DUMMY_PARTITION_FLAG - Static variable in class com.twilio.kudu.sql.schema.KuduSchema
 
createCubeMaintainer(CalciteKuduTable) - Method in class com.twilio.kudu.sql.CalciteModifiableKuduTable
 
createDummyPartition - Variable in class com.twilio.kudu.sql.schema.KuduSchema
 
createEndMessage() - Static method in class com.twilio.kudu.sql.CalciteScannerMessage
Construct a CalciteScannerMessage.MessageType.CLOSE message to represent closing of the scanner.
createMeta(AvaticaConnection) - Method in class org.apache.calcite.jdbc.KuduDriver
 
createPrepareFactory() - Method in class org.apache.calcite.jdbc.KuduDriver
 
createUnion(RelBuilder, RexBuilder, RelNode, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
 
createUnion(RelBuilder, RexBuilder, RelNode, RelNode, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
If the view will be used in a union rewriting, this method is responsible for generating the union and any other operator needed on top of it, e.g., a Project operator.
CUBE - com.twilio.kudu.sql.TableType
 
CubeGenerator - Class in com.twilio.kudu.dataloader.generator
Generate rows using the row counts of a cube grouped by its primary keys.
CubeGenerator() - Constructor for class com.twilio.kudu.dataloader.generator.CubeGenerator
 
CubeMaintainer - Class in com.twilio.kudu.sql.mutation
Used to calculate aggregated values and upsert rows to the kudu cube tables
CubeMaintainer(CalciteKuduTable, CalciteKuduTable) - Constructor for class com.twilio.kudu.sql.mutation.CubeMaintainer
 
CubeMutationState - Class in com.twilio.kudu.sql.mutation
 
CubeMutationState(CalciteModifiableKuduTable) - Constructor for class com.twilio.kudu.sql.mutation.CubeMutationState
 
CubeTableInfo - Class in com.twilio.kudu.sql.metadata
 
CubeTableInfo(String, CubeTableInfo.EventTimeAggregationType) - Constructor for class com.twilio.kudu.sql.metadata.CubeTableInfo
 
CubeTableInfo.EventTimeAggregationType - Enum in com.twilio.kudu.sql.metadata
 
cubeTables - Variable in class com.twilio.kudu.sql.CalciteKuduTable
 

D

DataLoader - Class in com.twilio.kudu.dataloader
 
DataLoader(String, Scenario) - Constructor for class com.twilio.kudu.dataloader.DataLoader
 
DataLoader(String, Scenario, Integer) - Constructor for class com.twilio.kudu.dataloader.DataLoader
 
dataType - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
day - com.twilio.kudu.sql.metadata.CubeTableInfo.EventTimeAggregationType
 
DAY - org.apache.calcite.prepare.KuduPrepareImpl.TimeAggregationType
 
DEFAULT_BATCH_SIZE - Static variable in class com.twilio.kudu.sql.rules.KuduNestedJoinRule
 
DefaultKuduSchemaFactory - Class in com.twilio.kudu.sql.schema
 
defaultValue - Variable in class com.twilio.kudu.dataloader.generator.EnvironmentVariableGenerator
 
defaultValueExp - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
deriveRowType() - Method in class com.twilio.kudu.sql.KuduQuery
 
descendingColumns - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
descendingOrderedColumnIndexes - Variable in class com.twilio.kudu.sql.CalciteKuduTable
 
descendingSortedFieldIndices - Variable in class com.twilio.kudu.sql.CalciteRow
 
DIMENSION - com.twilio.kudu.sql.TableType
 
DISABLE_CUBE_AGGREGATIONS - Static variable in class com.twilio.kudu.sql.schema.KuduSchema
 
DISABLE_MATERIALIZED_VIEWS - Static variable in class com.twilio.kudu.sql.schema.KuduSchema
 
DISABLE_SCHEMA_CACHE - Static variable in class com.twilio.kudu.sql.schema.KuduSchema
 
disableCubeAggregation - Variable in class com.twilio.kudu.sql.schema.KuduSchema
 
disableMaterializedViews - Variable in class com.twilio.kudu.sql.schema.KuduSchema
 

E

ENABLE_INSERTS_FLAG - Static variable in class com.twilio.kudu.sql.schema.KuduSchema
 
enableInserts - Variable in class com.twilio.kudu.sql.schema.KuduSchema
 
encoding - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
endPrimaryKey - Variable in class com.twilio.kudu.sql.ScannerMetrics
 
ENUMERABLE_RULES - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
enumerator() - Method in class com.twilio.kudu.sql.CalciteKuduEnumerable
 
enumerator() - Method in class com.twilio.kudu.sql.CalciteKuduTable.KuduQueryable
 
enumerator() - Method in class com.twilio.kudu.sql.KuduEnumerable
 
EnvironmentVariableGenerator<T> - Class in com.twilio.kudu.dataloader.generator
 
EnvironmentVariableGenerator(String) - Constructor for class com.twilio.kudu.dataloader.generator.EnvironmentVariableGenerator
 
EPOCH_DAY_FOR_REVERSE_SORT - Static variable in class com.twilio.kudu.sql.CalciteKuduTable
 
EPOCH_FOR_REVERSE_SORT_IN_MICROSECONDS - Static variable in class com.twilio.kudu.sql.CalciteKuduTable
 
EPOCH_FOR_REVERSE_SORT_IN_MILLISECONDS - Static variable in class com.twilio.kudu.sql.CalciteKuduTable
 
equals(Object) - Method in class com.twilio.kudu.sql.ComparisonPredicate
 
equals(Object) - Method in class com.twilio.kudu.sql.InListPredicate
 
equals(Object) - Method in class com.twilio.kudu.sql.NullPredicate
 
equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlColumnDefInPkConstraintNode
 
equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlColumnDefNode
 
equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlColumnNameNode
 
equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlDataTypeNode
 
equalsDeep(SqlNode, Litmus) - Method in class org.apache.calcite.sql.SqlOptionNode
 
EquivalenceClasses() - Constructor for class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.EquivalenceClasses
 
ERROR - com.twilio.kudu.sql.CalciteScannerMessage.MessageType
 
eventTimeAggregationType - Variable in class com.twilio.kudu.sql.CalciteKuduTable
 
eventTimeAggregationType - Variable in class com.twilio.kudu.sql.metadata.CubeTableInfo
 
executeDdl(CalcitePrepare.Context, SqlNode) - Method in class org.apache.calcite.prepare.KuduPrepareImpl
 
executeQuery(List<List<CalciteKuduPredicate>>, List<Integer>, long, long, boolean, boolean, KuduScanStats, AtomicBoolean, Function1<Object, Object>, Predicate1<Object>, boolean, Function1<Object, Object>, List<Integer>) - Method in class com.twilio.kudu.sql.CalciteKuduTable
Run the query against the kudu table CalciteKuduTable.kuduTable.
explainPredicate(ColumnSchema) - Method in class com.twilio.kudu.sql.CalciteKuduPredicate
Constructs a string used when generating the explain plan
explainPredicate(ColumnSchema) - Method in class com.twilio.kudu.sql.ComparisonPredicate
 
explainPredicate(ColumnSchema) - Method in class com.twilio.kudu.sql.InListPredicate
 
explainPredicate(ColumnSchema) - Method in class com.twilio.kudu.sql.NullPredicate
 
explainTerms(RelWriter) - Method in class com.twilio.kudu.sql.rel.KuduFilterRel
 
explainTerms(RelWriter) - Method in class com.twilio.kudu.sql.rel.KuduLimitRel
 
explainTerms(RelWriter) - Method in class com.twilio.kudu.sql.rel.KuduNestedJoin
 
explainTerms(RelWriter) - Method in class com.twilio.kudu.sql.rel.KuduSortRel
 
extractPossibleMapping(List<Set<RexTableInputRef>>, List<Set<RexTableInputRef>>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Given the source and target equivalence classes, it extracts the possible mappings from each source equivalence class to each target equivalence class.
extractReferences(RexBuilder, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
If the node is an Aggregate, it returns a list of references to the grouping columns.

F

FACT - com.twilio.kudu.sql.TableType
 
failure - Variable in class com.twilio.kudu.sql.CalciteScannerMessage
 
fastBailOut() - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.Config
 
fetch - Variable in class com.twilio.kudu.sql.rel.KuduLimitRel
 
field(int) - Method in class com.twilio.kudu.sql.KuduPhysType
 
fieldClass(int) - Method in class com.twilio.kudu.sql.KuduPhysType
 
fieldNullable(int) - Method in class com.twilio.kudu.sql.KuduPhysType
 
fieldReference(Expression, int) - Method in class com.twilio.kudu.sql.KuduPhysType
 
fieldReference(Expression, int, Type) - Method in class com.twilio.kudu.sql.KuduPhysType
 
FILTER - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
FILTER_SORT - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
FILTER_SORT_RULE - Static variable in class com.twilio.kudu.sql.rules.KuduSortRule
 
filterAggregateTransposeRule() - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule.Config
 
filterProjections - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
filterProjectTransposeRule() - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule.Config
 
flush() - Method in class com.twilio.kudu.sql.mutation.CubeMutationState
 
flush() - Method in class com.twilio.kudu.sql.mutation.MutationState
 

G

generateAccessor(List<Integer>) - Method in class com.twilio.kudu.sql.KuduPhysType
 
generateCollationKey(List<RelFieldCollation>) - Method in class com.twilio.kudu.sql.KuduPhysType
 
generateComparator(RelCollation) - Method in class com.twilio.kudu.sql.KuduPhysType
 
generateCubeDelta(Map<Integer, Object>) - Method in class com.twilio.kudu.sql.mutation.CubeMaintainer
Remaps the fact table columns to the cube table pk columns (dimensions) and the cube table non pk columns (measures) Also truncates the event time column to the cube rollup time
generateEquivalenceClasses(RexBuilder, KuduMaterializedViewRule.EquivalenceClasses, KuduMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Given the equi-column predicates of the source and the target and the computed equivalence classes, it extracts possible mappings between the equivalence classes.
generateMapping(RexBuilder, RexSimplify, RelMetadataQuery, RelNode, RelNode, ImmutableBitSet, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, List<RexNode>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
Mapping from node expressions to target expressions.
generateSelector(ParameterExpression, List<Integer>) - Method in class com.twilio.kudu.sql.KuduPhysType
 
generateSelector(ParameterExpression, List<Integer>, List<Integer>, JavaRowFormat) - Method in class com.twilio.kudu.sql.KuduPhysType
 
generateSelector(ParameterExpression, List<Integer>, JavaRowFormat) - Method in class com.twilio.kudu.sql.KuduPhysType
 
generateSwapColumnTableReferencesLineage(RexBuilder, RelMetadataQuery, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, List<RexNode>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
It swaps the column references and then the table references of the input expressions using the equivalence classes and the table mapping.
generateSwapTableColumnReferencesLineage(RexBuilder, RelMetadataQuery, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, List<RexNode>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
It swaps the table references and then the column references of the input expressions using the table mapping and the equivalence classes.
generateTableMappings(Multimap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
It will flatten a multimap containing table references to table references, producing all possible combinations of mappings.
generateUnionRewriting() - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.Config
 
gePKColumnIndexes() - Method in class com.twilio.kudu.sql.mutation.CubeMaintainer
 
getCeilSqlFunction(TimeUnitRange) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
Get ceil function datetime.
getClient() - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
getClient() - Method in class com.twilio.kudu.sql.schema.KuduSchema
 
getColumnIdx() - Method in class com.twilio.kudu.sql.CalciteKuduPredicate
returns the column index for this predicate
getColumnIdx() - Method in class com.twilio.kudu.sql.ComparisonPredicate
 
getColumnIdx() - Method in class com.twilio.kudu.sql.InListPredicate
 
getColumnIdx() - Method in class com.twilio.kudu.sql.NullPredicate
 
getColumnName() - Method in class org.apache.calcite.sql.SqlColumnNameNode
 
getColumnNames() - Method in class com.twilio.kudu.dataloader.generator.CubeGenerator
 
getColumnNames() - Method in class com.twilio.kudu.dataloader.generator.MultipleColumnValueGenerator
 
getColumnNameToValueGenerator() - Method in class com.twilio.kudu.dataloader.Scenario
 
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.ConstantValueGenerator
 
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.EnvironmentVariableGenerator
 
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.PhoneNumberListGenerator
 
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.RandomSidGenerator
 
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.SidListGenerator
 
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.SingleColumnValueGenerator
 
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.TimestampGenerator
 
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.UniformBigDecimalValueGenerator
Generates a double value between [0, maxValue)
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.UniformIntegerValueGenerator
Generates a int value between [minValue, maxValue)
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.UniformLongValueGenerator
Generates a long value between [minValue, maxValue)
getColumnValue() - Method in class com.twilio.kudu.dataloader.generator.ValueListGenerator
 
getColumnValue(String) - Method in class com.twilio.kudu.dataloader.generator.ColumnValueGenerator
 
getColumnValue(String) - Method in class com.twilio.kudu.dataloader.generator.CubeGenerator
 
getColumnValue(String) - Method in class com.twilio.kudu.dataloader.generator.SingleColumnValueGenerator
 
getConnectStringPrefix() - Method in class org.apache.calcite.jdbc.KuduDriver
 
getCubeMaintainer() - Method in class com.twilio.kudu.sql.CalciteModifiableKuduTable
 
getCubeTableInfo() - Method in class com.twilio.kudu.sql.metadata.KuduTableMetadata
 
getCubeTables() - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
getDef() - Method in class com.twilio.kudu.sql.metadata.KuduNonCumulativeCost
 
getDescendingColumnsIndicesInProjection(Schema) - Method in class com.twilio.kudu.sql.CalciteKuduTable
Return the integer indices of the descending sorted columns in the row projection.
getDescendingOrderedColumnIndexes() - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
getDescendingOrderedColumnNames() - Method in class com.twilio.kudu.sql.metadata.KuduTableMetadata
 
getEquivalenceClasses() - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.EquivalenceClasses
 
getEquivalenceClassesMap() - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.EquivalenceClasses
 
getEventTimeAggregationType() - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
getExplainPlan(ResultSet) - Static method in class com.twilio.kudu.sql.SqlUtil
 
getFactoryClassName(UnregisteredDriver.JdbcVersion) - Method in class org.apache.calcite.jdbc.KuduDriver
 
getFloorMod() - Method in class com.twilio.kudu.sql.mutation.CubeMaintainer
TODO support month and year
getFloorMod(TimeUnitRange) - Static method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
 
getFloorSqlFunction(TimeUnitRange) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
Get floor function datetime.
getFormat() - Method in class com.twilio.kudu.sql.KuduPhysType
 
getJavaFieldType(int) - Method in class com.twilio.kudu.sql.KuduPhysType
 
getJavaRowType() - Method in class com.twilio.kudu.sql.KuduPhysType
 
getKuduDataType(SqlDataTypeNode) - Static method in class com.twilio.kudu.sql.SqlUtil
Translates JDBC sql types to Kudu data types
getKuduSchema(SchemaPlus) - Static method in class org.apache.calcite.prepare.KuduPrepareImpl
 
getKuduTable() - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
getMeta() - Method in class org.apache.calcite.jdbc.KuduCalciteConnectionImpl
 
getModifiableCollection() - Method in class com.twilio.kudu.sql.CalciteModifiableKuduTable
 
getMultipleColumnValueGenerators() - Method in class com.twilio.kudu.dataloader.Scenario
 
getMutationState(CalciteModifiableKuduTable) - Method in class org.apache.calcite.jdbc.KuduMetaImpl
 
getNonCumulativeCost(RelNode, RelMetadataQuery) - Method in class com.twilio.kudu.sql.metadata.KuduNonCumulativeCost
 
getNonPKColumnIndexes() - Method in class com.twilio.kudu.sql.mutation.CubeMaintainer
 
getNumRows() - Method in class com.twilio.kudu.dataloader.Scenario
 
getPrimaryKeyColumnsInProjection(List<Integer>, List<Integer>) - Method in class com.twilio.kudu.sql.rel.KuduToEnumerableRel
Return the Integer indices in the Row Projection that match the primary key columns and in the order they need to match.
getProjectedColumnToRelDataTypeFieldMap() - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
getResult(ResultSet) - Static method in class com.twilio.kudu.sql.SqlUtil
 
getRollup(SqlAggFunction) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
Deprecated.
getRowCount() - Method in enum com.twilio.kudu.sql.TableType
Returns the estimated row count for this table type.
getRowData() - Method in class com.twilio.kudu.sql.CalciteRow
 
getRowsScannedCount() - Method in class com.twilio.kudu.sql.KuduScanStats
 
getRowType() - Method in class com.twilio.kudu.sql.KuduPhysType
 
getRowType(RelDataTypeFactory) - Method in class com.twilio.kudu.sql.CalciteKuduTable
Builds a mapping from Kudu Schema into relational schema names
getScannerCount() - Method in class com.twilio.kudu.sql.KuduScanStats
 
getScannerMetricsList() - Method in class com.twilio.kudu.sql.KuduScanStats
 
getScannerRpcCount() - Method in class com.twilio.kudu.sql.KuduScanStats
 
getSelectivity(RelNode, RelMetadataQuery, RexNode) - Method in class com.twilio.kudu.sql.metadata.KuduRelMdSelectivity
 
getSortPkPrefix(RelCollation, KuduQuery, Optional<Filter>) - Method in class com.twilio.kudu.sql.rules.KuduAggregationLimitRule
 
getStatistic() - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
getTable(String) - Method in class com.twilio.kudu.sql.schema.BaseKuduSchemaFactory
 
getTableMap() - Method in class com.twilio.kudu.sql.schema.KuduSchema
 
getTableName() - Method in class com.twilio.kudu.dataloader.Scenario
 
getTableSchema() - Method in class com.twilio.kudu.sql.KuduEnumerable
 
getTableType() - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
getTimestampColumnIndex() - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
getTimestampColumnName() - Method in class com.twilio.kudu.sql.metadata.KuduTableMetadata
 
getTimeToFirstRowMs() - Method in class com.twilio.kudu.sql.KuduScanStats
 
getTotalTimeMs() - Method in class com.twilio.kudu.sql.KuduScanStats
 
groupBy(Function1<Object, TKey>, Function0<TAccumulate>, Function2<TAccumulate, Object, TAccumulate>, Function2<TKey, TAccumulate, TResult>) - Method in class com.twilio.kudu.sql.KuduEnumerable
 
groupByLimited - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
groupByLimited - Variable in class com.twilio.kudu.sql.rel.KuduSortRel
 
groupBySorted - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
groupBySorted - Variable in class com.twilio.kudu.sql.rel.KuduSortRel
 
groupBySortedOrLimited - Variable in class com.twilio.kudu.sql.KuduEnumerable
 
groupedColumnCountsResource - Variable in class com.twilio.kudu.dataloader.generator.CubeGenerator
 
groupedColumns - Variable in class com.twilio.kudu.dataloader.generator.CubeGenerator
 
groupFetchLimit - Variable in class com.twilio.kudu.sql.KuduEnumerable
 

H

hashCode() - Method in class com.twilio.kudu.sql.ComparisonPredicate
 
hashCode() - Method in class com.twilio.kudu.sql.InListPredicate
 
hashCode() - Method in class com.twilio.kudu.sql.NullPredicate
 
HINT_NAME - Static variable in class com.twilio.kudu.sql.rules.KuduFilterRule
 
HINT_NAME - Static variable in class com.twilio.kudu.sql.rules.KuduNestedJoinRule
 
hour - com.twilio.kudu.sql.metadata.CubeTableInfo.EventTimeAggregationType
 
HOUR - org.apache.calcite.prepare.KuduPrepareImpl.TimeAggregationType
 

I

implement(KuduRelNode.Implementor) - Method in class com.twilio.kudu.sql.KuduQuery
 
implement(KuduRelNode.Implementor) - Method in interface com.twilio.kudu.sql.KuduRelNode
Each KuduRelNode implementation will accept the KuduRelNode.Implementor and manipulate it.
implement(KuduRelNode.Implementor) - Method in class com.twilio.kudu.sql.KuduWrite
 
implement(KuduRelNode.Implementor) - Method in class com.twilio.kudu.sql.rel.KuduFilterRel
 
implement(KuduRelNode.Implementor) - Method in class com.twilio.kudu.sql.rel.KuduLimitRel
 
implement(KuduRelNode.Implementor) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel
 
implement(KuduRelNode.Implementor) - Method in class com.twilio.kudu.sql.rel.KuduProjectValuesRel
 
implement(KuduRelNode.Implementor) - Method in class com.twilio.kudu.sql.rel.KuduSortRel
 
implement(KuduRelNode.Implementor) - Method in class com.twilio.kudu.sql.rel.KuduValuesRel
 
implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class com.twilio.kudu.sql.rel.KuduNestedJoin
 
implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class com.twilio.kudu.sql.rel.KuduToEnumerableRel
 
Implementor() - Constructor for class com.twilio.kudu.sql.KuduRelNode.Implementor
 
incrementRowsScannedCount(long) - Method in class com.twilio.kudu.sql.KuduScanStats
 
incrementScannerRpcCount(long) - Method in class com.twilio.kudu.sql.KuduScanStats
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.ColumnValueGenerator
Initialize the ColumnValueGenerator from JSON or other files.
initialize() - Method in class com.twilio.kudu.dataloader.generator.ConstantValueGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.CubeGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.EnvironmentVariableGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.PhoneNumberListGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.RandomSidGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.SidListGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.TimestampGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.UniformBigDecimalValueGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.UniformIntegerValueGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.UniformLongValueGenerator
 
initialize() - Method in class com.twilio.kudu.dataloader.generator.ValueListGenerator
 
inListOptimizationAllowed(int) - Method in class com.twilio.kudu.sql.CalciteKuduPredicate
Returns true or false if this can be considered for in list optimization.
inListOptimizationAllowed(int) - Method in class com.twilio.kudu.sql.ComparisonPredicate
 
InListPredicate - Class in com.twilio.kudu.sql
An implementation of CalciteKuduPredicate that creates an IN LIST predicate to KuduEnumerable KuduPredicate.newInListPredicate(ColumnSchema, List)
InListPredicate(int, List<Object>) - Constructor for class com.twilio.kudu.sql.InListPredicate
 
inMemoryCondition - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
INSTANCE - Static variable in class com.twilio.kudu.sql.metadata.KuduRelMetadataProvider
 
INSTANCE - Static variable in class com.twilio.kudu.sql.rules.KuduProjectValuesRule
 
INSTANCE - Static variable in class com.twilio.kudu.sql.rules.KuduToEnumerableConverter
 
INSTANCE - Static variable in class com.twilio.kudu.sql.rules.KuduValuesRule
 
INSTANCE - Static variable in class com.twilio.kudu.sql.rules.KuduWriteRule
 
INSTANCE - Static variable in class com.twilio.kudu.sql.schema.DefaultKuduSchemaFactory
 
invertComparisonOp(KuduPredicate.ComparisonOp) - Method in class com.twilio.kudu.sql.CalciteKuduPredicate
 
isColumnOrderedDesc(int) - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
isColumnOrderedDesc(String) - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
isDisableCubeAggregations() - Method in class com.twilio.kudu.sql.CalciteModifiableKuduTable
 
isDisableInListOptimizationPresent - Variable in class com.twilio.kudu.sql.rules.KuduSortRule.KuduFilterVisitor
 
isNullable - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
isPk - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
isRowTimestamp - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
isTerminal() - Method in class com.twilio.kudu.sql.CalciteScannerMessage
Whether or not this message means the end of the scan
isValidPlan(Project, RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
 
isValidPlan(Project, RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
 
isValidRelNodePlan(RelNode, RelMetadataQuery) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Returns whether a RelNode is a valid tree.

J

JDBCUtil - Class in com.twilio.kudu.sql
 
JDBCUtil() - Constructor for class com.twilio.kudu.sql.JDBCUtil
 

K

KUDU_CONNECTION_STRING - Static variable in class com.twilio.kudu.sql.schema.KuduSchema
 
KUDU_FILTER_INTO_JOIN - Static variable in class com.twilio.kudu.sql.rules.KuduFilterIntoJoinRule
 
KUDU_HINT_STRATEGY_TABLE - Static variable in class com.twilio.kudu.sql.KuduQuery
 
KUDU_MUTATE_ROW_METHOD - com.twilio.kudu.sql.KuduMethod
 
KUDU_MUTATE_TUPLES_METHOD - com.twilio.kudu.sql.KuduMethod
 
KUDU_QUERY_METHOD - com.twilio.kudu.sql.KuduMethod
 
KuduAggregationLimitRule - Class in com.twilio.kudu.sql.rules
Rule to match a limit over a sort over aggregation.
KuduAggregationLimitRule(RelBuilderFactory) - Constructor for class com.twilio.kudu.sql.rules.KuduAggregationLimitRule
 
KuduCalciteConnectionImpl - Class in org.apache.calcite.jdbc
 
KuduCalciteConnectionImpl(Driver, AvaticaFactory, String, Properties, CalciteSchema, JavaTypeFactory) - Constructor for class org.apache.calcite.jdbc.KuduCalciteConnectionImpl
 
KuduCalciteFactory - Class in org.apache.calcite.jdbc
Factory that uses CalciteJdbc41Factory as a delegate so that we can create our own KuduCalciteConnectionImpl that exposes KuduMetaImpl
KuduCalciteFactory() - Constructor for class org.apache.calcite.jdbc.KuduCalciteFactory
 
KuduCalciteFactory(int, int) - Constructor for class org.apache.calcite.jdbc.KuduCalciteFactory
 
KuduColumnVisitor() - Constructor for class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
KuduDriver - Class in org.apache.calcite.jdbc
Customized driver so that we can use our own meta implementation
KuduDriver() - Constructor for class org.apache.calcite.jdbc.KuduDriver
 
KuduEnumerable - Class in com.twilio.kudu.sql
An Enumerable that *can* returns Kudu records in Ascending order on their primary key.
KuduEnumerable(List<List<CalciteKuduPredicate>>, List<Integer>, AsyncKuduClient, CalciteKuduTable, long, long, boolean, boolean, KuduScanStats, AtomicBoolean, Function1<Object, Object>, Predicate1<Object>, boolean, Function1<Object, Object>, List<Integer>) - Constructor for class com.twilio.kudu.sql.KuduEnumerable
A KuduEnumerable is an Enumerable for Kudu that can be configured to be sorted.
KuduFilterIntoJoinRule - Class in com.twilio.kudu.sql.rules
 
KuduFilterIntoJoinRule(FilterJoinRule.FilterIntoJoinRule.FilterIntoJoinRuleConfig) - Constructor for class com.twilio.kudu.sql.rules.KuduFilterIntoJoinRule
 
KuduFilterRel - Class in com.twilio.kudu.sql.rel
 
KuduFilterRel(RelOptCluster, RelTraitSet, RelNode, RexNode, List<List<CalciteKuduPredicate>>, Schema, boolean) - Constructor for class com.twilio.kudu.sql.rel.KuduFilterRel
 
KuduFilterRule - Class in com.twilio.kudu.sql.rules
 
KuduFilterRule(RelBuilderFactory) - Constructor for class com.twilio.kudu.sql.rules.KuduFilterRule
 
KuduFilterVisitor(int, boolean) - Constructor for class com.twilio.kudu.sql.rules.KuduSortRule.KuduFilterVisitor
 
KuduLimitRel - Class in com.twilio.kudu.sql.rel
 
KuduLimitRel(RelOptCluster, RelTraitSet, RelNode, RexNode, RexNode) - Constructor for class com.twilio.kudu.sql.rel.KuduLimitRel
 
KuduLimitRule - Class in com.twilio.kudu.sql.rules
 
KuduLimitRule() - Constructor for class com.twilio.kudu.sql.rules.KuduLimitRule
 
KuduMaterializedViewAggregateRule<C extends org.apache.calcite.rel.rules.materialize.MaterializedViewAggregateRule.Config> - Class in org.apache.calcite.rel.rules.materialize
Materialized view rewriting for aggregate.
KuduMaterializedViewAggregateRule.Config - Interface in org.apache.calcite.rel.rules.materialize
Rule configuration.
KuduMaterializedViewOnlyAggregateRule - Class in org.apache.calcite.rel.rules.materialize
 
KuduMaterializedViewOnlyAggregateRule(RelOptRuleOperand, RelBuilderFactory, String, boolean, HepProgram, RelOptRule, RelOptRule, RelOptRule, RelOptRule) - Constructor for class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewOnlyAggregateRule
Deprecated.
KuduMaterializedViewOnlyAggregateRule(MaterializedViewOnlyAggregateRule.Config) - Constructor for class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewOnlyAggregateRule
 
KuduMaterializedViewOnlyAggregateRule(RelBuilderFactory, boolean, HepProgram) - Constructor for class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewOnlyAggregateRule
Deprecated.
KuduMaterializedViewRule<C extends org.apache.calcite.rel.rules.materialize.MaterializedViewRule.Config> - Class in org.apache.calcite.rel.rules.materialize
Planner rule that converts a Project followed by Aggregate or an Aggregate to a scan (and possibly other operations) over a materialized view.
KuduMaterializedViewRule.Config - Interface in org.apache.calcite.rel.rules.materialize
Rule configuration.
KuduMaterializedViewRule.Edge - Class in org.apache.calcite.rel.rules.materialize
Edge for graph.
KuduMaterializedViewRule.EquivalenceClasses - Class in org.apache.calcite.rel.rules.materialize
Class representing an equivalence class, i.e., a set of equivalent columns
KuduMaterializedViewRule.MatchModality - Enum in org.apache.calcite.rel.rules.materialize
Complete, view partial, or query partial.
KuduMaterializedViewRule.NodeLineage - Class in org.apache.calcite.rel.rules.materialize
Expression lineage details.
KuduMaterializedViewRule.ViewPartialRewriting - Class in org.apache.calcite.rel.rules.materialize
View partitioning result.
KuduMetaImpl - Class in org.apache.calcite.jdbc
 
KuduMetaImpl(CalciteConnectionImpl) - Constructor for class org.apache.calcite.jdbc.KuduMetaImpl
 
KuduMethod - Enum in com.twilio.kudu.sql
Builtin methods in the KuduDB adapter.
KuduNestedJoin - Class in com.twilio.kudu.sql.rel
Implements a join algorithm between two KuduToEnumerableRel objects using EnumerableDefaults.correlateBatchJoin(JoinType, Enumerable, Function1, Function2, Predicate2, int)
KuduNestedJoin(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelNode, RexNode, JoinRelType, int) - Constructor for class com.twilio.kudu.sql.rel.KuduNestedJoin
 
KuduNestedJoinRule - Class in com.twilio.kudu.sql.rules
 
KuduNestedJoinRule(RelBuilderFactory) - Constructor for class com.twilio.kudu.sql.rules.KuduNestedJoinRule
 
KuduNestedJoinRule(RelBuilderFactory, int) - Constructor for class com.twilio.kudu.sql.rules.KuduNestedJoinRule
 
KuduNonCumulativeCost - Class in com.twilio.kudu.sql.metadata
 
KuduNonCumulativeCost() - Constructor for class com.twilio.kudu.sql.metadata.KuduNonCumulativeCost
 
KuduPhysType - Class in com.twilio.kudu.sql
A partially implemented implementation of PhysType.
KuduPhysType(Schema, RelDataType, List<Integer>, List<Integer>) - Constructor for class com.twilio.kudu.sql.KuduPhysType
 
KuduPredicatePushDownVisitor - Class in com.twilio.kudu.sql.rules
KuduPredicatePushDownVisitor returns a List of a List of CalciteKuduPredicates.
KuduPredicatePushDownVisitor(RexBuilder, int, boolean) - Constructor for class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
KuduPrepareImpl - Class in org.apache.calcite.prepare
 
KuduPrepareImpl() - Constructor for class org.apache.calcite.prepare.KuduPrepareImpl
 
KuduPrepareImpl.TimeAggregationType - Enum in org.apache.calcite.prepare
 
kuduProjectedColumns - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
KuduProjectRel - Class in com.twilio.kudu.sql.rel
 
KuduProjectRel(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class com.twilio.kudu.sql.rel.KuduProjectRel
 
KuduProjectRel.KuduColumnVisitor - Class in com.twilio.kudu.sql.rel
 
KuduProjectRel.KuduProjectTransformer - Class in com.twilio.kudu.sql.rel
Used to transform projections of a LogicalProject to use the output of a KuduProjectRel
KuduProjectRule - Class in com.twilio.kudu.sql.rules
 
KuduProjectRule(RelBuilderFactory) - Constructor for class com.twilio.kudu.sql.rules.KuduProjectRule
 
KuduProjectTransformer() - Constructor for class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
KuduProjectValuesRel - Class in com.twilio.kudu.sql.rel
 
KuduProjectValuesRel(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class com.twilio.kudu.sql.rel.KuduProjectValuesRel
 
KuduProjectValuesRule - Class in com.twilio.kudu.sql.rules
 
KuduQuery - Class in com.twilio.kudu.sql
Relational expression representing a scan of a KuduTable
KuduQuery(RelOptCluster, RelTraitSet, RelOptTable, List<RelHint>, CalciteKuduTable, RelDataType) - Constructor for class com.twilio.kudu.sql.KuduQuery
 
KuduQueryable(QueryProvider, SchemaPlus, CalciteKuduTable, String) - Constructor for class com.twilio.kudu.sql.CalciteKuduTable.KuduQueryable
 
KuduRelMdSelectivity - Class in com.twilio.kudu.sql.metadata
 
KuduRelMdSelectivity() - Constructor for class com.twilio.kudu.sql.metadata.KuduRelMdSelectivity
 
KuduRelMetadataProvider - Class in com.twilio.kudu.sql.metadata
 
KuduRelMetadataProvider() - Constructor for class com.twilio.kudu.sql.metadata.KuduRelMetadataProvider
 
KuduRelNode - Interface in com.twilio.kudu.sql
A relational expression that represents a Kudu convention This will be used by the KuduToEnumerableConverter to translate into a Blocks.
KuduRelNode.Implementor - Class in com.twilio.kudu.sql
Implementor is a container to hold information required to execute a query or update to kudu.
KuduRules - Class in com.twilio.kudu.sql.rules
 
KuduRules() - Constructor for class com.twilio.kudu.sql.rules.KuduRules
 
KuduScanStats - Class in com.twilio.kudu.sql
A single KuduScanStats object is created per query that is executed and is accessed from all the ScannerCallbacks created for each scanner as well as the KuduEnumerable.
KuduScanStats() - Constructor for class com.twilio.kudu.sql.KuduScanStats
 
kuduSchema - Variable in class com.twilio.kudu.sql.rel.KuduFilterRel
 
KuduSchema - Class in com.twilio.kudu.sql.schema
 
KuduSchema(SchemaPlus, String, String, Map<String, KuduTableMetadata>, Map<String, Object>) - Constructor for class com.twilio.kudu.sql.schema.KuduSchema
 
KuduSortedAggregationRule - Class in com.twilio.kudu.sql.rules
Rule that matches a sort over an aggregation with both sort and aggregation using the same columns.
KuduSortedAggregationRule(RelBuilderFactory) - Constructor for class com.twilio.kudu.sql.rules.KuduSortedAggregationRule
 
KuduSortRel - Class in com.twilio.kudu.sql.rel
KuduSortRel(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode, boolean, boolean, List<Integer>) - Constructor for class com.twilio.kudu.sql.rel.KuduSortRel
 
KuduSortRel(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode, List<Integer>) - Constructor for class com.twilio.kudu.sql.rel.KuduSortRel
 
KuduSortRule - Class in com.twilio.kudu.sql.rules
Two Sort Rules that look to push the Sort into the Kudu RPC.
KuduSortRule(RelOptRuleOperand, RelBuilderFactory, String) - Constructor for class com.twilio.kudu.sql.rules.KuduSortRule
 
KuduSortRule.KuduFilterVisitor - Class in com.twilio.kudu.sql.rules
Searches RexNode to see if the Kudu column index -- stored as KuduSortRule.KuduFilterVisitor.mustHave is present in the RexNode and is required.
KuduSortRule.KuduSortWithFilter - Class in com.twilio.kudu.sql.rules
Rule to match a Sort above Filter and it is above KuduQuery.
KuduSortRule.KuduSortWithoutFilter - Class in com.twilio.kudu.sql.rules
Rule to match a Sort above KuduQuery.
KuduSortWithFilter(RelBuilderFactory) - Constructor for class com.twilio.kudu.sql.rules.KuduSortRule.KuduSortWithFilter
 
KuduSortWithoutFilter(RelBuilderFactory) - Constructor for class com.twilio.kudu.sql.rules.KuduSortRule.KuduSortWithoutFilter
 
kuduTable - Variable in class com.twilio.kudu.sql.CalciteKuduTable
 
kuduTable - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
kuduTable - Variable in class com.twilio.kudu.sql.mutation.MutationState
 
KuduTableMetadata - Class in com.twilio.kudu.sql.metadata
 
KuduTableMetadata.KuduTableMetadataBuilder - Class in com.twilio.kudu.sql.metadata
 
KuduTableMetadataBuilder() - Constructor for class com.twilio.kudu.sql.metadata.KuduTableMetadata.KuduTableMetadataBuilder
 
KuduToEnumerableConverter - Class in com.twilio.kudu.sql.rules
Rule to convert a relational expression from KuduRelNode.CONVENTION to EnumerableConvention.
KuduToEnumerableConverter(ConverterRule.Config) - Constructor for class com.twilio.kudu.sql.rules.KuduToEnumerableConverter
 
KuduToEnumerableRel - Class in com.twilio.kudu.sql.rel
 
KuduToEnumerableRel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class com.twilio.kudu.sql.rel.KuduToEnumerableRel
 
KuduValuesRel - Class in com.twilio.kudu.sql.rel
 
KuduValuesRel(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, RelTraitSet) - Constructor for class com.twilio.kudu.sql.rel.KuduValuesRel
 
KuduValuesRule - Class in com.twilio.kudu.sql.rules
 
KuduWrite - Class in com.twilio.kudu.sql
 
KuduWrite(KuduTable, RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Constructor for class com.twilio.kudu.sql.KuduWrite
 
KuduWriteRule - Class in com.twilio.kudu.sql.rules
 

L

limit - Variable in class com.twilio.kudu.sql.KuduEnumerable
 
limit - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
LIMIT - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
loadData(Optional<Long>) - Method in class com.twilio.kudu.dataloader.DataLoader
 
loadScenario(File) - Static method in class com.twilio.kudu.dataloader.Scenario
 
loadScenario(URL) - Static method in class com.twilio.kudu.dataloader.Scenario
 
logger - Static variable in class com.twilio.kudu.sql.rules.KuduToEnumerableConverter
 
LOGGER - Static variable in class com.twilio.kudu.sql.rel.KuduSortRel
 

M

makeNullable(boolean) - Method in class com.twilio.kudu.sql.KuduPhysType
 
MAP - Static variable in enum com.twilio.kudu.sql.KuduMethod
 
matches(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduNestedJoinRule
 
matches(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.SortInnerJoinTranspose
 
matches(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
 
maxValue - Variable in class com.twilio.kudu.dataloader.generator.UniformBigDecimalValueGenerator
 
maxValue - Variable in class com.twilio.kudu.dataloader.generator.UniformIntegerValueGenerator
 
maxValue - Variable in class com.twilio.kudu.dataloader.generator.UniformLongValueGenerator
 
mergePredicateLists(SqlKind, List<List<CalciteKuduPredicate>>, List<List<CalciteKuduPredicate>>) - Static method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
method - Variable in enum com.twilio.kudu.sql.KuduMethod
 
metrics - Variable in class com.twilio.kudu.sql.ScannerMetrics
 
minute - com.twilio.kudu.sql.metadata.CubeTableInfo.EventTimeAggregationType
 
MINUTE - org.apache.calcite.prepare.KuduPrepareImpl.TimeAggregationType
 
minValue - Variable in class com.twilio.kudu.dataloader.generator.UniformIntegerValueGenerator
 
minValue - Variable in class com.twilio.kudu.dataloader.generator.UniformLongValueGenerator
 
month - com.twilio.kudu.sql.metadata.CubeTableInfo.EventTimeAggregationType
 
MONTH - org.apache.calcite.prepare.KuduPrepareImpl.TimeAggregationType
 
MultipleColumnValueGenerator - Class in com.twilio.kudu.dataloader.generator
 
MultipleColumnValueGenerator() - Constructor for class com.twilio.kudu.dataloader.generator.MultipleColumnValueGenerator
 
mustHave - Variable in class com.twilio.kudu.sql.rules.KuduSortRule.KuduFilterVisitor
 
mutateRow(List<Integer>, List<Object>) - Method in class com.twilio.kudu.sql.CalciteKuduTable.KuduQueryable
Applies a mutation to the table using plain Objects
mutateRow(List<Integer>, List<Object>) - Method in class com.twilio.kudu.sql.mutation.MutationState
Mutate Kudu table using Object.
mutateTuples(List<Integer>, List<List<RexLiteral>>) - Method in class com.twilio.kudu.sql.CalciteKuduTable.KuduQueryable
Applies a mutation to the table using RexLiterals.
mutateTuples(List<Integer>, List<List<RexLiteral>>) - Method in class com.twilio.kudu.sql.mutation.MutationState
Mutate Kudu table using RexLiteral.
MutationState - Class in com.twilio.kudu.sql.mutation
 
MutationState(CalciteModifiableKuduTable) - Constructor for class com.twilio.kudu.sql.mutation.MutationState
 
MV_AGGREGATE - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 

N

NESTED_JOIN - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
NESTED_JOIN_PREDICATES - com.twilio.kudu.sql.KuduMethod
 
NestedJoinFactory - Class in com.twilio.kudu.sql
NestedJoinFactory is an implementation of Function1 that returns an Enumerable for the Right hand side of a nested join.
NestedJoinFactory(int, List<TranslationPredicate>, CloneableEnumerable<Object>) - Constructor for class com.twilio.kudu.sql.NestedJoinFactory
Create a Factory that produces Enumerable that can cache results from previous calls
nestedJoinPredicates(Join) - Method in class com.twilio.kudu.sql.KuduEnumerable
Return a function that accepts the Left hand sides rows and creates a new SortableEnumerable that will match the batch of rows.
newConnection(UnregisteredDriver, AvaticaFactory, String, Properties, CalciteSchema, JavaTypeFactory) - Method in class org.apache.calcite.jdbc.KuduCalciteFactory
 
newDatabaseMetaData(AvaticaConnection) - Method in class org.apache.calcite.jdbc.KuduCalciteFactory
 
newPreparedStatement(AvaticaConnection, Meta.StatementHandle, Meta.Signature, int, int, int) - Method in class org.apache.calcite.jdbc.KuduCalciteFactory
 
newResultSet(AvaticaStatement, QueryState, Meta.Signature, TimeZone, Meta.Frame) - Method in class org.apache.calcite.jdbc.KuduCalciteFactory
 
newResultSetMetaData(AvaticaStatement, Meta.Signature) - Method in class org.apache.calcite.jdbc.KuduCalciteFactory
 
newStatement(AvaticaConnection, Meta.StatementHandle, int, int, int) - Method in class org.apache.calcite.jdbc.KuduCalciteFactory
 
nextBatch() - Method in class com.twilio.kudu.sql.ScannerCallback
After an Batch is completed, this method should be called to fetch the next
NullPredicate - Class in com.twilio.kudu.sql
An implementation of CalciteKuduPredicate that pushes down both NOT NULL and IS NULL to Kudu.
NullPredicate(int, boolean) - Constructor for class com.twilio.kudu.sql.NullPredicate
 
numBindExpressions - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
numDaysBefore - Variable in class com.twilio.kudu.dataloader.generator.TimestampGenerator
 
numUniqueGroups - Variable in class com.twilio.kudu.dataloader.generator.CubeGenerator
 
numValues - Variable in class com.twilio.kudu.dataloader.generator.PhoneNumberListGenerator
 
numValues - Variable in class com.twilio.kudu.dataloader.generator.SidListGenerator
 

O

of(RelNode, Project, RelNode) - Static method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.ViewPartialRewriting
 
offset - Variable in class com.twilio.kudu.sql.KuduEnumerable
 
offset - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
offset - Variable in class com.twilio.kudu.sql.rel.KuduLimitRel
 
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduAggregationLimitRule
 
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduFilterRule
When we match, this method needs to transform the RelOptRuleCall into a new rule with push filters applied.
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduLimitRule
 
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduNestedJoinRule
 
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduProjectRule
 
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduSortedAggregationRule
 
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduSortRule.KuduSortWithFilter
 
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.KuduSortRule.KuduSortWithoutFilter
 
onMatch(RelOptRuleCall) - Method in class com.twilio.kudu.sql.rules.SortInnerJoinTranspose
 
onMatch(RelOptRuleCall) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewOnlyAggregateRule
 
operation - Variable in class com.twilio.kudu.sql.ComparisonPredicate
 
org.apache.calcite.jdbc - package org.apache.calcite.jdbc
 
org.apache.calcite.prepare - package org.apache.calcite.prepare
 
org.apache.calcite.rel.rules.materialize - package org.apache.calcite.rel.rules.materialize
 
org.apache.calcite.sql - package org.apache.calcite.sql
 

P

perform(RelOptRuleCall, Project, RelNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Rewriting logic is based on "Optimizing Queries Using Materialized Views: A Practical, Scalable Solution" by Goldstein and Larson.
perform(RelOptRuleCall, Filter, Join) - Method in class com.twilio.kudu.sql.rules.KuduFilterIntoJoinRule
 
perform(RelOptRuleCall, Sort, KuduQuery, KuduTable, Optional<Filter>) - Method in class com.twilio.kudu.sql.rules.KuduSortRule
 
perform(RelOptRuleCall, Sort, Aggregate, KuduToEnumerableRel, Project, Filter, KuduQuery) - Method in class com.twilio.kudu.sql.rules.KuduSortedAggregationRule
 
perform(RelOptRuleCall, Sort, Aggregate, Project, Filter, KuduQuery) - Method in class com.twilio.kudu.sql.rules.KuduAggregationLimitRule
 
PhoneNumberListGenerator - Class in com.twilio.kudu.dataloader.generator
 
PhoneNumberListGenerator(int) - Constructor for class com.twilio.kudu.dataloader.generator.PhoneNumberListGenerator
 
pkSortColumns - Variable in class com.twilio.kudu.sql.rules.KuduSortRule
 
precision - Variable in class com.twilio.kudu.dataloader.generator.UniformBigDecimalValueGenerator
 
precision - Variable in class org.apache.calcite.sql.SqlDataTypeNode
 
predicates - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
primaryKeyColumnsInProjection - Variable in class com.twilio.kudu.sql.CalciteRow
 
project(List<Integer>, boolean, JavaRowFormat) - Method in class com.twilio.kudu.sql.KuduPhysType
 
project(List<Integer>, JavaRowFormat) - Method in class com.twilio.kudu.sql.KuduPhysType
 
PROJECT - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
projections - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
projectMergeRule() - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule.Config
 
projectRowType - Variable in class com.twilio.kudu.sql.KuduQuery
List of column indices that are stored in reverse order.
propertyName - Variable in class org.apache.calcite.sql.SqlOptionNode
 
pushFilterToOriginalViewPlan(RelBuilder, RelNode, RelNode, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
 
pushFilterToOriginalViewPlan(RelBuilder, RelNode, RelNode, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Once we create a compensation predicate, this method is responsible for pushing the resulting filter through the view nodes.

Q

query(List<List<CalciteKuduPredicate>>, List<Integer>, long, long, boolean, boolean, KuduScanStats, AtomicBoolean, Function1<Object, Object>, Predicate1<Object>, boolean, Function1<Object, Object>, List<Integer>) - Method in class com.twilio.kudu.sql.CalciteKuduTable.KuduQueryable
This is the method that is called by Code generation to run the query.
QUERY_PARTIAL - org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.MatchModality
 

R

randomSid() - Method in class com.twilio.kudu.dataloader.generator.RandomSidGenerator
 
RandomSidGenerator - Class in com.twilio.kudu.dataloader.generator
 
RandomSidGenerator(String) - Constructor for class com.twilio.kudu.dataloader.generator.RandomSidGenerator
 
READ_SNAPSHOT_TIME_DIFFERENCE - Static variable in class com.twilio.kudu.sql.schema.KuduSchema
 
readSnapshotTimeDifference - Variable in class com.twilio.kudu.sql.CalciteKuduTable
 
readSnapshotTimeDifference - Variable in class com.twilio.kudu.sql.schema.KuduSchema
 
record(List<Expression>) - Method in class com.twilio.kudu.sql.KuduPhysType
 
register(RelOptPlanner) - Method in class com.twilio.kudu.sql.KuduQuery
 
register(RelOptPlanner) - Method in class com.twilio.kudu.sql.KuduWrite
 
registerGenerator(Class<?>, String) - Static method in class com.twilio.kudu.dataloader.Scenario
 
replaceWithOriginalReferences(RexBuilder, RelNode, KuduMaterializedViewRule.NodeLineage, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Given the input expression, it will replace (sub)expressions when possible using the content of the mapping.
reset() - Method in class com.twilio.kudu.dataloader.generator.CubeGenerator
 
reset() - Method in class com.twilio.kudu.dataloader.generator.MultipleColumnValueGenerator
Reset the state so that column values for a new row can be generated
rewriteExpression(RexBuilder, RelMetadataQuery, RelNode, RelNode, List<RexNode>, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, boolean, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
First, the method takes the node expressions nodeExprs and swaps the table and column references using the table mapping and the equivalence classes.
rewriteExpressions(RexBuilder, RelMetadataQuery, RelNode, RelNode, List<RexNode>, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, boolean, List<RexNode>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
First, the method takes the node expressions nodeExprs and swaps the table and column references using the table mapping and the equivalence classes.
rewriteQuery(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, RexNode, RexNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, KuduMaterializedViewRule.EquivalenceClasses, boolean) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
 
rewriteQuery(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, RexNode, RexNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses, KuduMaterializedViewRule.EquivalenceClasses, boolean) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
If the view will be used in a union rewriting, this method is responsible for rewriting the query branch of the union using the given compensation predicate.
rewriteView(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, KuduMaterializedViewRule.MatchModality, boolean, RelNode, Project, RelNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
 
rewriteView(RelBuilder, RexBuilder, RexSimplify, RelMetadataQuery, KuduMaterializedViewRule.MatchModality, boolean, RelNode, Project, RelNode, Project, RelNode, BiMap<RexTableInputRef.RelTableRef, RexTableInputRef.RelTableRef>, KuduMaterializedViewRule.EquivalenceClasses) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Rewrites the query using the given view query.
rightHandValue - Variable in class com.twilio.kudu.sql.ComparisonPredicate
 
row - Variable in class com.twilio.kudu.sql.CalciteScannerMessage
 
ROW - com.twilio.kudu.sql.CalciteScannerMessage.MessageType
 
rowSchema - Variable in class com.twilio.kudu.sql.CalciteRow
 
RowValueExpressionConverter - Class in com.twilio.kudu.sql.rules
Used to paginate through rows in the order of the primary key columns by comparing row expressions with a greater than operator If the the PK of the table is (A asc, B asc, C asc) (A, B, C) > ('a1', 'b1', * 'c1') is transformed to (A > 'a1') OR ((A = 'a1') AND (B > 'b1')) OR ((A = 'a1') AND (B = 'b1') AND (C > 'c1')) If the the PK of the table is (A asc, B desc, C asc) (A, B, C) > ('a1', 'b1', 'c1') is transformed to (A > 'a1') OR ((A = 'a1') AND (B < 'b1')) OR ((A = 'a1') AND (B = 'b1') AND (C > 'c1')) This implementation is different from the SQL-92 standard see https://stackoverflow.com/questions/32981903/sql-syntax-term-for-where-col1-col2-val1-val2/32982077#32982077
RowValueExpressionConverter(RexBuilder, CalciteKuduTable) - Constructor for class com.twilio.kudu.sql.rules.RowValueExpressionConverter
 

S

scale - Variable in class com.twilio.kudu.dataloader.generator.UniformBigDecimalValueGenerator
 
scale - Variable in class org.apache.calcite.sql.SqlDataTypeNode
 
ScannerCallback - Class in com.twilio.kudu.sql
Scanner Callback that produces CalciteScannerMessage into a BlockingQueue.
ScannerCallback(CalciteKuduTable, AsyncKuduScanner, BlockingQueue<CalciteScannerMessage<CalciteRow>>, AtomicBoolean, AtomicBoolean, Schema, KuduScanStats, boolean, Function1<Object, Object>, Predicate1<Object>, boolean, List<Integer>) - Constructor for class com.twilio.kudu.sql.ScannerCallback
 
scannerId - Variable in class com.twilio.kudu.sql.ScannerMetrics
 
ScannerMetrics - Class in com.twilio.kudu.sql
Metric information for a single kudu scanner
ScannerMetrics(AsyncKuduScanner) - Constructor for class com.twilio.kudu.sql.ScannerMetrics
 
scanPredicates - Variable in class com.twilio.kudu.sql.rel.KuduFilterRel
 
scanStats - Variable in class com.twilio.kudu.sql.KuduEnumerable
 
Scenario - Class in com.twilio.kudu.dataloader
 
Scenario.ScenarioBuilder - Class in com.twilio.kudu.dataloader
 
ScenarioBuilder(String, int) - Constructor for class com.twilio.kudu.dataloader.Scenario.ScenarioBuilder
 
schemaCache - Variable in class com.twilio.kudu.sql.schema.BaseKuduSchemaFactory
 
second - com.twilio.kudu.sql.metadata.CubeTableInfo.EventTimeAggregationType
 
SECOND - org.apache.calcite.prepare.KuduPrepareImpl.TimeAggregationType
 
selector(ParameterExpression, List<Integer>, JavaRowFormat) - Method in class com.twilio.kudu.sql.KuduPhysType
 
session - Variable in class com.twilio.kudu.sql.mutation.MutationState
 
setColumnNameToValueGenerator(Map<String, SingleColumnValueGenerator>) - Method in class com.twilio.kudu.dataloader.generator.CubeGenerator
 
setCubeTableInfoList(List<CubeTableInfo>) - Method in class com.twilio.kudu.sql.metadata.KuduTableMetadata.KuduTableMetadataBuilder
 
setCubeTables(List<CalciteKuduTable>) - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
setDescendingOrderedColumnNames(List<String>) - Method in class com.twilio.kudu.sql.metadata.KuduTableMetadata.KuduTableMetadataBuilder
 
setDescendingOrderedFieldIndices(List<Integer>) - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
setDisableCubeAggregation(boolean) - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
setEnableInserts(boolean) - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
setEventTimeAggregationType(CubeTableInfo.EventTimeAggregationType) - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
setReadSnapshotTimeDifference(long) - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
setTableType(TableType) - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
setTimestampColumnIndex(Integer) - Method in class com.twilio.kudu.sql.CalciteKuduTableBuilder
 
setTimestampColumnName(String) - Method in class com.twilio.kudu.sql.metadata.KuduTableMetadata.KuduTableMetadataBuilder
 
setTimeToFirstRowMs() - Method in class com.twilio.kudu.sql.KuduScanStats
 
setTotalTimeMs() - Method in class com.twilio.kudu.sql.KuduScanStats
 
shuttleReferences(RexBuilder, RexNode, Multimap<RexNode, Integer>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Replaces all the possible sub-expressions by input references to the input node.
shuttleReferences(RexBuilder, RexNode, Multimap<RexNode, Integer>, RelNode, Multimap<Integer, Integer>) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Replaces all the possible sub-expressions by input references to the input node.
shuttleReferences(RexBuilder, RexNode, Mapping) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Replaces all the input references by the position in the input column set.
SidListGenerator - Class in com.twilio.kudu.dataloader.generator
 
SidListGenerator(String, int) - Constructor for class com.twilio.kudu.dataloader.generator.SidListGenerator
 
sidPrefix - Variable in class com.twilio.kudu.dataloader.generator.RandomSidGenerator
 
SIMPLE_SORT_RULE - Static variable in class com.twilio.kudu.sql.rules.KuduSortRule
 
SingleColumnValueGenerator<T> - Class in com.twilio.kudu.dataloader.generator
 
SingleColumnValueGenerator() - Constructor for class com.twilio.kudu.dataloader.generator.SingleColumnValueGenerator
 
sort - Variable in class com.twilio.kudu.sql.KuduEnumerable
 
SORT - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
SORT_OVER_JOIN_TRANSPOSE - Static variable in class com.twilio.kudu.sql.rules.KuduRules
 
sorted - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
SORTED_AGGREGATION_RULE - Static variable in class com.twilio.kudu.sql.rules.KuduSortedAggregationRule
 
sortedEnumerator(List<AsyncKuduScanner>, List<Enumerator<CalciteRow>>) - Method in class com.twilio.kudu.sql.KuduEnumerable
 
sortedPrefixKeySelector - Variable in class com.twilio.kudu.sql.KuduEnumerable
 
SortInnerJoinTranspose - Class in com.twilio.kudu.sql.rules
 
SortInnerJoinTranspose(RelBuilderFactory) - Constructor for class com.twilio.kudu.sql.rules.SortInnerJoinTranspose
 
sortOrder - Variable in class org.apache.calcite.sql.SqlColumnDefInPkConstraintNode
 
sortOrder - Variable in class org.apache.calcite.sql.SqlColumnDefNode
 
sortPkColumns - Variable in class com.twilio.kudu.sql.KuduEnumerable
 
sortPkColumns - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
sortPkColumns - Variable in class com.twilio.kudu.sql.rel.KuduSortRel
 
SOURCE - Static variable in class com.twilio.kudu.sql.metadata.KuduNonCumulativeCost
 
SOURCE - Static variable in class com.twilio.kudu.sql.metadata.KuduRelMdSelectivity
 
splitPredicates(RexBuilder, RexNode) - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule
Classifies each of the predicates in the list into one of these two categories: 1-l) column equality predicates, or 2-r) residual predicates, all the rest
SqlColumnDefInPkConstraintNode - Class in org.apache.calcite.sql
 
SqlColumnDefInPkConstraintNode(SqlParserPos, SqlIdentifier, SortOrder) - Constructor for class org.apache.calcite.sql.SqlColumnDefInPkConstraintNode
 
SqlColumnDefNode - Class in org.apache.calcite.sql
 
SqlColumnDefNode(SqlParserPos, SqlIdentifier, SqlDataTypeNode, boolean, boolean, boolean, SortOrder, SqlNode, SqlNode, SqlNode, int, SqlNode) - Constructor for class org.apache.calcite.sql.SqlColumnDefNode
 
SqlColumnNameNode - Class in org.apache.calcite.sql
 
SqlColumnNameNode(SqlParserPos, SqlIdentifier) - Constructor for class org.apache.calcite.sql.SqlColumnNameNode
 
SqlDataTypeNode - Class in org.apache.calcite.sql
 
SqlDataTypeNode(SqlParserPos, String, Integer, Integer) - Constructor for class org.apache.calcite.sql.SqlDataTypeNode
 
SqlDataTypeNode(SqlParserPos, SqlTypeNameSpec) - Constructor for class org.apache.calcite.sql.SqlDataTypeNode
 
SqlOptionNode - Class in org.apache.calcite.sql
 
SqlOptionNode(SqlParserPos, String, String) - Constructor for class org.apache.calcite.sql.SqlOptionNode
 
SqlOptionNode(SqlParserPos, SqlNode, SqlIdentifier) - Constructor for class org.apache.calcite.sql.SqlOptionNode
 
SqlOptionNode(SqlParserPos, SqlNode, SqlLiteral) - Constructor for class org.apache.calcite.sql.SqlOptionNode
 
SqlUtil - Class in com.twilio.kudu.sql
 
SqlUtil() - Constructor for class com.twilio.kudu.sql.SqlUtil
 
startPrimaryKey - Variable in class com.twilio.kudu.sql.ScannerMetrics
 
SUPPORTED_DATE_TIME_ROLLUP_UNITS - Static variable in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule
 
SYSTEM - com.twilio.kudu.sql.TableType
 

T

table - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
table - Variable in class com.twilio.kudu.sql.ScannerMetrics
 
tableDataType - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
tableName - Variable in class com.twilio.kudu.sql.metadata.CubeTableInfo
 
tablet - Variable in class com.twilio.kudu.sql.ScannerMetrics
 
tableType - Variable in class com.twilio.kudu.sql.CalciteKuduTable
 
TableType - Enum in com.twilio.kudu.sql
 
timestampColumnIndex - Variable in class com.twilio.kudu.sql.CalciteKuduTable
 
TimestampGenerator - Class in com.twilio.kudu.dataloader.generator
Generates a timestamp randomly between [numDaysAgo, now())
TimestampGenerator(long) - Constructor for class com.twilio.kudu.dataloader.generator.TimestampGenerator
 
toModificationRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Method in class com.twilio.kudu.sql.CalciteModifiableKuduTable
 
toPredicate(CalciteKuduTable) - Method in class com.twilio.kudu.sql.CalciteKuduPredicate
Transforms this POJO into a proper KuduPredicate
toPredicate(Object[]) - Method in class com.twilio.kudu.sql.TranslationPredicate
 
toPredicate(ColumnSchema, boolean) - Method in class com.twilio.kudu.sql.CalciteKuduPredicate
Transforms this POJO into a proper KuduPredicate
toPredicate(ColumnSchema, boolean) - Method in class com.twilio.kudu.sql.ComparisonPredicate
In order to support descending ordered primary key column we invert the column value (see MutationState.getColumnValue())
toPredicate(ColumnSchema, boolean) - Method in class com.twilio.kudu.sql.InListPredicate
 
toPredicate(ColumnSchema, boolean) - Method in class com.twilio.kudu.sql.NullPredicate
 
toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class com.twilio.kudu.sql.CalciteKuduTable
 
toString() - Method in class com.twilio.kudu.sql.ComparisonPredicate
 
toString() - Method in class com.twilio.kudu.sql.InListPredicate
 
toString() - Method in class com.twilio.kudu.sql.NullPredicate
 
toString() - Method in class com.twilio.kudu.sql.ScannerMetrics
 
toString() - Method in class org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.Edge
 
translateDefaultValue(Type, Object) - Static method in class com.twilio.kudu.sql.SqlUtil
Translates the default object value type to the data type that is expected by Kudu
TranslationPredicate - Class in com.twilio.kudu.sql
 
TranslationPredicate(int, int, RexCall) - Constructor for class com.twilio.kudu.sql.TranslationPredicate
 
TranslationPredicate(int, int, KuduPredicate.ComparisonOp) - Constructor for class com.twilio.kudu.sql.TranslationPredicate
 
TranslationPredicate.ConditionTranslationVisitor - Class in com.twilio.kudu.sql
Computes the conjunction based on the join condition
tuples - Variable in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
type - Variable in class com.twilio.kudu.sql.CalciteScannerMessage
 
typeName - Variable in class org.apache.calcite.sql.SqlDataTypeNode
 

U

UniformBigDecimalValueGenerator - Class in com.twilio.kudu.dataloader.generator
 
UniformBigDecimalValueGenerator(double) - Constructor for class com.twilio.kudu.dataloader.generator.UniformBigDecimalValueGenerator
 
UniformIntegerValueGenerator - Class in com.twilio.kudu.dataloader.generator
 
UniformIntegerValueGenerator(int, int) - Constructor for class com.twilio.kudu.dataloader.generator.UniformIntegerValueGenerator
 
UniformLongValueGenerator - Class in com.twilio.kudu.dataloader.generator
 
UniformLongValueGenerator() - Constructor for class com.twilio.kudu.dataloader.generator.UniformLongValueGenerator
 
UniformLongValueGenerator(long, long) - Constructor for class com.twilio.kudu.dataloader.generator.UniformLongValueGenerator
 
unionRewritingPullProgram() - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.Config
 
unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlColumnDefInPkConstraintNode
 
unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlColumnDefNode
 
unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlColumnNameNode
 
unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlDataTypeNode
 
unparse(SqlWriter, int, int) - Method in class org.apache.calcite.sql.SqlOptionNode
 
unsortedEnumerator(List<AsyncKuduScanner>, BlockingQueue<CalciteScannerMessage<CalciteRow>>) - Method in class com.twilio.kudu.sql.KuduEnumerable
 
updateMutationState(Map<Integer, Object>) - Method in class com.twilio.kudu.sql.mutation.CubeMutationState
Updates the aggregated values for this cube table that is used to generate an upsert when commit is called
updateMutationState(Map<Integer, Object>) - Method in class com.twilio.kudu.sql.mutation.MutationState
Creates a mutation for the row being inserted and adds it to the kudu session.
useInMemoryFiltering - Variable in class com.twilio.kudu.sql.rel.KuduFilterRel
 

V

VALID_CALL_TYPES - Static variable in class com.twilio.kudu.sql.rules.KuduNestedJoinRule
 
validate(SqlValidator, SqlValidatorScope) - Method in class org.apache.calcite.sql.AbstractSqlNode
 
value - Variable in class org.apache.calcite.sql.SqlOptionNode
 
ValueListGenerator - Class in com.twilio.kudu.dataloader.generator
 
ValueListGenerator(List<String>) - Constructor for class com.twilio.kudu.dataloader.generator.ValueListGenerator
 
valueOf(String) - Static method in enum com.twilio.kudu.sql.CalciteScannerMessage.MessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.twilio.kudu.sql.KuduMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.twilio.kudu.sql.metadata.CubeTableInfo.EventTimeAggregationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.twilio.kudu.sql.TableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.calcite.prepare.KuduPrepareImpl.TimeAggregationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.MatchModality
Returns the enum constant of this type with the specified name.
values - Variable in class com.twilio.kudu.dataloader.generator.ValueListGenerator
 
values() - Static method in enum com.twilio.kudu.sql.CalciteScannerMessage.MessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.twilio.kudu.sql.KuduMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.twilio.kudu.sql.metadata.CubeTableInfo.EventTimeAggregationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.twilio.kudu.sql.TableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.calcite.prepare.KuduPrepareImpl.TimeAggregationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.MatchModality
Returns an array containing the constants of this enum type, in the order they are declared.
valueType - Variable in class com.twilio.kudu.dataloader.generator.EnvironmentVariableGenerator
 
variableName - Variable in class com.twilio.kudu.dataloader.generator.EnvironmentVariableGenerator
 
VIEW_PARTIAL - org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.MatchModality
 
visitCall(RexCall) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
Extact the columns used an inputs to functions
visitCall(RexCall) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
Extract the columns used an inputs to functions
visitCall(RexCall) - Method in class com.twilio.kudu.sql.rules.KuduSortRule.KuduFilterVisitor
 
visitCall(RexCall) - Method in class com.twilio.kudu.sql.rules.RowValueExpressionConverter
 
visitCall(RexCall) - Method in class com.twilio.kudu.sql.TranslationPredicate.ConditionTranslationVisitor
 
visitCall(RexCall, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
A sql function call, process it.
visitChild(int, RelNode) - Method in class com.twilio.kudu.sql.KuduRelNode.Implementor
 
visitCorrelVariable(RexCorrelVariable) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
visitCorrelVariable(RexCorrelVariable) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitCorrelVariable(RexCorrelVariable, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitDynamicParam(RexDynamicParam) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
visitDynamicParam(RexDynamicParam) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitDynamicParam(RexDynamicParam, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitFieldAccess(RexFieldAccess) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitFieldAccess(RexFieldAccess, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitInputRef(RexInputRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
visitInputRef(RexInputRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitInputRef(RexInputRef) - Method in class com.twilio.kudu.sql.rules.KuduSortRule.KuduFilterVisitor
 
visitInputRef(RexInputRef, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitLiteral(RexLiteral) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
visitLiteral(RexLiteral) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitLiteral(RexLiteral) - Method in class com.twilio.kudu.sql.rules.KuduSortRule.KuduFilterVisitor
 
visitLiteral(RexLiteral, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
This visit method adds a predicate.
visitLocalRef(RexLocalRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
visitLocalRef(RexLocalRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitLocalRef(RexLocalRef) - Method in class com.twilio.kudu.sql.rules.KuduSortRule.KuduFilterVisitor
 
visitLocalRef(RexLocalRef, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitOver(RexOver) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitOver(RexOver, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitPatternFieldRef(RexPatternFieldRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
visitPatternFieldRef(RexPatternFieldRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitPatternFieldRef(RexPatternFieldRef, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitRangeRef(RexRangeRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
visitRangeRef(RexRangeRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitRangeRef(RexRangeRef, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitSubQuery(RexSubQuery) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitSubQuery(RexSubQuery, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 
visitTableInputRef(RexTableInputRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduColumnVisitor
 
visitTableInputRef(RexTableInputRef) - Method in class com.twilio.kudu.sql.rel.KuduProjectRel.KuduProjectTransformer
 
visitTableInputRef(RexTableInputRef, RexCall) - Method in class com.twilio.kudu.sql.rules.KuduPredicatePushDownVisitor
 

W

withAggregateProjectPullUpConstantsRule(RelOptRule) - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule.Config
 
withFastBailOut(boolean) - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.Config
 
withFilterAggregateTransposeRule(RelOptRule) - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule.Config
 
withFilterProjectTransposeRule(RelOptRule) - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule.Config
 
withGenerateUnionRewriting(boolean) - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.Config
 
withHints(List<RelHint>) - Method in class com.twilio.kudu.sql.KuduQuery
 
withProjectMergeRule(RelOptRule) - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewAggregateRule.Config
 
withUnionRewritingPullProgram(HepProgram) - Method in interface org.apache.calcite.rel.rules.materialize.KuduMaterializedViewRule.Config
 

Y

year - com.twilio.kudu.sql.metadata.CubeTableInfo.EventTimeAggregationType
 
YEAR - org.apache.calcite.prepare.KuduPrepareImpl.TimeAggregationType
 
A B C D E F G H I J K L M N O P Q R S T U V W Y 
All Classes All Packages