A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- A_TABLE - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- AB_TABLES - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- abc(StringBuilder, Object) - Method in class org.apache.calcite.util.Smalls.TableMacroFunctionWithNamedParameters
- abRecordType - Variable in class org.apache.calcite.test.catalog.Fixture
- abstractCast(RexNode, RelDataType) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates a call to the CAST operator.
- AbstractCommand() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- AbstractGeodeTest - Class in org.apache.calcite.adapter.geode.rel
-
Base class that allows sharing same geode instance across all tests.
- AbstractGeodeTest() - Constructor for class org.apache.calcite.adapter.geode.rel.AbstractGeodeTest
- AbstractModifiableTable(String) - Constructor for class org.apache.calcite.test.JdbcTest.AbstractModifiableTable
- AbstractModifiableView() - Constructor for class org.apache.calcite.test.JdbcTest.AbstractModifiableView
- AbstractPigTest - Class in org.apache.calcite.test
-
Common methods inheritable by all Pig-specific test classes.
- AbstractPigTest() - Constructor for class org.apache.calcite.test.AbstractPigTest
- AbstractSqlTester - Class in org.apache.calcite.sql.test
-
Abstract implementation of
SqlValidatorTestCase.Tester
that talks to a mock catalog. - AbstractSqlTester(SqlTestFactory) - Constructor for class org.apache.calcite.sql.test.AbstractSqlTester
- accept(PreparedStatement) - Method in interface org.apache.calcite.test.CalciteAssert.PreparedStatementConsumer
- add(int, int, int) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- add(long, int) - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- add(long, int) - Method in class org.apache.calcite.util.Smalls.MySumFunction
- add(long, int, int, int) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- add(long, int, String) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- add(long, int, String, String) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- add(short, int) - Method in class org.apache.calcite.util.Smalls.SumFunctionBadIAdd
- add(A, V) - Method in interface org.apache.calcite.util.Smalls.MyGenericAggFunction
- add(Integer, Integer) - Method in class org.apache.calcite.util.Smalls.MySum3
- add(RelDataType, Object[]) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.Builder
- add(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- add0(SqlTypeName, Object...) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.Builder
- add1(SqlTypeName, int, Object...) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.Builder
- addCloseCommand(int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Closes a previously
prepared
SQL statement. - addColumn(String, RelDataType) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addColumn(String, RelDataType, boolean) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addCommand(int, int, ConcurrentTestCommand) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Handles adding a command to
ConcurrentTestCommandGenerator.threadMap
. - addCommitCommand(int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Commits pending transaction on the thread's connection.
- addDdlCommand(int, int, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Executes a DDL statement immediately.
- addDiffMask(String) - Method in class org.apache.calcite.test.DiffTestCase
-
Adds a diff mask.
- addExplainCommand(int, int, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Adds an "explain plan" command.
- addExtraCommands(Iterable<String>, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- addFetchAndCompareCommand(int, int, int, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Executes a previously
prepared
SQL statement and compares itsResultSet
to the given data. - addHook(Hook, Consumer<T>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- addIgnorePattern(String) - Method in class org.apache.calcite.test.DiffTestCase
- addInsertCommand(int, int, int, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Executes the given SQL via
Statement.executeUpdate(String)
. - AddIntermediateNodeRule() - Constructor for class org.apache.calcite.plan.volcano.ComboRuleTest.AddIntermediateNodeRule
- addMonotonic(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- addOperator(SqlOperator) - Method in class org.apache.calcite.test.MockSqlOperatorTable
-
Adds an operator to this table.
- addPrepareCommand(int, int, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Creates a
PreparedStatement
for the given SQL. - addQuery(String) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- addQuery(String) - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- addRamp(MockSqlOperatorTable) - Static method in class org.apache.calcite.test.MockSqlOperatorTable
- addressType - Variable in class org.apache.calcite.test.catalog.Fixture
- addRollbackCommand(int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Rolls back pending transaction on the thread's connection.
- addRow(ImmutableList.Builder<ImmutableList<RexLiteral>>, RexBuilder, Object...) - Method in class org.apache.calcite.test.RelMetadataTest
- addRule(RelOptRule) - Method in class org.apache.calcite.test.MockRelOptPlanner
- addSchema(SchemaPlus, CalciteAssert.SchemaSpec) - Static method in class org.apache.calcite.test.CalciteAssert
- addSchemaIfNotExists(SchemaPlus, CalciteAssert.SchemaSpec) - Static method in class org.apache.calcite.test.CalciteAssert
- AddSchemaPostProcessor(String, Schema) - Constructor for class org.apache.calcite.test.CalciteAssert.AddSchemaPostProcessor
- AddSchemaSpecPostProcessor(CalciteAssert.SchemaSpec) - Constructor for class org.apache.calcite.test.CalciteAssert.AddSchemaSpecPostProcessor
- addSleepCommand(int, int, long) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Causes the given thread to sleep for the indicated number of milliseconds.
- addSynchronizationCommand(int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Adds a synchronization commands.
- addTable(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- addThreadWriters(Integer) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- adjustValue(String) - Method in class org.apache.calcite.test.CalciteAssert.ResultSetFormatter
- adviseSql(int, String, Consumer<ResultSet>) - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
- ADVISOR_TEST_FACTORY - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- after() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- after() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy
- after() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy.RefCountPolicy
- after() - Method in class org.apache.calcite.adapter.mongodb.MongoDatabasePolicy
- after() - Method in class org.apache.calcite.test.SqlToRelConverterExtendedTest
- afterClass() - Static method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- agg1() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- aggBuckets1() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- aggEmpty() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- aggManyAggregations() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- aggMultiBuckets() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- aggMultiValues() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- AggregationTest - Class in org.apache.calcite.adapter.elasticsearch
-
Testing Elasticsearch aggregation transformations.
- AggregationTest() - Constructor for class org.apache.calcite.adapter.elasticsearch.AggregationTest
- aggSingle1() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- aggSingle2() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- aid - Variable in class org.apache.calcite.test.BookstoreSchema.Author
- all() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- AllPrivate() - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest.AllPrivate
- allPrivates - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- AllType(boolean, byte, char, short, int, long, float, double, BigDecimal, BigInteger, String, Object) - Constructor for class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- AllTypesFunction() - Constructor for class org.apache.calcite.util.Smalls.AllTypesFunction
- ALT_EMPTY_TRAIT - Static variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
-
Private alternate trait.
- ALT_TRAIT - Static variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
-
Private alternate trait.
- ALT_TRAIT_DEF - Static variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
-
Private trait definition for an alternate type of traits.
- ALT_TRAIT2 - Static variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
-
Private alternate trait.
- AltTrait(VolcanoPlannerTraitTest.AltTraitDef, String) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- AltTraitConverter(RelOptCluster, RelNode, RelTrait) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitConverter
- AltTraitConverterRule(VolcanoPlannerTraitTest.AltTrait, VolcanoPlannerTraitTest.AltTrait, String) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitConverterRule
- AltTraitDef() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitDef
- altTraitOrdinal - Static variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
-
Ordinal count for alternate traits (so they can implement equals() and avoid being canonized into the same trait).
- AmbiguousNumber() - Constructor for class org.apache.calcite.util.ReflectVisitorTest.AmbiguousNumber
- amend(String, String) - Method in class org.apache.calcite.test.DiffRepository
- and(Iterable<? extends RexNode>) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- and(RexNode...) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- and(RexNode...) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- and(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- ANY - Static variable in class org.apache.calcite.sql.parser.SqlParserTest
- ANY - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- ANY - Static variable in class org.apache.calcite.test.SqlValidatorTest
- ANY_PARAMETER_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker that allows any number or type of parameters.
- ANY_RESULT_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker that allows any result.
- ANY_SAME_TYPE_MULTI_ARG - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- ANY_TO_BOOL - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- ANY_TYPE_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
-
Checker which allows any type.
- anyChild(Class<? extends RelNode>) - Static method in class org.apache.calcite.plan.volcano.TraitPropagationTest
- anyValue() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
-
Testing
SqlKind.ANY_VALUE
aggregate function - APOS - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- appendBlockWithSameVariable(Expression, Expression) - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest
- apply(I) - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest.Identity
- apply(Connection) - Method in class org.apache.calcite.test.CalciteAssert.AddSchemaPostProcessor
- apply(Connection) - Method in class org.apache.calcite.test.CalciteAssert.AddSchemaSpecPostProcessor
- apply(Connection) - Method in interface org.apache.calcite.test.CalciteAssert.ConnectionPostProcessor
- apply(Connection) - Method in class org.apache.calcite.test.CalciteAssert.DefaultSchemaPostProcessor
- apply(RelOptCluster, RelOptSchema, SchemaPlus) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PropAction
- apply(Profiler.Statistic) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid.StatisticToJson
- apply(Statement, FrameworkMethod, Object) - Method in class org.apache.calcite.test.SqlValidatorTestCase.TesterConfigurationRule
- applyDiffMask(String) - Method in class org.apache.calcite.test.DiffTestCase
- applyMapping(ObjectNode, String, String) - Static method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
-
Creates nested mappings for an index.
- applyTimes - Variable in class org.apache.calcite.test.HepPlannerTest.HepTestListener
- applyVariableRebindings() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- approximateCount() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
-
Checks Cardinality aggregation
approx_count_distinct
- ApproximateResultChecker(Number, double) - Constructor for class org.apache.calcite.sql.test.SqlTests.ApproximateResultChecker
- approxQuery(URL, String) - Method in class org.apache.calcite.test.DruidAdapterIT
- approxQuery(URL, String) - Method in class org.apache.calcite.test.DruidAdapterIT2
- argv - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ShellCommand
- ArrayAppendDoubleFunction() - Constructor for class org.apache.calcite.test.UdfTest.ArrayAppendDoubleFunction
- arrayAppendFun(List, Integer) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- ArrayAppendIntegerFunction() - Constructor for class org.apache.calcite.test.UdfTest.ArrayAppendIntegerFunction
- ArrayAppendScalarFunction() - Constructor for class org.apache.calcite.test.UdfTest.ArrayAppendScalarFunction
- arrayBigInt - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- arrayBigIntNullable - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- arrayFloat - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- arrayOfArrayBigInt - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- arrayOfArrayFloat - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- ArrayTableTest - Class in org.apache.calcite.adapter.clone
-
Unit test for
ArrayTable
andColumnLoader
. - ArrayTableTest() - Constructor for class org.apache.calcite.adapter.clone.ArrayTableTest
- asBoolValue(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
translates argument of !set force etc.
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.adapter.generate.RangeTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.calcite.tools.FrameworksTest.TableImpl
- assertAppend(Source, Source, String) - Method in class org.apache.calcite.util.SourceTest
- assertAppendUrl(Source, Source, String) - Method in class org.apache.calcite.util.SourceTest
- assertArgValue(int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- assertArrayEqual(String, Object[], Object[]) - Static method in class org.apache.calcite.test.CalciteAssert
-
Asserts that two objects are equal.
- assertByteArray(String, String, int) - Method in class org.apache.calcite.util.UtilTest
- assertCanonical(String, Supplier<List<RelCollation>>) - Method in class org.apache.calcite.plan.RelTraitTest
- assertComplete(String, String, String) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- assertComplete(String, String, String, Map<String, String>) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
-
Tests that a given SQL which may be invalid or incomplete simplifies itself and yields the salesTables set of completion hints.
- assertComplete(String, List<String>...) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- assertComplete(String, Map<String, String>, List<String>...) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- assertConvertsTo(String, String) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Checks that a SQL statement converts to a given plan.
- assertConvertsTo(String, String) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- assertConvertsTo(String, String, boolean) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Checks that a SQL statement converts to a given plan, optionally trimming columns that are not needed.
- assertConvertsTo(String, String, boolean) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- assertDejsonize(String, Matcher<Object>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertDejsonizeFailed(String, Matcher<? super Throwable>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertEmpty(String) - Method in class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
- assertEquals(String[], List<String>...) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- assertEquals(String, String, String) - Method in class org.apache.calcite.test.DiffRepository
- assertEqualsList(String, List<String>) - Static method in class org.apache.calcite.util.PartiallyOrderedSetTest
- assertEqualsVerbose(String, String) - Static method in class org.apache.calcite.util.TestUtil
- assertExceptionIsThrown(String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- assertExceptionIsThrown(String, String) - Method in class org.apache.calcite.sql.test.SqlRuntimeTester
- assertExceptionIsThrown(String, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- assertExceptionIsThrown(String, String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Checks that a query is valid, or, if invalid, throws the right message at the right location.
- assertExceptionIsThrown(String, String, boolean) - Method in class org.apache.calcite.sql.test.SqlRuntimeTester
- assertExprPrintsTo(boolean, String, String) - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- assertFailed(String, Supplier<?>, Matcher<? super Throwable>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertFails(String) - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchVersionTest
- assertHint(String, String) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
-
Checks that a given SQL statement yields the expected set of completion hints.
- assertHint(String, List<String>...) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- assertIsJsonArray(String, Matcher<? super Boolean>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertIsJsonObject(String, Matcher<? super Boolean>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertIsJsonScalar(String, Matcher<? super Boolean>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertIsJsonValue(String, Matcher<? super Boolean>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonApiCommonSyntax(Object, String, Matcher<? super SqlFunctions.PathContext>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonArray(Matcher<? super String>, SqlJsonConstructorNullClause, Object...) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonArrayAggAdd(List, Object, SqlJsonConstructorNullClause, Matcher<? super List>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonExists(Object, SqlJsonExistsErrorBehavior, Matcher<? super Boolean>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonExistsFailed(Object, SqlJsonExistsErrorBehavior, Matcher<? super Throwable>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonize(Object, Matcher<? super String>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonObject(Matcher<? super String>, SqlJsonConstructorNullClause, Object...) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonObjectAggAdd(Map, String, Object, SqlJsonConstructorNullClause, Matcher<? super Map>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonQuery(Object, SqlJsonQueryWrapperBehavior, SqlJsonQueryEmptyOrErrorBehavior, SqlJsonQueryEmptyOrErrorBehavior, Matcher<? super String>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonQueryFailed(Object, SqlJsonQueryWrapperBehavior, SqlJsonQueryEmptyOrErrorBehavior, SqlJsonQueryEmptyOrErrorBehavior, Matcher<? super Throwable>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonStructuredValueExpression(Object, Matcher<Object>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonValueAny(Object, SqlJsonValueEmptyOrErrorBehavior, Object, SqlJsonValueEmptyOrErrorBehavior, Object, Matcher<Object>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonValueAnyFailed(Object, SqlJsonValueEmptyOrErrorBehavior, Object, SqlJsonValueEmptyOrErrorBehavior, Object, Matcher<? super Throwable>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- assertJsonValueExpression(String, Matcher<Object>) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- AssertMetaData(CalciteAssert.ConnectionFactory, Function<Connection, ResultSet>) - Constructor for class org.apache.calcite.test.CalciteAssert.AssertMetaData
- assertModel(String) - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- assertModel(URL) - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- assertNoActiveScrolls() - Method in class org.apache.calcite.adapter.elasticsearch.ScrollingTest
-
Ensures there are no pending scroll contexts in elastic search cluster.
- assertNode(String, String, RexNode) - Method in class org.apache.calcite.test.RexProgramTest
-
Asserts that given node has expected string representation with account of node type
- assertPrepare(Connection, String, boolean, Function<RelNode, Void>, Function<RelNode, Void>) - Static method in class org.apache.calcite.test.CalciteAssert
- assertPrepare(Connection, String, int, boolean, List<Pair<Hook, Consumer>>, Consumer<ResultSet>, Consumer<Integer>, Consumer<Throwable>, CalciteAssert.PreparedStatementConsumer) - Static method in class org.apache.calcite.test.CalciteAssert
- assertPrintEquals(String, String, boolean) - Method in class org.apache.calcite.util.UtilTest
- assertPrintsTo(boolean, String, String) - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- assertQuery(Connection, String, int, boolean, List<Pair<Hook, Consumer>>, Consumer<ResultSet>, Consumer<Integer>, Consumer<Throwable>) - Static method in class org.apache.calcite.test.CalciteAssert
- AssertQuery(CalciteAssert.ConnectionFactory, String) - Constructor for class org.apache.calcite.test.CalciteAssert.AssertQuery
- assertReplacements(String, Map<String, String>, SqlAdvisor, String, List<SqlMoniker>) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- assertReversible(String) - Static method in class org.apache.calcite.util.UtilTest
- assertRows(Interpreter, boolean, String...) - Static method in class org.apache.calcite.test.InterpreterTest
- assertRows(Interpreter, String...) - Static method in class org.apache.calcite.test.InterpreterTest
- assertRowsUnordered(Interpreter, String...) - Static method in class org.apache.calcite.test.InterpreterTest
- assertScriptAndResults(String, String, String, String[]) - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- assertSimplify(String, String) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
-
Tests that a given SQL statement simplifies to the salesTables result.
- assertSingle(String) - Method in class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
- AssertThat(CalciteAssert.ConnectionFactory) - Constructor for class org.apache.calcite.test.CalciteAssert.AssertThat
- assertToIterBitSet(String, BitSet) - Method in class org.apache.calcite.util.BitSetsTest
-
Tests that iterating over a BitSet yields the expected string.
- assertToIterBitSet(String, ImmutableBitSet) - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests that iterating over an
ImmutableBitSet
yields the expected string. - assertTokenizesTo(String, String) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- assertTypeAndToString(RexNode, String, String) - Method in class org.apache.calcite.test.RexProgramTest
- assertUniqueConsistent(RelNode) - Method in class org.apache.calcite.test.RelMetadataTest
-
Asserts that
RelMetadataQuery.getUniqueKeys(RelNode)
andRelMetadataQuery.areColumnsUnique(RelNode, ImmutableBitSet)
return consistent results. - assertValid(RelNode) - Static method in class org.apache.calcite.test.SqlToRelTestBase
-
Checks that every node of a relational expression is valid.
- assertWithMacro(Class) - Method in class org.apache.calcite.test.JdbcTest
- assumeRealMongoInstance() - Static method in class org.apache.calcite.test.MongoAssertions
-
Used to skip tests if current instance is not mongo.
- assumeToolExists(String) - Static method in class org.apache.calcite.adapter.os.OsAdapterTest
- Author(int, String, BookstoreSchema.Place, List<BookstoreSchema.Book>) - Constructor for class org.apache.calcite.test.BookstoreSchema.Author
- authors - Variable in class org.apache.calcite.test.BookstoreSchema
- AUTO_LATTICE - Static variable in class org.apache.calcite.test.LatticeTest
- AutoSynchronizationCommand() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AutoSynchronizationCommand
- AutoTempDriver(List<Object>) - Constructor for class org.apache.calcite.test.JdbcTest.AutoTempDriver
- AUX - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that loads AUX schema for tests involving view expansions and lateral joins tests.
- AUX - org.apache.calcite.test.CalciteAssert.SchemaSpec
- AwkwardFunction() - Constructor for class org.apache.calcite.util.Smalls.AwkwardFunction
B
- b - Variable in class org.apache.calcite.linq4j.test.BlockBuilderTest
- b - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- b - Variable in class org.apache.calcite.linq4j.test.InlinerTest
- BabelCommandHandler() - Constructor for class org.apache.calcite.test.BabelQuidemTest.BabelCommandHandler
- BabelParserTest - Class in org.apache.calcite.test
-
Tests the "Babel" SQL parser, that understands all dialects of SQL.
- BabelParserTest() - Constructor for class org.apache.calcite.test.BabelParserTest
- BabelQuidemTest - Class in org.apache.calcite.test
-
Unit tests for the Babel SQL parser.
- BabelQuidemTest(String) - Constructor for class org.apache.calcite.test.BabelQuidemTest
-
Creates a BabelQuidemTest.
- BabelQuidemTest.BabelCommandHandler - Class in org.apache.calcite.test
-
Command handler that adds a "!explain-validated-on dialect..." command (see
BabelQuidemTest.ExplainValidatedCommand
). - BabelQuidemTest.ExplainValidatedCommand - Class in org.apache.calcite.test
-
Command that prints the validated parse tree of a SQL statement.
- BabelTest - Class in org.apache.calcite.test
-
Unit tests for Babel framework.
- BabelTest() - Constructor for class org.apache.calcite.test.BabelTest
- BAD_DATETIME_MESSAGE - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- badEmps - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- badEntries - Variable in class org.apache.calcite.test.ExceptionMessageTest.TestSchema
- BadType() - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest.BadType
- badTypes - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- bar(int, int, int, int, int) - Static method in class org.apache.calcite.linq4j.test.ExpressionTest
- BaseOrderStreamTable() - Constructor for class org.apache.calcite.test.StreamTest.BaseOrderStreamTable
- basePullConstantTroughAggregate() - Method in class org.apache.calcite.test.RelOptRulesTest
- basePushAggThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- basePushFilterPastAggWithGroupingSets(boolean) - Method in class org.apache.calcite.test.RelOptRulesTest
- baseRepository - Variable in class org.apache.calcite.test.DiffRepository
- baseTime - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- basic() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- bd - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- beatles(StringBuilder, Integer, int[]) - Static method in class org.apache.calcite.test.ScannableTableTest
- BEATLES - Static variable in class org.apache.calcite.test.ScannableTableTest
- BeatlesFilterableTable(StringBuilder, boolean) - Constructor for class org.apache.calcite.test.ScannableTableTest.BeatlesFilterableTable
- BeatlesProjectableFilterableTable(StringBuilder, boolean) - Constructor for class org.apache.calcite.test.ScannableTableTest.BeatlesProjectableFilterableTable
- BeatlesTable() - Constructor for class org.apache.calcite.test.ScannableTableTest.BeatlesTable
- before() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- before() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy
- before() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy.RefCountPolicy
- before() - Method in class org.apache.calcite.test.SqlToRelConverterExtendedTest
- beforeClass() - Static method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- BETTER_FACTORY - Static variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- bi - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- BinarySearchTest - Class in org.apache.calcite.runtime
-
Tests
BinarySearch
. - BinarySearchTest() - Constructor for class org.apache.calcite.runtime.BinarySearchTest
- Binding(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser.Binding
- Binding(String, String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser.Binding
- bindings - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- bindType(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- birthPlace - Variable in class org.apache.calcite.test.BookstoreSchema.Author
- bitSet - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.BadType
- bitSet - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- BitSetsTest - Class in org.apache.calcite.util
-
Unit test for
BitSets
. - BitSetsTest() - Constructor for class org.apache.calcite.util.BitSetsTest
- bl - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- BLANK - org.apache.calcite.test.CalciteAssert.SchemaSpec
- BlockBuilderBase - Class in org.apache.calcite.linq4j.test
-
Base methods and constant for simplified Expression testing
- BlockBuilderBase() - Constructor for class org.apache.calcite.linq4j.test.BlockBuilderBase
- BlockBuilderTest - Class in org.apache.calcite.linq4j.test
-
Tests BlockBuilder.
- BlockBuilderTest() - Constructor for class org.apache.calcite.linq4j.test.BlockBuilderTest
- BlockBuilderTest.Identity<I> - Class in org.apache.calcite.linq4j.test
-
Class with generics to validate if
Expressions.call(Method, Expression...)
works. - Book(String, int, List<BookstoreSchema.Page>) - Constructor for class org.apache.calcite.test.BookstoreSchema.Book
- BookMasterRegionTest - Class in org.apache.calcite.adapter.geode.simple
- BookMasterRegionTest() - Constructor for class org.apache.calcite.adapter.geode.simple.BookMasterRegionTest
- books - Variable in class org.apache.calcite.test.BookstoreSchema.Author
- BOOKSTORE - org.apache.calcite.test.CalciteAssert.SchemaSpec
- BookstoreSchema - Class in org.apache.calcite.test
-
A Schema representing a bookstore.
- BookstoreSchema() - Constructor for class org.apache.calcite.test.BookstoreSchema
- BookstoreSchema.Author - Class in org.apache.calcite.test
- BookstoreSchema.Book - Class in org.apache.calcite.test
- BookstoreSchema.Coordinate - Class in org.apache.calcite.test
- BookstoreSchema.Page - Class in org.apache.calcite.test
- BookstoreSchema.Place - Class in org.apache.calcite.test
- bool(String) - Static method in class org.apache.calcite.linq4j.test.BlockBuilderBase
- BOOL_TO_BOOL - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- BOOL_TO_BOOL_MULTI_ARG - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- BOOLEAN_TYPE_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
- BooleanLogicTest - Class in org.apache.calcite.adapter.elasticsearch
-
Test of different boolean expressions (some more complex than others).
- BooleanLogicTest() - Constructor for class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
- booleanType - Variable in class org.apache.calcite.test.catalog.Fixture
- booleanTypeNull - Variable in class org.apache.calcite.test.catalog.Fixture
- booleanValueOfTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- boolQuery() - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
- boolRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- boolRelDataType - Variable in class org.apache.calcite.test.RexTransformerTest
- bools - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- BridgeRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.BridgeRel
- BrokenColTypeImpl() - Constructor for class org.apache.calcite.test.RelMetadataTest.BrokenColTypeImpl
- buf - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.SubsetRule
- buf - Variable in class org.apache.calcite.test.CalciteAssert.ResultSetFormatter
- buf - Variable in class org.apache.calcite.test.ScannableTableTest.BeatlesFilterableTable
- buf - Variable in class org.apache.calcite.test.ScannableTableTest.BeatlesProjectableFilterableTable
- BUF_SIZE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- build() - Method in class org.apache.calcite.test.CalciteAssert.PropBuilder
- builder() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- Builder(RelDataTypeFactory) - Constructor for class org.apache.calcite.sql.test.SqlOperatorBaseTest.Builder
- buildQueries(String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
-
Converts a scalar expression into a list of SQL queries that evaluate it.
- buildQuery(String) - Static method in class org.apache.calcite.sql.test.AbstractSqlTester
- buildQuery2(String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
-
Builds a query that extracts all literals as columns in an underlying select.
- buildQueryAgg(String) - Static method in class org.apache.calcite.sql.test.AbstractSqlTester
- by - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- byteDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
C
- c - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- cache() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy
-
Returns current cache instance which was initialized for tests.
- calciteAssert() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- calciteAssert() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- calciteAssert() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- calciteAssert() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- CalciteAssert - Class in org.apache.calcite.test
-
Fluid DSL for testing Calcite connections and queries.
- CalciteAssert() - Constructor for class org.apache.calcite.test.CalciteAssert
- CalciteAssert.AddSchemaPostProcessor - Class in org.apache.calcite.test
-
Adds
Schema
and sets it as default. - CalciteAssert.AddSchemaSpecPostProcessor - Class in org.apache.calcite.test
-
Adds
CalciteAssert.SchemaSpec
(set of schemes) to a connection. - CalciteAssert.AssertMetaData - Class in org.apache.calcite.test
-
Fluent interface for building a metadata query to be tested.
- CalciteAssert.AssertQuery - Class in org.apache.calcite.test
-
Fluent interface for building a query to be tested.
- CalciteAssert.AssertThat - Class in org.apache.calcite.test
-
Result of calling
CalciteAssert.that()
. - CalciteAssert.Config - Enum in org.apache.calcite.test
-
Connection configuration.
- CalciteAssert.ConnectionFactory - Class in org.apache.calcite.test
-
Abstract implementation of connection factory whose
with
methods throw. - CalciteAssert.ConnectionPostProcessor - Interface in org.apache.calcite.test
-
Connection post processor
- CalciteAssert.DatabaseInstance - Enum in org.apache.calcite.test
-
Information necessary to create a JDBC connection.
- CalciteAssert.DefaultSchemaPostProcessor - Class in org.apache.calcite.test
-
Sets a default schema name.
- CalciteAssert.MapConnectionFactory - Class in org.apache.calcite.test
-
Connection factory that uses a given map of (name, value) pairs and optionally an initial schema.
- CalciteAssert.NopAssertQuery - Class in org.apache.calcite.test
-
Implementation of
CalciteAssert.AssertQuery
that does nothing. - CalciteAssert.PoolingConnectionFactory - Class in org.apache.calcite.test
-
Connection factory that uses the same instance of connections.
- CalciteAssert.PreparedStatementConsumer - Interface in org.apache.calcite.test
-
We want a consumer which can throw SqlException
- CalciteAssert.PropBuilder - Class in org.apache.calcite.test
-
Builds a
Properties
containing connection property settings. - CalciteAssert.ResultSetFormatter - Class in org.apache.calcite.test
-
Converts a
ResultSet
to string. - CalciteAssert.SchemaSpec - Enum in org.apache.calcite.test
-
Specification for common test schemas.
- CalciteHandler - Class in org.apache.calcite.test
-
Extension to
Handler
that can execute commands using Calcite. - CalciteHandler(PigRelBuilder, Writer) - Constructor for class org.apache.calcite.test.CalciteHandler
- CalciteRemoteDriverTest - Class in org.apache.calcite.jdbc
-
Test for Calcite's remote JDBC driver.
- CalciteRemoteDriverTest() - Constructor for class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- CalciteRemoteDriverTest.Factory - Class in org.apache.calcite.jdbc
-
Factory that creates a
Meta
that can see the test databases. - CalciteRemoteDriverTest.Factory2 - Class in org.apache.calcite.jdbc
-
Factory that creates a
LocalJsonService
. - CalciteRemoteDriverTest.LocalServiceModifiableFactory - Class in org.apache.calcite.jdbc
-
Factory that creates a Service with connection to a modifiable table.
- CalciteRemoteDriverTest.LocalServiceMoreFactory - Class in org.apache.calcite.jdbc
-
Service factory that creates a Calcite instance with more data.
- CalciteResourceTest - Class in org.apache.calcite.test
-
Tests the generated implementation of
CalciteResource
(mostly a sanity check for the resource-generation infrastructure). - CalciteResourceTest() - Constructor for class org.apache.calcite.test.CalciteResourceTest
- CalciteSqlOperatorTest - Class in org.apache.calcite.test
-
Embodiment of
SqlOperatorBaseTest
that generates SQL statements and executes them using Calcite. - CalciteSqlOperatorTest() - Constructor for class org.apache.calcite.test.CalciteSqlOperatorTest
- CalciteSuite - Class in org.apache.calcite.test
-
Calcite test suite.
- CalciteSuite() - Constructor for class org.apache.calcite.test.CalciteSuite
- call(Object, String, Object...) - Static method in class org.apache.calcite.test.CalciteAssert
-
Calls a non-static method via reflection.
- cancel(Statement) - Method in class org.apache.calcite.test.CsvTest
-
Creates a command that cancels a statement.
- canConvert(RelOptPlanner, TraitConversionTest.SimpleDistribution, TraitConversionTest.SimpleDistribution) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.ConvertRelDistributionTraitDef
- canConvert(RelOptPlanner, VolcanoPlannerTraitTest.AltTrait, VolcanoPlannerTraitTest.AltTrait) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitDef
- canConvert(RelOptPlanner, RelCollation, RelCollation) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationTraitDef
- cannotConvertToRelation(String) - Static method in class org.apache.calcite.test.SqlValidatorTest
- cannotConvertToStream(String) - Static method in class org.apache.calcite.test.SqlValidatorTest
- cannotStreamResultsForNonStreamingInputs(String) - Static method in class org.apache.calcite.test.SqlValidatorTest
- cardinality(List<Lattice.Column>) - Method in class org.apache.calcite.test.FoodMartLatticeStatisticProvider
- cardinality(Lattice.Column) - Method in class org.apache.calcite.test.FoodMartLatticeStatisticProvider
- CARDINALITY_MAP - Static variable in class org.apache.calcite.test.FoodMartLatticeStatisticProvider
- CarefulNumberNegater() - Constructor for class org.apache.calcite.util.ReflectVisitorTest.CarefulNumberNegater
- CarelessNumberNegater() - Constructor for class org.apache.calcite.util.ReflectVisitorTest.CarelessNumberNegater
- case_(Iterable<? extends RexNode>) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- case_(RexNode...) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- CASE_INSENSITIVE_LIST_COMPARATOR - Static variable in class org.apache.calcite.test.MaterializationTest
- CASE_INSENSITIVE_LIST_LIST_COMPARATOR - Static variable in class org.apache.calcite.test.MaterializationTest
- CassandraAdapterTest - Class in org.apache.calcite.test
-
Tests for the
org.apache.calcite.adapter.cassandra
package. - CassandraAdapterTest() - Constructor for class org.apache.calcite.test.CassandraAdapterTest
- cast(RelDataType, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- cast(RexNode, RelDataType) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates a call to the CAST operator, expanding if possible, and not preserving nullability.
- cat1() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- cat1Cat2() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- cat1Cat2Cat3() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- cat1Cat3() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- cat2() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- catalog - Variable in class org.apache.calcite.test.ConnectionSpec
- catalogReader - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- catalogReader - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- catalogReader - Variable in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- catalogReaderFactory - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- catalogReaderFactory - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- CATCHALL - Static variable in class org.apache.calcite.test.ReflectiveSchemaTest
- CatchallSchema() - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- ceilDay - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- ceilHour - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- ceilMinute - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- ceilMonth - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- ceilYear - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- ch - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- changeTraits(RelNode, RelTraitSet) - Method in class org.apache.calcite.test.MockRelOptPlanner
- charDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- charLiteral(String) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- check() - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- check(boolean) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- check(int) - Method in class org.apache.calcite.test.LatticeTest
- check(Boolean, RexNode, String) - Method in class org.apache.calcite.test.RexTransformerTest
- check(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- check(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- check(String, String) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- check(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- check(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- check(String, String) - Method in class org.apache.calcite.test.SqlToRelConverterTest
- check(String, SqlTester.TypeChecker, Object, double) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- check(String, SqlTester.TypeChecker, Object, double) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL query returns a single column with the given type.
- check(String, SqlTester.TypeChecker, SqlTester.ParameterChecker, SqlTester.ResultChecker) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- check(String, SqlTester.TypeChecker, SqlTester.ParameterChecker, SqlTester.ResultChecker) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.TesterImpl
- check(String, SqlTester.TypeChecker, SqlTester.ParameterChecker, SqlTester.ResultChecker) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL query returns a result of expected type and value.
- check(ResultSetMetaData, String, Class) - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- check(List<SqlFunctionCategory>, SqlFunctionCategory...) - Static method in class org.apache.calcite.prepare.LookupOperatorOverloadsTest
- check(RexBuilder, RexExecutorImpl) - Method in interface org.apache.calcite.rex.RexExecutorTest.Action
- check(RexExecutorTest.Action) - Method in class org.apache.calcite.rex.RexExecutorTest
- check(Matcher<Iterable<String>>) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- checkAddMonths(int, int, int, int, int, int, int) - Method in class org.apache.calcite.test.SqlFunctionsTest
- checkAgg(String, String[], Object, double) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkAgg(String, String[], Object, double) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that an aggregate expression returns the expected result.
- checkAgg(CalciteAssert.AssertThat, String) - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- checkAggType(SqlTester, String, String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Very similar to
tester.checkType
, but generates inside a SELECT with a non-empty GROUP BY. - checkAggWithMultipleArgs(String, String[][], Object, double) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkAggWithMultipleArgs(String, String[][], Object, double) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that an aggregate expression with multiple args returns the expected result.
- checkAllPredicates(RelOptCluster, RelOptTable, RelOptTable) - Method in class org.apache.calcite.test.RelMetadataTest
- checkAssignInConditionOptimizedOut(int, String) - Method in class org.apache.calcite.linq4j.test.InlinerTest
- checkAverageRowSize(RelOptCluster, RelOptTable, RelOptTable) - Method in class org.apache.calcite.test.RelMetadataTest
- checkBigDecimalLiteral(RexBuilder, String) - Method in class org.apache.calcite.rex.RexBuilderTest
- checkBlockBuilder(boolean, String) - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- checkBoolean(String, Boolean) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkBoolean(String, Boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a scalar SQL expression returns the expected boolean result.
- checkBushy(String, String) - Method in class org.apache.calcite.tools.PlannerTest
-
Checks that a query returns a particular plan, using a planner with MultiJoinOptimizeBushyRule enabled.
- checkCase0(String) - Method in class org.apache.calcite.util.UtilTest
- checkCase1(String) - Method in class org.apache.calcite.util.UtilTest
- checkCast(Enumerator<Integer>) - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- checkCastFails(String, String, String, boolean) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- checkCastToApproxOkay(String, String, double, double) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- checkCastToScalarOkay(String, String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- checkCastToScalarOkay(String, String, String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- checkCastToString(String, String, String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- checkCastToStringOkay(String, String, String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- checkCeil(int, int, int) - Method in class org.apache.calcite.test.SqlFunctionsTest
- checkChangedFieldList(List<String>, List<String>, boolean) - Static method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- checkCharset(String, Charset) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkCharset(String, Charset) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- checkCharset(String, Charset) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
- checkCnf(RexNode, String) - Method in class org.apache.calcite.test.RexProgramTest
- checkCollation(String, String, SqlCollation.Coercibility) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkCollation(String, String, SqlCollation.Coercibility) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- checkCollation(String, String, SqlCollation.Coercibility) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
- checkCollation(RelOptCluster, RelOptTable, RelOptTable) - Method in class org.apache.calcite.test.RelMetadataTest
- checkColumn(ArrayTable.Column, ArrayTable.RepresentationType, String) - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- checkColumnOrigin(String) - Method in class org.apache.calcite.test.RelMetadataTest
- checkColumnOrigin(RelColumnOrigin, String, String, boolean) - Static method in class org.apache.calcite.test.RelMetadataTest
- checkColumnType(String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkColumnType(String, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that a query returns one column of an expected type.
- checkColumnType(String, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Checks that a query returns a single column, and that the column has the expected type.
- checkColumnType(String, String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Checks that a query returns one column of an expected type.
- checkCompositeMap(String[], Map<String, Integer>) - Method in class org.apache.calcite.util.UtilTest
- checkConstant(Object, Function<RexBuilder, RexNode>) - Method in class org.apache.calcite.rex.RexExecutorTest
- checkConvertMutableRel(String, String) - Static method in class org.apache.calcite.test.MutableRelTest
-
Verifies that after conversion to and from a MutableRel, the new RelNode remains identical to the original RelNode.
- checkConvertMutableRel(String, String, boolean, List<RelOptRule>) - Static method in class org.apache.calcite.test.MutableRelTest
-
Verifies that after conversion to and from a MutableRel, the new RelNode remains identical to the original RelNode.
- checkCustomColumnResolving(String) - Method in class org.apache.calcite.test.SqlValidatorTest
- checkCustomSchema(String, String) - Method in class org.apache.calcite.test.JdbcTest
- checkCustomSchemaInFileInPwd(String) - Method in class org.apache.calcite.test.JdbcTest
- checkDate(RexNode) - Method in class org.apache.calcite.rex.RexBuilderTest
- checkDateRange(RexImplicationCheckerTest.Fixture, RexNode, String, Matcher<String>, Matcher<String>) - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- checkDateRange(RexImplicationCheckerTest.Fixture, RexNode, Matcher<String>) - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- checkDateRange(RexImplicationCheckerTest.Fixture, RexNode, Matcher<String>) - Method in class org.apache.calcite.test.DruidDateRangeRulesTest
- checkDateRangeNoSimplify(RexImplicationCheckerTest.Fixture, RexNode, Matcher<String>) - Method in class org.apache.calcite.test.DruidDateRangeRulesTest
- checker - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- Checker(String, String) - Constructor for class org.apache.calcite.sql.parser.SqlParserTest.Checker
- checkEvent(List<RelOptListener.RelEvent>, int, Class, RelNode, Class<? extends RelOptRule>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
- checkEx(Throwable, String, SqlParserUtil.StringAndPos) - Static method in class org.apache.calcite.test.SqlValidatorTestCase
-
Checks whether an exception matches the expected pattern.
- checkEx(Throwable, String, SqlParserUtil.StringAndPos, SqlTests.Stage) - Static method in class org.apache.calcite.sql.test.SqlTests
-
Checks whether an exception matches the expected pattern.
- checkException(String) - Static method in class org.apache.calcite.test.CalciteAssert
- checkExp(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- checkExp(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.Checker
- checkExp(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- checkExp(String, String) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- checkExp(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkExp(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- checkExpandTable(RelBuilder, Matcher<RelNode>) - Method in class org.apache.calcite.test.RelBuilderTest
- checkExpFails(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.Checker
- checkExpFails(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests that an expression throws an exception which matches the given pattern.
- checkExpFails(String, String) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- checkExpFails(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
-
Tests that an expression throws an exception which matches the given pattern.
- checkExpFails(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- checkExpFails(String, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Checks that a SQL expression gives a particular error.
- checkExponentialCnf(int) - Method in class org.apache.calcite.test.RexProgramTest
- checkExpSame(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- checkExpType(String, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- checkFails(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- checkFails(String, String) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- checkFails(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkFails(String, String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- checkFails(String, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Checks that a SQL query gives a particular error, or succeeds if
expected
is null. - checkFails(String, String, boolean) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkFails(String, String, boolean) - Method in class org.apache.calcite.sql.test.SqlRuntimeTester
- checkFails(String, String, boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a scalar SQL expression fails at run time.
- checkFeature(String, Feature) - Method in class org.apache.calcite.test.SqlValidatorFeatureTest
- checkFieldOrigin(String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkFieldOrigin(String, String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Given a SQL query, returns a list of the origins of each result field.
- checkFilterSelectivity(String, double) - Method in class org.apache.calcite.test.RelMetadataTest
- checkFlatList(int) - Method in class org.apache.calcite.util.UtilTest
- checkFloor(int, int, int) - Method in class org.apache.calcite.test.SqlFunctionsTest
- checkFoodMartAll(boolean) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- checkFoodMartAll(boolean) - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest
- checkFunctionType(int, String, List<SqlOperator>) - Method in class org.apache.calcite.prepare.LookupOperatorOverloadsTest
- checkGetTimestamp(Connection) - Method in class org.apache.calcite.test.JdbcTest
- checkGroupBySingleSortLimit(boolean) - Method in class org.apache.calcite.test.DruidAdapterIT
- checkGroupBySingleSortLimit(boolean) - Method in class org.apache.calcite.test.DruidAdapterIT2
- checkHash(double) - Method in class org.apache.calcite.util.UtilTest
- checkHeuristic(String, String) - Method in class org.apache.calcite.tools.PlannerTest
- checkImplies(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- checking(Consumer<ResultSet>) - Method in class org.apache.calcite.test.CsvTest.Fluent
-
Assigns a function to call to test whether output is correct.
- checking(Function<ResultSet, Void>) - Method in class org.apache.calcite.adapter.file.SqlTest.Fluent
-
Assigns a function to call to test whether output is correct.
- checkIntegerIntervalSet(String, int...) - Method in class org.apache.calcite.util.UtilTest
- checkIntervalConv(String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkIntervalConv(String, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Checks that the first column returned by a query has the expected type.
- checkIntervalConv(String, String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Checks if the interval value conversion to milliseconds is valid.
- checkIs(RexNode, boolean) - Method in class org.apache.calcite.test.RexProgramTest
-
Checks that
RexNode.isAlwaysTrue()
,RexNode.isAlwaysTrue()
andRexSimplify
agree that an expression reduces to true or false. - checkIterable(Enumerator<Integer>) - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- checkJdbcSchemaDirectConnection(String) - Method in class org.apache.calcite.test.JdbcTest
- checkJoinNWay(int) - Static method in class org.apache.calcite.test.JdbcTest
- checkJoinNWay(int) - Method in class org.apache.calcite.tools.PlannerTest
- checkLarge(int, Consumer<String>) - Static method in class org.apache.calcite.test.SqlValidatorTest
- checkLikeToRegex(boolean, String, String) - Method in class org.apache.calcite.test.JdbcTest
- checkListClear(int) - Method in class org.apache.calcite.util.ChunkListTest
- checkListToString(String...) - Method in class org.apache.calcite.util.UtilTest
- checkLiteral(String) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- checkLiteral2(String, String) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- checkLitmus(int, Litmus) - Method in class org.apache.calcite.util.UtilTest
- checkMapSchemaDirectConnection(String) - Method in class org.apache.calcite.test.JdbcTest
- checkMaskedResultContains(String) - Static method in class org.apache.calcite.test.CalciteAssert
- checkMaterialize(String, String) - Method in class org.apache.calcite.test.MaterializationTest
-
Checks that a given query can use a materialized view with a given definition.
- checkMaterialize(String, String, String, Consumer<ResultSet>) - Method in class org.apache.calcite.test.MaterializationTest
-
Checks that a given query can use a materialized view with a given definition.
- checkMaterialize(String, String, String, Consumer<ResultSet>, RuleSet) - Method in class org.apache.calcite.test.MaterializationTest
- checkMaterializeWithRules(String, String, RuleSet) - Method in class org.apache.calcite.test.MaterializationTest
-
Checks that a given query can use a materialized view with a given definition.
- checkMazeTableFunction(Boolean, String) - Method in class org.apache.calcite.test.ExampleFunctionTest
- checkMetadataPredicates(String, String) - Method in class org.apache.calcite.tools.PlannerTest
-
Helper method for testing
RelMetadataQuery.getPulledUpPredicates(org.apache.calcite.rel.RelNode)
metadata. - checkMonotonic(String, SqlMonotonicity) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkMonotonic(String, SqlMonotonicity) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that the first column of a SQL query has a given monotonicity.
- checkNameMap(String, NameMap<Integer>) - Method in class org.apache.calcite.util.UtilTest
- checkNameMultimap(String, NameMultimap<Integer>) - Method in class org.apache.calcite.util.UtilTest
- checkNameSet(String, NameSet) - Method in class org.apache.calcite.util.UtilTest
- checkNav(NavigableSet<String>, String) - Method in class org.apache.calcite.util.UtilTest
- checkNegWindow(String, String) - Method in class org.apache.calcite.test.SqlValidatorTest
- checkNoColumnOrigin(String) - Method in class org.apache.calcite.test.RelMetadataTest
- checkNode(String, Matcher<SqlNode>) - Method in interface org.apache.calcite.sql.parser.SqlParserTest.Tester
- checkNode(String, Matcher<SqlNode>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- checkNodeTypeCount(String, Map<Class<? extends RelNode>, Integer>) - Method in class org.apache.calcite.test.RelMetadataTest
- checkNoMaterialize(String, String, String) - Method in class org.apache.calcite.test.MaterializationTest
-
Checks that a given query CAN NOT use a materialized view with a given definition.
- checkNotImplies(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- checkNotSatisfiable(RexNode) - Method in class org.apache.calcite.test.MaterializationTest
- checkNull(String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkNull(String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL expression returns the SQL NULL value.
- checkNullableTimestamp(CalciteAssert.Config) - Method in class org.apache.calcite.test.JdbcTest
- checkNullOperand(SqlTester, String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- checkOp(CalciteAssert.AssertThat, String) - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- checkOrderBy(boolean, NullCollation) - Method in class org.apache.calcite.test.JdbcTest
- checkOrderByDescNullsFirst(CalciteAssert.Config) - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY ...
- checkOrderByDescNullsLast(CalciteAssert.Config) - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY ...
- checkOrderByNulls(CalciteAssert.Config) - Method in class org.apache.calcite.test.JdbcTest
- checkOrderByNullsFirst(CalciteAssert.Config) - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY ...
- checkOrderByNullsLast(CalciteAssert.Config) - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY ...
- checkOrdReverse(Iterable<Ord<String>>) - Method in class org.apache.calcite.util.UtilTest
- checkOverlaps(SqlOperatorBaseTest.OverlapChecker) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- checkParameters(RelDataType) - Method in interface org.apache.calcite.sql.test.SqlTester.ParameterChecker
- checkParseAndConvert(String, String, String) - Method in class org.apache.calcite.tools.PlannerTest
- checkParseEx(Throwable, String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkPercentageOriginalRows(String, double) - Method in class org.apache.calcite.test.RelMetadataTest
- checkPercentageOriginalRows(String, double, double) - Method in class org.apache.calcite.test.RelMetadataTest
- checkPeriodPredicate(SqlParserTest.Checker) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- checkPlanning(String) - Method in class org.apache.calcite.test.RelOptRulesTest
- checkPlanning(HepProgram, String) - Method in class org.apache.calcite.test.RelOptTestBase
-
Checks the plan for a SQL statement before/after executing a given program.
- checkPlanning(RelOptPlanner, String) - Method in class org.apache.calcite.test.RelOptTestBase
-
Checks the plan for a SQL statement before/after executing a given planner.
- checkPlanning(RelOptRule, String) - Method in class org.apache.calcite.test.RelOptTestBase
-
Checks the plan for a SQL statement before/after executing a given rule.
- checkPlanning(SqlToRelTestBase.Tester, HepProgram, RelOptPlanner, String) - Method in class org.apache.calcite.test.RelOptTestBase
-
Checks the plan for a SQL statement before/after executing a given rule, with a pre-program to prepare the tree.
- checkPlanning(SqlToRelTestBase.Tester, HepProgram, RelOptPlanner, String, boolean) - Method in class org.apache.calcite.test.RelOptTestBase
-
Checks the plan for a SQL statement before/after executing a given rule, with a pre-program to prepare the tree.
- checkPlanningDynamic(String) - Method in class org.apache.calcite.test.RelOptTestBase
-
Checks the plan for a SQL statement before/after executing a given rule.
- checkPlanningDynamic(RelOptRule, String) - Method in class org.apache.calcite.test.RelOptTestBase
-
Checks the plan for a SQL statement before/after executing a given rule.
- checkPlanUnchanged(RelOptPlanner, String) - Method in class org.apache.calcite.test.RelOptTestBase
-
Checks that the plan is the same before and after executing a given planner.
- checkPoset(PartiallyOrderedSet.Ordering<Integer>, boolean, Iterable<Integer>, boolean) - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- checkPosetBitsLarge(PartiallyOrderedSet<Integer>, int, int, int) - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- checkPrecendenceList(RelDataType, RelDataType, RelDataType) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryTest
- checkPrecision(int, int, int, int) - Method in class org.apache.calcite.sql.type.SqlTypeFactoryTest
- checkPredicate(int, String) - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- checkPredicates(RelOptCluster, RelOptTable, RelOptTable) - Method in class org.apache.calcite.test.RelMetadataTest
- checkPreparedOffsetFetch(int, int, Matcher<? super ResultSet>) - Method in class org.apache.calcite.test.JdbcTest
- checkPrettySeparateLines(String) - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- checkProcessExists(String) - Static method in class org.apache.calcite.adapter.os.OsAdapterTest
- checkPullFactors(RexNode, String) - Method in class org.apache.calcite.test.RexProgramTest
- checkPullFactorsUnchanged(RexNode) - Method in class org.apache.calcite.test.RexProgramTest
- checkQuery(int) - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- checkQuery(int) - Method in class org.apache.calcite.adapter.tpch.TpchTest
- checkQuery(String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkQuery(String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL query succeeds at prepare time.
- checkQueryFails(String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkQueryFails(String, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL query fails at prepare time.
- checkRandom(Random, ChunkList<Integer>, List<Integer>, int) - Method in class org.apache.calcite.util.ChunkListTest
- checkReduceNullableToNotNull(ReduceExpressionsRule) - Method in class org.apache.calcite.test.RelOptRulesTest
- checkRel(String, AtomicInteger) - Static method in class org.apache.calcite.test.CalciteAssert
- checkRelSelectivity(RelNode, double) - Method in class org.apache.calcite.test.RelMetadataTest
- checkResourceMethodNames(Object) - Method in class org.apache.calcite.util.UtilTest
- checkResult(boolean, boolean, String...) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResult(String) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResult(String, CalciteAssert.ResultSetFormatter) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResult(ResultSet) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ExceptionResultChecker
- checkResult(ResultSet) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueOrExceptionResultChecker
- checkResult(ResultSet) - Method in interface org.apache.calcite.sql.test.SqlTester.ResultChecker
- checkResult(ResultSet) - Method in class org.apache.calcite.sql.test.SqlTests.ApproximateResultChecker
- checkResult(ResultSet) - Method in class org.apache.calcite.sql.test.SqlTests.PatternResultChecker
- checkResult(ResultSet) - Method in class org.apache.calcite.sql.test.SqlTests.RefSetResultChecker
- checkResultContains(String...) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResultContains(String, int) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResultCount(Matcher<Integer>) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResults(Enumerator<Integer[]>, Integer[][]) - Method in class org.apache.calcite.linq4j.test.CorrelateJoinTest
- checkResultSetMetaData(Connection, String) - Method in class org.apache.calcite.test.JdbcTest
- checkResultType(String) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResultType(String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkResultType(String, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Checks that a query returns a row of the expected type.
- checkResultType(String, String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Checks that a query returns one column of an expected type.
- checkResultUnordered(String...) - Static method in class org.apache.calcite.test.CalciteAssert
- checkResultUnordered(String...) - Static method in class org.apache.calcite.test.MongoAssertions
-
Similar to
CalciteAssert.checkResultUnordered(java.lang.String...)
, but filters strings before comparing them. - checkResultValue(String) - Static method in class org.apache.calcite.test.CalciteAssert
- checkRewrite(SqlValidator, String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkRewrite(SqlValidator, String, String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Checks that a query gets rewritten to an expected form.
- checkRowCount(String, double, double, double) - Method in class org.apache.calcite.test.RelMetadataTest
- checkRuleApplyCount(HepMatchOrder) - Method in class org.apache.calcite.test.HepPlannerTest
- checkRun(String) - Method in class org.apache.calcite.test.QuidemTest
- checkSatisfiable(RexNode, String) - Method in class org.apache.calcite.test.MaterializationTest
- checkScalar(String, Object, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkScalar(String, Object, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a scalar SQL expression returns the expected result and the expected type.
- checkScalarApprox(String, String, double, double) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkScalarApprox(String, String, double, double) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a scalar SQL expression returns expected appoximate numeric result.
- checkScalarExact(String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkScalarExact(String, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a scalar SQL expression returns the expected exact numeric result as an integer.
- checkScalarExact(String, String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkScalarExact(String, String, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a scalar SQL expression returns the expected exact numeric result.
- checkScriptFile(String, boolean, Matcher<SqlLine.Status>, Matcher<String>) - Method in class org.apache.calcite.test.SqlLineTest
-
Attempts to execute a simple script file with the -f option to SqlLine.
- checkSelectDistinctWiki(URL, String) - Method in class org.apache.calcite.test.DruidAdapterIT
- checkSimple(SqlPrettyWriter, String, String) - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- checkSimplify(RexNode, String) - Method in class org.apache.calcite.test.RexProgramTest
-
Simplifies an expression and checks that the result is as expected.
- checkSimplify2(RexNode, String, String) - Method in class org.apache.calcite.test.RexProgramTest
-
Simplifies an expression and checks the result if unknowns remain unknown, or if unknown becomes false.
- checkSimplify3(RexNode, String, String, String) - Method in class org.apache.calcite.test.RexProgramTest
- checkSimplify3_(RexNode, String, String, String) - Method in class org.apache.calcite.test.RexProgramTest
- checkSimplifyDynamicParam() - Method in class org.apache.calcite.test.RexProgramTest
- checkSimplifyFilter(RexNode, String) - Method in class org.apache.calcite.test.RexProgramTest
- checkSimplifyFilter(RexNode, RelOptPredicateList, String) - Method in class org.apache.calcite.test.RexProgramTest
- checkSimplifyUnchanged(RexNode) - Method in class org.apache.calcite.test.RexProgramTest
-
Simplifies an expression and checks that the result is unchanged.
- checkSingleColumnOrigin(String, String, String, boolean) - Method in class org.apache.calcite.test.RelMetadataTest
- checkSql(String, String, Consumer<ResultSet>) - Method in class org.apache.calcite.test.CsvTest
- checkSql(String, String, Function<ResultSet, Void>) - Method in class org.apache.calcite.adapter.file.SqlTest
- checkSql(String, Function<ResultSet, Void>) - Method in class org.apache.calcite.test.SplunkAdapterTest
- checkSqlSetOptionSame(SqlNode) - Static method in class org.apache.calcite.sql.SqlSetOptionOperatorTest
- checkString(String, String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkString(String, String, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a scalar SQL expression returns the expected string result.
- checkSubQuery(String) - Method in class org.apache.calcite.test.RelOptRulesTest
- checkTableFunctionInModel(Class) - Method in class org.apache.calcite.test.JdbcTest
- checkTableMacroInModel(Class) - Method in class org.apache.calcite.test.JdbcTest
- checkTablesByType(String, Matcher<String>) - Method in class org.apache.calcite.test.JdbcFrontJdbcBackTest
- checkThatMaterialize(String, String, String, boolean, String, Consumer<ResultSet>, RuleSet) - Method in class org.apache.calcite.test.MaterializationTest
-
Checks that a given query can use a materialized view with a given definition.
- checkThresholdCnf(RexNode, int, String) - Method in class org.apache.calcite.test.RexProgramTest
- checkTileAlgorithm(String, String) - Method in class org.apache.calcite.test.LatticeTest
- checkTime(RexNode) - Method in class org.apache.calcite.rex.RexBuilderTest
- checkTimestamp(RexNode) - Method in class org.apache.calcite.rex.RexBuilderTest
- checkTimestampWithLocalTimeZone(RexNode) - Method in class org.apache.calcite.rex.RexBuilderTest
- checkTpchQuery(String) - Method in class org.apache.calcite.tools.PlannerTest
- checkTwoColumnOrigin(String, String, String, String, String, boolean) - Method in class org.apache.calcite.test.RelMetadataTest
- checkType(String, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkType(String, String) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Tests that a SQL expression has a given type.
- checkType(RelDataType) - Method in interface org.apache.calcite.sql.test.SqlTester.TypeChecker
- checkType(RelDataType) - Method in class org.apache.calcite.sql.test.SqlTests.SqlTypeChecker
- checkType(RelDataType) - Method in class org.apache.calcite.sql.test.SqlTests.StringTypeChecker
- checkTypeSystem(int, FrameworkConfig) - Method in class org.apache.calcite.tools.FrameworksTest
- checkUnchanged() - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- checkUnknownAs(RexNode) - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- checkUnknownAs(RexNode, RexUnknownAs) - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- checkUpdateCount(int) - Static method in class org.apache.calcite.test.CalciteAssert
- checkValidationException(String) - Static method in class org.apache.calcite.test.CalciteAssert
- checkView(String, Matcher<String>) - Method in class org.apache.calcite.tools.PlannerTest
- checkWholeExpFails(String, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Checks that a SQL expression gives a particular error, and that the location of the error is the whole expression.
- checkWinAgg(String, String[], String, String, Object, double) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- checkWinAgg(String, String[], String, String, Object, double) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Checks that a windowed aggregate expression returns the expected result.
- checkWinFuncExpWithWinClause(String, String) - Method in class org.apache.calcite.test.SqlValidatorTest
- ChunkListTest - Class in org.apache.calcite.util
-
Unit and performance test for
ChunkList
. - ChunkListTest() - Constructor for class org.apache.calcite.util.ChunkListTest
- CITIES_SOURCE - Static variable in class org.apache.calcite.adapter.file.FileReaderTest
- city - Variable in class org.apache.calcite.test.BookstoreSchema.Place
- CLEANUP - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- CLEANUP_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- CLEANUP_THREAD_ID - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- cleanupCommands - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- clear() - Method in class org.apache.calcite.test.MockRelOptPlanner
- clearStatement() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Clears the thread's current JDBC statement.
- client - Variable in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- client - Variable in class org.apache.calcite.adapter.mongodb.MongoDatabasePolicy
- client() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
-
Exposes elastic transport client (use of HTTP client is preferred).
- CLONE_FOODMART - org.apache.calcite.test.CalciteAssert.SchemaSpec
- close() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
- close() - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- close() - Method in class org.apache.calcite.test.CsvTest.Worker
- close() - Method in class org.apache.calcite.test.JdbcAdapterTest.LockWrapper
- close(Connection, Statement) - Method in class org.apache.calcite.adapter.file.SqlTest
- close(Connection, Statement) - Method in class org.apache.calcite.test.CsvTest
- close(Connection, Statement) - Method in class org.apache.calcite.test.SplunkAdapterTest
- CLOSE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- closeable - Variable in class org.apache.calcite.test.SqlToRelConverterExtendedTest
- CloseCommand() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.CloseCommand
- closer - Variable in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- CluelessNumberNegater() - Constructor for class org.apache.calcite.util.ReflectVisitorTest.CluelessNumberNegater
- clusterFactory - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- coalesce(RexNode...) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- CODE_2201F - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- collation(int...) - Static method in class org.apache.calcite.rel.RelCollationTest
- COLLATION - Static variable in class org.apache.calcite.plan.RelTraitTest
- COLLATION - Static variable in class org.apache.calcite.plan.volcano.TraitPropagationTest
- COLLATION_TRAIT_DEF - Static variable in class org.apache.calcite.plan.volcano.CollationConversionTest
- CollationConversionTest - Class in org.apache.calcite.plan.volcano
-
Unit test for
RelCollationTraitDef
. - CollationConversionTest() - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest
- CollationConversionTest.LeafRel - Class in org.apache.calcite.plan.volcano
-
Leaf node with physical convention and LEAF_COLLATION trait.
- CollationConversionTest.LeafTraitRule - Class in org.apache.calcite.plan.volcano
-
Converts a
CollationConversionTest.NoneLeafRel
(with none convention) toCollationConversionTest.LeafRel
(with physical convention). - CollationConversionTest.NoneLeafRel - Class in org.apache.calcite.plan.volcano
-
Leaf node with none convention and LEAF_COLLATION trait.
- CollationConversionTest.NoneSingleRel - Class in org.apache.calcite.plan.volcano
-
A single-input node with none convention and LEAF_COLLATION trait.
- CollationConversionTest.PhysicalSort - Class in org.apache.calcite.plan.volcano
-
Physical sort node (not logical).
- CollationConversionTest.RootSingleRel - Class in org.apache.calcite.plan.volcano
-
Root node with physical convention and ROOT_COLLATION trait.
- CollationConversionTest.SingleNodeRule - Class in org.apache.calcite.plan.volcano
-
Converts a NoneSingleRel to RootSingleRel.
- CollationConversionTest.TestRelCollationImpl - Class in org.apache.calcite.plan.volcano
-
Dummy collation trait implementation for the test.
- CollationConversionTest.TestRelCollationTraitDef - Class in org.apache.calcite.plan.volcano
-
Dummy collation trait def implementation for the test (uses
CollationConversionTest.PhysicalSort
below). - collationList - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- collationList - Variable in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- collect(List<String>, ResultSet) - Static method in class org.apache.calcite.adapter.file.SqlTest
- collect(List<String>, ResultSet) - Static method in class org.apache.calcite.test.CsvTest
- CollectionTypeTest - Class in org.apache.calcite.test
- CollectionTypeTest() - Constructor for class org.apache.calcite.test.CollectionTypeTest
- CollectionTypeTest.NestedCollectionTable - Class in org.apache.calcite.test
-
Table that returns columns which include complicated collection type via the ScannableTable interface.
- CollectionTypeTest.NestedCollectionWithAnyTypeTable - Class in org.apache.calcite.test
-
Table that returns columns which include complicated collection type via the ScannableTable interface.
- collectResults() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Builds a map of thread ids to result data for the thread.
- colType(RelMetadataQuery, RelNode, int) - Method in class org.apache.calcite.test.RelMetadataTest
- colType(RelNode, int) - Method in class org.apache.calcite.test.RelMetadataTest.MyRelMetadataQuery
- colTypeHandler - Variable in class org.apache.calcite.test.RelMetadataTest.MyRelMetadataQuery
- ColTypeImpl() - Constructor for class org.apache.calcite.test.RelMetadataTest.ColTypeImpl
- columnList - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- columnName - Variable in class org.apache.calcite.adapter.generate.RangeTable
- columnNames - Variable in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- columns - Variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- columns - Variable in class org.apache.calcite.test.FoodMartQuerySet.FoodmartQuery
- columnType(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- columnTypes - Variable in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- com.example - package com.example
-
Examples of using linq4j.
- ComboRule() - Constructor for class org.apache.calcite.plan.volcano.ComboRuleTest.ComboRule
- ComboRuleTest - Class in org.apache.calcite.plan.volcano
-
Unit test for
VolcanoPlanner
- ComboRuleTest() - Constructor for class org.apache.calcite.plan.volcano.ComboRuleTest
- ComboRuleTest.AddIntermediateNodeRule - Class in org.apache.calcite.plan.volcano
-
Rule that adds an intermediate node above the
PlannerTests.PhysLeafRel
. - ComboRuleTest.ComboRule - Class in org.apache.calcite.plan.volcano
-
Matches
PlannerTests.PhysSingleRel
-ComboRuleTest.IntermediateNode
-Any and converts toComboRuleTest.IntermediateNode
-PlannerTests.PhysSingleRel
-Any. - ComboRuleTest.IntermediateNode - Class in org.apache.calcite.plan.volcano
-
Intermediate node, the cost decreases as it is pushed up the tree (more inputs it has, cheaper it gets).
- COMMA - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- command - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ShellCommand
- commandIndex - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator.TimedIterator
- CommandParser() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- commands - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Command sequence for this thread.
- commands - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator.TimedIterator
- CommandWithTimeout(int) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.CommandWithTimeout
- CommandWithTimeout(long) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandWithTimeout
- CommandWithTimeoutAndRowLimit(long) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandWithTimeoutAndRowLimit
- CommandWithTimeoutAndRowLimit(long, int) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandWithTimeoutAndRowLimit
- commission - Variable in class org.apache.calcite.test.JdbcTest.Employee
- CommitCommand() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.CommitCommand
- COMPARABLE_TO_BOOL - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- comparator - Variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- compareResultSet(ResultSet, Set<String>) - Static method in class org.apache.calcite.sql.test.SqlTests
-
Compares the first column of a result set against a String-valued reference set, disregarding order entirely.
- compareResultSetWithDelta(ResultSet, double, double) - Static method in class org.apache.calcite.sql.test.SqlTests
-
Compares the first column of a result set against a numeric result, within a given tolerance.
- compareResultSetWithPattern(ResultSet, Pattern) - Static method in class org.apache.calcite.sql.test.SqlTests
-
Compares the first column of a result set against a pattern.
- compareTo(SimplifyTask) - Method in class org.apache.calcite.test.fuzzer.SimplifyTask
- compiledDiffMatcher - Variable in class org.apache.calcite.test.DiffTestCase
- compiledIgnoreMatcher - Variable in class org.apache.calcite.test.DiffTestCase
- COMPLEX_UNION_TREE - Static variable in class org.apache.calcite.test.HepPlannerTest
- componentName - Variable in enum org.apache.calcite.sql.test.SqlTests.Stage
- compose(Matcher<T>, Function<F, T>) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher by applying a function to a value before calling another matcher.
- ComposingMatcher(Matcher<T>, Function<F, T>) - Constructor for class org.apache.calcite.test.Matchers.ComposingMatcher
- compositeEmpty() - Method in class org.apache.calcite.plan.RelTraitTest
- compositeOne() - Method in class org.apache.calcite.plan.RelTraitTest
- compositeTwo() - Method in class org.apache.calcite.plan.RelTraitTest
- CompoundNameColumn - Class in org.apache.calcite.test.catalog
-
Column having names with multiple parts.
- CompoundNameColumn(String, String, RelDataType) - Constructor for class org.apache.calcite.test.catalog.CompoundNameColumn
- CompoundNameColumnResolver - Class in org.apache.calcite.test.catalog
-
ColumnResolver implementation that resolves CompoundNameColumn by simulating Phoenix behaviors.
- CompoundNameColumnResolver(List<CompoundNameColumn>, String) - Constructor for class org.apache.calcite.test.catalog.CompoundNameColumnResolver
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.LeafRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.PhysicalSort
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.RootSingleRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.ComboRuleTest.IntermediateNode
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.PlannerTests.PhysLeafRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.PlannerTests.PhysSingleRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.PlannerTests.TestLeafRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.PlannerTests.TestSingleRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.BridgeRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.RandomSingleRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.SingletonLeafRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysAgg
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysProj
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysSort
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysTable
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterMergedRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysLeafRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestLeafRel
- computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestSingleRel
- ConcurrentTestCommand - Interface in org.apache.calcite.test.concurrent
-
ConcurrentTestCommand represents a command, sequentially executed by
ConcurrentTestCommandExecutor
, during a concurrency test - ConcurrentTestCommand.ShouldHaveFailedException - Exception in org.apache.calcite.test.concurrent
-
Indicates that a command should have failed, but instead succeeded, which is a test error
- ConcurrentTestCommandExecutor - Class in org.apache.calcite.test.concurrent
-
ConcurrentTestCommandExecutor is a thread that executes a sequence of
commands
on a JDBC connection. - ConcurrentTestCommandExecutor(int, String, String, Properties, Iterable<ConcurrentTestCommand>, ConcurrentTestCommandExecutor.Sync, PrintStream) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Constructs a ConcurrentTestCommandExecutor with the given thread ID, JDBC URL, commands and synchronization object.
- ConcurrentTestCommandExecutor.Sync - Class in org.apache.calcite.test.concurrent
-
Synchronization object that allows multiple ConcurrentTestCommandExecutors to execute commands in lock-step.
- ConcurrentTestCommandGenerator - Class in org.apache.calcite.test.concurrent
-
ConcurrentTestCommandGenerator creates instances of
ConcurrentTestCommand
that perform specific actions in a specific order and within the context of a test thread (ConcurrentTestCommandExecutor
). - ConcurrentTestCommandGenerator() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Constructs a new ConcurrentTestCommandGenerator.
- ConcurrentTestCommandGenerator.AbstractCommand - Class in org.apache.calcite.test.concurrent
-
abstract base to handle SQLExceptions
- ConcurrentTestCommandGenerator.AutoSynchronizationCommand - Class in org.apache.calcite.test.concurrent
-
AutoSynchronizationCommand is idential to SynchronizationCommand, except that it is generated automatically by the test harness and is not counted when displaying the step number in which an error occurred.
- ConcurrentTestCommandGenerator.CloseCommand - Class in org.apache.calcite.test.concurrent
-
CloseCommand closes a previously prepared statement.
- ConcurrentTestCommandGenerator.CommandWithTimeout - Class in org.apache.calcite.test.concurrent
-
Command that executes statements with a given timeout.
- ConcurrentTestCommandGenerator.CommitCommand - Class in org.apache.calcite.test.concurrent
-
CommitCommand commits pending transactions via
Connection.commit()
. - ConcurrentTestCommandGenerator.DdlCommand - Class in org.apache.calcite.test.concurrent
-
DdlCommand executes DDL commands.
- ConcurrentTestCommandGenerator.ExplainCommand - Class in org.apache.calcite.test.concurrent
-
ExplainCommand executes explain plan commands.
- ConcurrentTestCommandGenerator.FailedThread - Class in org.apache.calcite.test.concurrent
-
Describes a thread that failed
- ConcurrentTestCommandGenerator.FetchAndCompareCommand - Class in org.apache.calcite.test.concurrent
-
FetchAndCompareCommand executes a previously prepared statement stored in the ConcurrentTestCommandExecutor and then validates the returned rows against expected data.
- ConcurrentTestCommandGenerator.InsertCommand - Class in org.apache.calcite.test.concurrent
-
InsertCommand exeutes an insert, update or delete SQL statement.
- ConcurrentTestCommandGenerator.PrepareCommand - Class in org.apache.calcite.test.concurrent
-
PrepareCommand creates a
PreparedStatement
. - ConcurrentTestCommandGenerator.RollbackCommand - Class in org.apache.calcite.test.concurrent
-
RollbackCommand rolls back pending transactions via
Connection.rollback()
. - ConcurrentTestCommandGenerator.SleepCommand - Class in org.apache.calcite.test.concurrent
-
SleepCommand causes the execution thread to wait for all other threads in the test before continuing.
- ConcurrentTestCommandGenerator.SynchronizationCommand - Class in org.apache.calcite.test.concurrent
-
SynchronizationCommand causes the execution thread to wait for all other threads in the test before continuing.
- ConcurrentTestCommandScript - Class in org.apache.calcite.test.concurrent
-
ConcurrentTestCommandScript creates instances of
ConcurrentTestCommand
that perform specific actions in a specific order and within the context of a test thread (ConcurrentTestCommandExecutor
). - ConcurrentTestCommandScript() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- ConcurrentTestCommandScript(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Constructs and prepares a new ConcurrentTestCommandScript.
- ConcurrentTestCommandScript.CommandParser - Class in org.apache.calcite.test.concurrent
-
Command parser.
- ConcurrentTestCommandScript.CommandParser.Binding - Class in org.apache.calcite.test.concurrent
-
Binding of a value to a variable.
- ConcurrentTestCommandScript.CommandWithTimeout - Class in org.apache.calcite.test.concurrent
-
Command that has a timeout.
- ConcurrentTestCommandScript.CommandWithTimeoutAndRowLimit - Class in org.apache.calcite.test.concurrent
-
Command with timeout and row limit.
- ConcurrentTestCommandScript.EchoCommand - Class in org.apache.calcite.test.concurrent
-
Echo command.
- ConcurrentTestCommandScript.FetchAndPrintCommand - Class in org.apache.calcite.test.concurrent
-
FetchAndPrintCommand executes a previously prepared statement stored inthe ConcurrentTestCommandExecutor and then outputs the returned rows.
- ConcurrentTestCommandScript.PluginCommand - Class in org.apache.calcite.test.concurrent
-
Plugin command.
- ConcurrentTestCommandScript.PrepareCommand - Class in org.apache.calcite.test.concurrent
-
PrepareCommand creates a
PreparedStatement
, which is saved as the current statement of its test thread. - ConcurrentTestCommandScript.PrintCommand - Class in org.apache.calcite.test.concurrent
-
Print command.
- ConcurrentTestCommandScript.ResultsReader - Class in org.apache.calcite.test.concurrent
-
Result reader.
- ConcurrentTestCommandScript.SelectCommand - Class in org.apache.calcite.test.concurrent
-
SelectCommand creates and executes a SQL select statement, with optional timeout and row limit.
- ConcurrentTestCommandScript.ShellCommand - Class in org.apache.calcite.test.concurrent
-
Shell command.
- ConcurrentTestCommandScript.SqlCommand - Class in org.apache.calcite.test.concurrent
-
SelectCommand creates and executes a SQL select statement, with optional timeout.
- ConcurrentTestCommandScript.StateAction - Class in org.apache.calcite.test.concurrent
-
State action.
- ConcurrentTestCommandScript.StateDatum - Class in org.apache.calcite.test.concurrent
-
State datum.
- ConcurrentTestCommandScript.Tool - Class in org.apache.calcite.test.concurrent
-
Standalone client test tool.
- ConcurrentTestCommandScript.VariableTable - Class in org.apache.calcite.test.concurrent
-
Symbol table of script variables.
- ConcurrentTestCommandScript.VariableTable.Excn - Exception in org.apache.calcite.test.concurrent
-
Exception.
- ConcurrentTestPlugin - Class in org.apache.calcite.test.concurrent
-
Used to extend functionality of mtsql.
- ConcurrentTestPlugin() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestPlugin
- ConcurrentTestPluginCommand - Interface in org.apache.calcite.test.concurrent
-
Used to extend functionality of mtsql.
- ConcurrentTestPluginCommand.TestContext - Interface in org.apache.calcite.test.concurrent
-
Test context.
- ConcurrentTestTimedCommandGenerator - Class in org.apache.calcite.test.concurrent
-
ConcurrentTestTimedCommandGenerator extends
ConcurrentTestCommandGenerator
and repeats the configured command sequence until a certain amount of time has elapsed. - ConcurrentTestTimedCommandGenerator(int) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator
-
Constructs a new ConcurrentTestTimedCommandGenerator that will run for at least the given amount of time.
- ConcurrentTestTimedCommandGenerator.TimedIterator<E> - Class in org.apache.calcite.test.concurrent
-
TimedIterator is an Iterator that repeats a given collection's elements until
System.currentTimeMillis() ≥ endTimeMillis
. - config - Variable in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- config - Variable in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- config - Variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- config - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- config - Variable in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- config - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- config() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- config() - Static method in class org.apache.calcite.plan.RelOptUtilTest
-
Creates a config based on the "scott" schema.
- config() - Static method in class org.apache.calcite.test.PigRelBuilderTest
-
Creates a config based on the "scott" schema.
- config() - Static method in class org.apache.calcite.test.RelBuilderTest
-
Creates a config based on the "scott" schema.
- config(SqlToRelConverter.Config) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- config(CalciteAssert.Config) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- config(CalciteAssert.SchemaSpec) - Static method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- Config() - Constructor for enum org.apache.calcite.test.CalciteAssert.Config
- configureTester - Variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- conformance - Variable in class org.apache.calcite.sql.parser.SqlParserTest
- conformance - Variable in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- conformance - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- conformance(SqlConformance) - Method in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- conn - Variable in class org.apache.calcite.test.ExceptionMessageTest
- connect() - Static method in class org.apache.calcite.test.BabelTest
- connect() - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Use sparingly.
- connect() - Static method in class org.apache.calcite.test.ServerTest
- connect(String) - Method in class org.apache.calcite.test.QuidemTest.QuidemConnectionFactory
- connect(String, boolean) - Method in class org.apache.calcite.test.QuidemTest.QuidemConnectionFactory
- connection - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
JDBC connection for commands.
- connectionFactory - Variable in class org.apache.calcite.test.CalciteAssert.AssertMetaData
- connectionFactory - Variable in class org.apache.calcite.test.CalciteAssert.AssertQuery
- connectionFactory - Variable in class org.apache.calcite.test.CalciteAssert.AssertThat
- ConnectionFactory() - Constructor for class org.apache.calcite.test.CalciteAssert.ConnectionFactory
- ConnectionSpec - Class in org.apache.calcite.test
-
Information necessary to create a JDBC connection.
- ConnectionSpec(String, String, String, String, String) - Constructor for class org.apache.calcite.test.ConnectionSpec
- connectThrows(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Asserts that there is an exception with the given message while creating a connection.
- connectThrows(Consumer<Throwable>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Asserts that there is an exception that matches the given predicate while creating a connection.
- consistentResult(boolean) - Static method in class org.apache.calcite.test.CalciteAssert
-
Checks that the result of the second and subsequent executions is the same as the first.
- constraint - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable
- consumer - Variable in class org.apache.calcite.test.CalciteAssert.AssertQuery
- consumesPreparedStatement(CalciteAssert.PreparedStatementConsumer) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- CONTAINS_LOCATIONS - Static variable in class org.apache.calcite.test.MaterializationTest
- CONTAINS_M0 - Static variable in class org.apache.calcite.test.MaterializationTest
- containsStringLinux(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches when the examined string is equal to the specified
operand
when all Windows-style line endings ("\r\n") have been converted to Unix-style line endings ("\n"). - content - Variable in class org.apache.calcite.test.BabelQuidemTest.ExplainValidatedCommand
- content - Variable in class org.apache.calcite.util.Smalls.MazeTable
- contentType - Variable in class org.apache.calcite.test.BookstoreSchema.Page
- context - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- contextMatches(SqlFunctions.PathContext) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- conversionMap - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitDef
- convert(Object, Class) - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- convert(RelOptPlanner, RelNode, TraitConversionTest.SimpleDistribution, boolean) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.ConvertRelDistributionTraitDef
- convert(RelOptPlanner, RelNode, VolcanoPlannerTraitTest.AltTrait, boolean) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitDef
- convert(RelOptPlanner, RelNode, RelCollation, boolean) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationTraitDef
- convert(RelNode) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysSortRule
- convert(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitConverterRule
- convert(RelNode) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysToIteratorConverterRule
- convert(RelNode) - Method in class org.apache.calcite.tools.PlannerTest.MockJdbcProjectRule
- convert(RelNode) - Method in class org.apache.calcite.tools.PlannerTest.MockJdbcTableRule
- convertCompletionHints(List<SqlMoniker>) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- convertContains(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Checks that when the query (which was set using
CalciteAssert.AssertThat.query(String)
) is converted to a relational algebra expression matching the given string. - convertMatches(Function<RelNode, Void>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- convertMatches(Function<RelNode, Void>) - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- ConvertRelDistributionTraitDef() - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.ConvertRelDistributionTraitDef
- convertSql(String) - Method in class org.apache.calcite.test.RelMetadataTest
- convertSqlToRel(String) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Converts a SQL string to a
RelNode
tree. - convertSqlToRel(String) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- convertsTo(String) - Method in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- cooperative - Variable in class org.apache.calcite.test.ScannableTableTest.BeatlesFilterableTable
- cooperative - Variable in class org.apache.calcite.test.ScannableTableTest.BeatlesProjectableFilterableTable
- Coordinate(BigDecimal, BigDecimal) - Constructor for class org.apache.calcite.test.BookstoreSchema.Coordinate
- coords - Variable in class org.apache.calcite.test.BookstoreSchema.Place
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.LeafRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.NoneLeafRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.NoneSingleRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.RootSingleRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.ComboRuleTest.IntermediateNode
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.PlannerTests.NoneLeafRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.PlannerTests.NoneSingleRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.PlannerTests.PhysLeafRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.PlannerTests.PhysSingleRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.BridgeRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.NoneLeafRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.NoneSingleRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.RandomSingleRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.SingletonLeafRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.PhysToIteratorConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterMergedRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.NoneLeafRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.NoneSingleRel
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysToIteratorConverter
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.calcite.tools.PlannerTest.MockJdbcTableScan
- copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysAgg
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysProj
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.PhysicalSort
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysSort
- CoreQuidemTest - Class in org.apache.calcite.test
-
Test that runs every Quidem file in the "core" module as a test.
- CoreQuidemTest(String) - Constructor for class org.apache.calcite.test.CoreQuidemTest
- CorrelateJoinTest - Class in org.apache.calcite.linq4j.test
-
Tests
ExtendedEnumerable.correlateJoin(org.apache.calcite.linq4j.CorrelateJoinType, org.apache.calcite.linq4j.function.Function1<TSource, org.apache.calcite.linq4j.Enumerable<TInner>>, org.apache.calcite.linq4j.function.Function2<TSource, TInner, TResult>)
- CorrelateJoinTest() - Constructor for class org.apache.calcite.linq4j.test.CorrelateJoinTest
- correlationIds() - Method in class org.apache.calcite.test.SqlToRelConverterTest.RelValidityChecker
- count - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrintCommand
- count(ResultSet) - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- count(Enumerator<String>) - Static method in class org.apache.calcite.linq4j.test.Linq4jTest
- CountArgs0Function() - Constructor for class org.apache.calcite.util.Smalls.CountArgs0Function
- CountArgs1Function() - Constructor for class org.apache.calcite.util.Smalls.CountArgs1Function
- CountArgs1NullableFunction() - Constructor for class org.apache.calcite.util.Smalls.CountArgs1NullableFunction
- CountArgs2Function() - Constructor for class org.apache.calcite.util.Smalls.CountArgs2Function
- counted - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- counter - Variable in class org.apache.calcite.test.JdbcTest.MockDdlDriver
- CountingFactory - Class in org.apache.calcite.test.catalog
-
To check whether
InitializerExpressionFactory.newColumnDefaultValue(org.apache.calcite.plan.RelOptTable, int, org.apache.calcite.sql2rel.InitializerContext)
is called. - CountingFactory(List<String>) - Constructor for class org.apache.calcite.test.catalog.CountingFactory
- CountriesTableFunction - Class in org.apache.calcite.test
-
A table function that returns all countries in the world.
- CountriesTableFunction() - Constructor for class org.apache.calcite.test.CountriesTableFunction
- countRows(ResultSet) - Static method in class org.apache.calcite.test.CalciteAssert
- country - Variable in class org.apache.calcite.test.BookstoreSchema.Place
- countStar() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- create() - Static method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
-
Creates elastic node as single member of a cluster.
- create() - Static method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
-
Factory method to create this rule.
- create() - Static method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy
- create() - Static method in class org.apache.calcite.adapter.mongodb.MongoDatabasePolicy
-
Creates an instance based on current maven profile (as defined by
-Pit
). - create(Class<?>, String, int, int) - Static method in class org.apache.calcite.adapter.generate.RangeTable
-
Creates a RangeTable.
- create(List<String>) - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest.Factory
- create(AvaticaConnection) - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest.Factory2
- create(AvaticaConnection) - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest.LocalServiceModifiableFactory
- create(AvaticaConnection) - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest.LocalServiceMoreFactory
- create(RelNode, List<RexNode>, RelDataType) - Static method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysProj
- create(RelDataTypeFactory, boolean) - Method in interface org.apache.calcite.sql.test.SqlTestFactory.MockCatalogReaderFactory
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
Returns always the same schema to avoid initialization costs.
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.calcite.test.JdbcTest.MySchemaFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.adapter.generate.RangeTable.Factory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.test.JdbcTest.EmpDeptTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.test.StreamTest.InfiniteOrdersStreamTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.test.StreamTest.OrdersStreamTableFactory
- create(SchemaPlus, String, Map<String, Object>, RelDataType) - Method in class org.apache.calcite.test.StreamTest.ProductsTableFactory
- create(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory, SqlConformance) - Method in interface org.apache.calcite.sql.test.SqlTestFactory.ValidatorFactory
- create(MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable, MockCatalogReader, String, String, String, boolean, double, MockCatalogReader.ColumnResolver) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- create(MockCatalogReader, List<String>, boolean, double) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double, MockCatalogReader.ColumnResolver) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(MockCatalogReader, MockCatalogReader.MockSchema, String, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- create(Settings) - Static method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
-
Creates an instance with existing settings
- createAdvisor() - Method in class org.apache.calcite.sql.test.SqlTestFactory
- createCatalogReader(RelDataTypeFactory) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Factory method for a
Prepare.CatalogReader
. - createCatalogReader(RelDataTypeFactory) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- createChecker(Object, double) - Static method in class org.apache.calcite.sql.test.SqlTests
- createColumnSet(SqlValidatorTable, List<String>, RelDataType, List<RelCollation>) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- createCommandHandler() - Method in class org.apache.calcite.test.BabelQuidemTest
- createCommandHandler() - Method in class org.apache.calcite.test.QuidemTest
-
Creates a command handler.
- createConnection() - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- createConnection() - Method in class org.apache.calcite.test.CalciteAssert.ConnectionFactory
- createConnection() - Method in class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- createConnection() - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- createConnection() - Method in class org.apache.calcite.test.CalciteAssert.PoolingConnectionFactory
- createConnectionFactory() - Method in class org.apache.calcite.chinook.EndToEndTest
- createConnectionFactory() - Method in class org.apache.calcite.test.BabelQuidemTest
- createConnectionFactory() - Method in class org.apache.calcite.test.QuidemTest
-
Creates a connection factory.
- createConnectionFactory() - Method in class org.apache.calcite.test.ServerQuidemTest
- createDag() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
- createDynamicTester() - Method in class org.apache.calcite.test.RelOptTestBase
- createEdge(String, String) - Method in class org.apache.calcite.util.graph.DirectedGraphTest.DefaultAttributedEdgeFactory
- createEdge(String, String, Object...) - Method in class org.apache.calcite.util.graph.DirectedGraphTest.DefaultAttributedEdgeFactory
- createFieldTrimmer(RelBuilder) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
-
Creates a RelFieldTrimmer.
- createHandler() - Method in class org.apache.calcite.test.JdbcTest.AutoTempDriver
- createHandler() - Method in class org.apache.calcite.test.JdbcTest.HandlerDriver
- createIndex(String, Map<String, String>) - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
-
Creates index in elastic search given a mapping.
- createMapList() - Static method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- createOperand() - Static method in class org.apache.calcite.plan.volcano.ComboRuleTest.ComboRule
- createOperatorTable() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
-
Creates an operator table.
- createOperatorTable(SqlOperatorTable) - Static method in class org.apache.calcite.sql.test.SqlTestFactory
- createParser(String) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- createParserConfig(ImmutableMap<String, Object>) - Static method in class org.apache.calcite.sql.test.SqlTestFactory
- createPlanner() - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
- createPlanner() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- createPrepareFactory() - Method in class org.apache.calcite.test.JdbcTest.MockDdlDriver
- createProg(int) - Method in class org.apache.calcite.test.RexProgramTest
-
Creates a program, depending on variant:
select (x + y) + (x + 1) as a, (x + x) as b from t(x, y)
select (x + y) + (x + 1) as a, (x + (x + 1)) as b from t(x, y)
select (x + y) + (x + 1) as a, (x + x) as b from t(x, y) where ((x + y) > 1) and ((x + y) > 1)
select (x + y) + (x + 1) as a, (x + x) as b from t(x, y) where not case when x + 1 > 5 then true when y is null then null else false end
- createRelBuilder(SchemaPlus) - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- createSqlToRelConverter(SqlValidator, Prepare.CatalogReader, RelDataTypeFactory, SqlToRelConverter.Config) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- createStructType(RelDataType, RelDataTypeFactory, List<Map.Entry<String, Integer>>) - Static method in class org.apache.calcite.test.catalog.CompoundNameColumnResolver
- createTester() - Method in class org.apache.calcite.test.RelOptTestBase
- createTester() - Method in class org.apache.calcite.test.SqlToRelTestBase
- createTester(SqlConformance) - Method in class org.apache.calcite.test.SqlToRelTestBase
- createTestSchema() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- createTypeFactory() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- createTypeFactory(SqlConformance) - Static method in class org.apache.calcite.sql.test.SqlTestFactory
- createValidator(SqlValidatorCatalogReader, RelDataTypeFactory) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Factory method to create a
SqlValidator
. - createValidator(SqlValidatorCatalogReader, RelDataTypeFactory) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- CsvTest - Class in org.apache.calcite.test
-
Unit test of the Calcite adapter for CSV.
- CsvTest() - Constructor for class org.apache.calcite.test.CsvTest
- CsvTest.Fluent - Class in org.apache.calcite.test
-
Fluent API to perform test actions.
- CsvTest.Worker<E> - Class in org.apache.calcite.test
-
Receives commands on a queue and executes them on its own thread.
- cube(ImmutableBitSet...) - Method in class org.apache.calcite.test.SqlValidatorTest
- CURRENT_TZ - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- currentDirectory - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- currentSeed - Variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- currentTimeString(TimeZone) - Static method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Returns a time string, in GMT, that will be valid for at least 2 minutes.
- cust_id - Variable in class org.apache.calcite.examples.foodmart.java.JdbcExample.SalesFact
- cust_id - Variable in class org.apache.calcite.test.JdbcTest.SalesFact
- customer - Variable in class org.apache.calcite.test.JdbcTest.FoodmartJdbcSchema
- Customer(int) - Constructor for class org.apache.calcite.test.JdbcTest.Customer
- customer_id - Variable in class org.apache.calcite.test.JdbcTest.Customer
- customErrorHandler(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Custom error handling occurs here if
ConcurrentTestCommandGenerator.requiresCustomErrorHandling()
returns true. - customErrorHandler(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
D
- d - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- d - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- d2ts(int, int) - Method in class org.apache.calcite.test.SqlFunctionsTest
-
Converts a date (days since epoch) and milliseconds (since midnight) into a timestamp (milliseconds since epoch).
- DASHES - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- data() - Static method in class org.apache.calcite.chinook.EndToEndTest
-
For
Parameterized
runner. - data() - Static method in class org.apache.calcite.test.BabelQuidemTest
-
For
Parameterized
runner. - data() - Static method in class org.apache.calcite.test.CoreQuidemTest
-
For
Parameterized
runner. - data() - Static method in class org.apache.calcite.test.ServerQuidemTest
-
For
Parameterized
runner. - data(String) - Static method in class org.apache.calcite.test.QuidemTest
- database - Variable in class org.apache.calcite.adapter.mongodb.MongoDatabasePolicy
- database() - Method in class org.apache.calcite.adapter.mongodb.MongoDatabasePolicy
- DatabaseInstance(ConnectionSpec, ConnectionSpec) - Constructor for enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- dataContext - Variable in class org.apache.calcite.test.InterpreterTest
- dataSource - Variable in class org.apache.calcite.test.CalciteAssert.PoolingConnectionFactory
- DATE_PATTERN - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Regular expression for a SQL DATE value.
- dateCat() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
-
Group by date data type.
- DateColumnSchema() - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest.DateColumnSchema
- dateDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- dateFun(Date) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- dateLiteral(DateString) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- DateRangeRulesTest - Class in org.apache.calcite.rel.rules
-
Unit tests for
DateRangeRules
algorithms. - DateRangeRulesTest() - Constructor for class org.apache.calcite.rel.rules.DateRangeRulesTest
- DateRangeRulesTest.Fixture2 - Class in org.apache.calcite.rel.rules
-
Common expressions across tests.
- dateType - Variable in class org.apache.calcite.test.catalog.Fixture
- DB - Static variable in class org.apache.calcite.test.CalciteAssert
-
Which database to use for tests that require a JDBC data source.
- DB_NAME - Static variable in class org.apache.calcite.adapter.mongodb.MongoDatabasePolicy
- DdlCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.DdlCommand
- debug - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- debug - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- DEBUG - Static variable in class org.apache.calcite.util.PartiallyOrderedSetTest
- debugPrintStream - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Debugging print stream.
- debugStream - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- dec - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- DECIMAL - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Whether DECIMAL type is implemented.
- decorrelate - Variable in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- decorrelate(boolean) - Method in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- decRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- deduceLogic(RexNode, RexNode, RelOptUtil.Logic) - Method in class org.apache.calcite.test.RexTransformerTest
- deduceMonotonicity(Prepare.PreparingTable) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader
- deduceMonotonicity(SqlValidatorTable) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- DedupFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.DedupFunction
- DEF - Static variable in interface org.apache.calcite.test.RelMetadataTest.ColType
- DEFAULT_CATALOG - Static variable in class org.apache.calcite.test.catalog.MockCatalogReader
- DEFAULT_COLUMNS - Static variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- DEFAULT_COMP_SELECTIVITY - Static variable in class org.apache.calcite.test.RelMetadataTest
- DEFAULT_EQUAL_SELECTIVITY - Static variable in class org.apache.calcite.test.RelMetadataTest
- DEFAULT_EQUAL_SELECTIVITY_SQUARED - Static variable in class org.apache.calcite.test.RelMetadataTest
- DEFAULT_NOTNULL_SELECTIVITY - Static variable in class org.apache.calcite.test.RelMetadataTest
- DEFAULT_OPTIONS - Static variable in class org.apache.calcite.sql.test.SqlTestFactory
- DEFAULT_REL_CONFIG - Static variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- DEFAULT_SCHEMA - Static variable in class org.apache.calcite.test.catalog.MockCatalogReader
- DEFAULT_SELECTIVITY - Static variable in class org.apache.calcite.test.RelMetadataTest
- DEFAULT_TESTER - Static variable in class org.apache.calcite.sql.test.SqlOperatorTest
- DefaultAttributedEdge(String, String, List) - Constructor for class org.apache.calcite.util.graph.DirectedGraphTest.DefaultAttributedEdge
- DefaultAttributedEdgeFactory() - Constructor for class org.apache.calcite.util.graph.DirectedGraphTest.DefaultAttributedEdgeFactory
- defaultColumnGroup - Variable in class org.apache.calcite.test.catalog.CompoundNameColumnResolver
- defaultColumns - Variable in class org.apache.calcite.test.catalog.CountingFactory
- defaultFuzzTest() - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- DefaultSchemaPostProcessor(String) - Constructor for class org.apache.calcite.test.CalciteAssert.DefaultSchemaPostProcessor
- deferredBindings - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- define(String, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- defineVariables(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- delegate - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- DelegateStructType(RelDataType, StructKind) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- DelegatingRelOptTable(RelOptTable) - Constructor for class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- delta - Variable in class org.apache.calcite.sql.test.SqlTests.ApproximateResultChecker
- Department(int, String, List<JdbcTest.Employee>, JdbcTest.Location) - Constructor for class org.apache.calcite.test.JdbcTest.Department
- Department(String, int, List<Linq4jTest.Employee>) - Constructor for class org.apache.calcite.linq4j.test.Linq4jTest.Department
- Dependent(int, String) - Constructor for class org.apache.calcite.test.JdbcTest.Dependent
- dependents - Variable in class org.apache.calcite.test.JdbcTest.HrSchema
- dependents - Variable in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- Dept(int, String) - Constructor for class org.apache.calcite.runtime.EnumerablesTest.Dept
- DEPT_COLUMNS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- DEPT_DEPTNO_SELECTOR - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- DEPT_DEPTNO_SELECTOR2 - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- DEPT_EMPLOYEES_SELECTOR - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- DEPT_NAME_SELECTOR - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- DEPT_ROW - Static variable in class org.apache.calcite.plan.RelOptUtilTest
- DEPT_SCAN - Static variable in class org.apache.calcite.plan.RelOptUtilTest
- DEPT_SIZE - Static variable in class org.apache.calcite.test.RelMetadataTest
- deptno - Variable in class com.example.Linq4jExample.Employee
- deptno - Variable in class org.apache.calcite.linq4j.test.Linq4jTest.Department
- deptno - Variable in class org.apache.calcite.linq4j.test.Linq4jTest.Employee
- deptno - Variable in class org.apache.calcite.runtime.EnumerablesTest.Dept
- deptno - Variable in class org.apache.calcite.runtime.EnumerablesTest.Emp
- deptno - Variable in class org.apache.calcite.test.JdbcTest.Department
- deptno - Variable in class org.apache.calcite.test.JdbcTest.Employee
- DEPTNO - Variable in class org.apache.calcite.test.JdbcTest.LingualEmp
- depts - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- depts - Variable in class org.apache.calcite.test.JdbcTest.HrSchema
- depts - Variable in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- DEPTS - Static variable in class org.apache.calcite.runtime.EnumerablesTest
- deriveRowType() - Method in class org.apache.calcite.plan.volcano.PlannerTests.TestLeafRel
- deriveRowType() - Method in class org.apache.calcite.plan.volcano.PlannerTests.TestSingleRel
- deriveRowType() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestLeafRel
- deriveRowType() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestSingleRel
- deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Method in class org.apache.calcite.tools.PlannerTest.MyCountAggFunction
- describe(Matcher) - Static method in class org.apache.calcite.util.UtilTest
- DESCRIBE_RESULT_SET_CMD - Static variable in class org.apache.calcite.test.concurrent.SamplePlugin
- describeMismatchSafely(F, Description) - Method in class org.apache.calcite.test.Matchers.ComposingMatcher
- DescribeResultSet() - Constructor for class org.apache.calcite.test.concurrent.SamplePlugin.DescribeResultSet
- describeTo(Description) - Method in class org.apache.calcite.test.Matchers.ComposingMatcher
- describeTo(Description) - Method in class org.apache.calcite.test.Matchers.IsWithin
- description - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- description - Variable in exception org.apache.calcite.test.concurrent.ConcurrentTestCommand.ShouldHaveFailedException
- deterministic(int) - Static method in class org.apache.calcite.linq4j.test.DeterministicTest.TestClass
- deterministic(int) - Static method in class org.apache.calcite.linq4j.test.DeterministicTest.TestDeterministicClass
- DeterministicTest - Class in org.apache.calcite.linq4j.test
-
Tests factoring out deterministic expressions.
- DeterministicTest() - Constructor for class org.apache.calcite.linq4j.test.DeterministicTest
- DeterministicTest.TestClass - Class in org.apache.calcite.linq4j.test
-
Class to test @Deterministic annotation
- DeterministicTest.TestDeterministicClass - Class in org.apache.calcite.linq4j.test
-
Class to test @NonDeterministic annotation
- dialect - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- dialect(SqlDialect) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- diff(File, File) - Static method in class org.apache.calcite.test.DiffTestCase
-
Returns a string containing the difference between the contents of two files.
- diffFail(File, int) - Method in class org.apache.calcite.test.DiffTestCase
- diffFile(File, File) - Method in class org.apache.calcite.test.DiffTestCase
-
Compares a log file with its reference log.
- diffLines(List<String>, List<String>) - Static method in class org.apache.calcite.test.DiffTestCase
-
Returns a string containing the difference between the two sets of lines.
- diffMasks - Variable in class org.apache.calcite.test.DiffTestCase
-
Diff masks defined so far
- diffRepos - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- DiffRepository - Class in org.apache.calcite.test
-
A collection of resources used by tests.
- DiffRepository(URL, File, DiffRepository, DiffRepository.Filter) - Constructor for class org.apache.calcite.test.DiffRepository
-
Creates a DiffRepository.
- DiffRepository.Filter - Interface in org.apache.calcite.test
-
Callback to filter strings before returning them.
- DiffTestCase - Class in org.apache.calcite.test
-
DiffTestCase is an abstract base for JUnit tests which produce multi-line output to be verified by diffing against a pre-existing reference file.
- DiffTestCase(String) - Constructor for class org.apache.calcite.test.DiffTestCase
-
Initializes a new DiffTestCase.
- diffTestLog() - Method in class org.apache.calcite.test.DiffTestCase
-
Finishes a diff-based test.
- DirectedGraphTest - Class in org.apache.calcite.util.graph
-
Unit test for
DirectedGraph
. - DirectedGraphTest() - Constructor for class org.apache.calcite.util.graph.DirectedGraphTest
- DirectedGraphTest.DefaultAttributedEdge - Class in org.apache.calcite.util.graph
-
Edge that stores its attributes in a list.
- DirectedGraphTest.DefaultAttributedEdgeFactory - Class in org.apache.calcite.util.graph
-
Factory for
DirectedGraphTest.DefaultAttributedEdge
. - disabled - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- DISABLED - Static variable in class org.apache.calcite.test.CalciteAssert
-
Implementation of
CalciteAssert.AssertThat
that does nothing. - DISABLED - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- DISABLED_IDS - Static variable in class org.apache.calcite.test.FoodmartTest
- disabledFeature - Variable in class org.apache.calcite.test.SqlValidatorFeatureTest
- dispatcher - Variable in class org.apache.calcite.util.ReflectVisitorTest.NumberNegater
- div(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- divideBy(RelOptCost) - Method in class org.apache.calcite.test.MockRelOptCost
- divInt(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- DIVISION_BY_ZERO_MESSAGE - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- doc - Variable in class org.apache.calcite.test.DiffRepository
- doEndOfState(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- doExample(RelBuilder, int) - Method in class org.apache.calcite.examples.RelBuilderExample
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.CloseCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.CommitCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.DdlCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.ExplainCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.InsertCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.PrepareCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.RollbackCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.SleepCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.SynchronizationCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.EchoCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.FetchAndPrintCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PluginCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrepareCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrintCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SelectCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ShellCommand
- doExecute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SqlCommand
- doWithConnection(Consumer<CalciteConnection>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a
CalciteConnection
and executes a callback that returns no result. - doWithConnection(Function<CalciteConnection, T>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a
CalciteConnection
and executes a callback. - doWithDataContext(Function<DataContext, T>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a
DataContext
and executes a callback. - driver - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- driver - Variable in class org.apache.calcite.test.ConnectionSpec
- DruidAdapterIT - Class in org.apache.calcite.test
-
Tests for the
org.apache.calcite.adapter.druid
package. - DruidAdapterIT() - Constructor for class org.apache.calcite.test.DruidAdapterIT
- DruidAdapterIT2 - Class in org.apache.calcite.test
-
Tests for the
org.apache.calcite.adapter.druid
package. - DruidAdapterIT2() - Constructor for class org.apache.calcite.test.DruidAdapterIT2
- druidChecker(String...) - Static method in class org.apache.calcite.test.DruidAdapterIT
-
Returns a consumer that checks that a particular Druid query is generated to implement a query.
- druidChecker(String...) - Static method in class org.apache.calcite.test.DruidAdapterIT2
-
Returns a function that checks that a particular Druid query is generated to implement a query.
- DruidDateRangeRulesTest - Class in org.apache.calcite.test
-
Unit tests for
DateRangeRules
algorithms. - DruidDateRangeRulesTest() - Constructor for class org.apache.calcite.test.DruidDateRangeRulesTest
- DruidDateRangeRulesTest.Fixture2 - Class in org.apache.calcite.test
-
Common expressions across tests.
- druidQuery - Variable in class org.apache.calcite.adapter.druid.DruidQueryFilterTest
- DruidQueryFilterTest - Class in org.apache.calcite.adapter.druid
-
Tests generating Druid filters.
- DruidQueryFilterTest() - Constructor for class org.apache.calcite.adapter.druid.DruidQueryFilterTest
- DruidQueryFilterTest.Fixture - Class in org.apache.calcite.adapter.druid
-
Everything a test needs for a healthy, active life.
- druidTable - Variable in class org.apache.calcite.adapter.druid.DruidQueryFilterTest.Fixture
- DummyRelNode(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.test.RelMetadataTest.DummyRelNode
-
Creates a
DummyRelNode
. - DummyTestDataContext() - Constructor for class org.apache.calcite.test.RexProgramBuilderBase.DummyTestDataContext
- dump(ResultSet, boolean) - Method in class org.apache.calcite.test.CalciteHandler
- dump(RelNode) - Method in class org.apache.calcite.test.CalciteHandler
- dump(PartiallyOrderedSet<E>) - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- dumpColumn(ResultSet, int) - Method in class org.apache.calcite.test.CalciteHandler
-
Dumps a column value.
- dumpData(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
-
Outputs expected and result data in tabular format.
- duration - Variable in class org.apache.calcite.test.fuzzer.SimplifyTask
- dynamicParams - Variable in class org.apache.calcite.test.RexProgramBuilderBase
E
- e - Variable in class org.apache.calcite.test.CsvTest.Worker
-
Exception thrown by a command or queue wait.
- ECHO - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- ECHO_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- EchoCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.EchoCommand
- ElasticSearchAdapterTest - Class in org.apache.calcite.adapter.elasticsearch
-
Set of tests for ES adapter.
- ElasticSearchAdapterTest() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- elasticsearchChecker(String...) - Static method in class org.apache.calcite.test.ElasticsearchChecker
-
Returns a function that checks that a particular Elasticsearch pipeline is generated to implement a query.
- ElasticsearchChecker - Class in org.apache.calcite.test
-
Internal util methods for ElasticSearch tests
- ElasticsearchChecker() - Constructor for class org.apache.calcite.test.ElasticsearchChecker
- ElasticsearchJsonTest - Class in org.apache.calcite.adapter.elasticsearch
-
Testing correct parsing of JSON (elasticsearch) response.
- ElasticsearchJsonTest() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- ElasticsearchVersionTest - Class in org.apache.calcite.adapter.elasticsearch
-
Basic tests for parsing ES version in different formats
- ElasticsearchVersionTest() - Constructor for class org.apache.calcite.adapter.elasticsearch.ElasticsearchVersionTest
- EmbeddedElasticsearchNode - Class in org.apache.calcite.adapter.elasticsearch
-
Represents a single elastic search node which can run embedded in a java application.
- EmbeddedElasticsearchNode(Node) - Constructor for class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
- EmbeddedElasticsearchNode.LocalNode - Class in org.apache.calcite.adapter.elasticsearch
-
Having separate class to expose (protected) constructor which allows to install different plugins.
- EmbeddedElasticsearchPolicy - Class in org.apache.calcite.adapter.elasticsearch
-
Used to initialize a single elastic node.
- EmbeddedElasticsearchPolicy(EmbeddedElasticsearchNode) - Constructor for class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- Emp(int, String) - Constructor for class org.apache.calcite.runtime.EnumerablesTest.Emp
- EMP_COLUMNS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- EMP_COLUMNS_E - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- EMP_DEPT_JOIN_REL_FIELDS - Static variable in class org.apache.calcite.plan.RelOptUtilTest
- EMP_DEPT_TO_STRING - Static variable in class org.apache.calcite.runtime.EnumerablesTest
- EMP_DEPTNO_SELECTOR - Static variable in class com.example.Linq4jExample
- EMP_DEPTNO_SELECTOR - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- EMP_EMPNO_SELECTOR - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- EMP_NAME_SELECTOR - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- EMP_QNAME - Static variable in class org.apache.calcite.test.RelMetadataTest
- EMP_RECORD_TYPE - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- EMP_RECORD_TYPE - Static variable in class org.apache.calcite.test.SqlValidatorTest
- EMP_ROW - Static variable in class org.apache.calcite.plan.RelOptUtilTest
- EMP_SCAN - Static variable in class org.apache.calcite.plan.RelOptUtilTest
- EMP_SIZE - Static variable in class org.apache.calcite.test.RelMetadataTest
- EMP_TABLE - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- EmpDeptTableFactory() - Constructor for class org.apache.calcite.test.JdbcTest.EmpDeptTableFactory
- empid - Variable in class org.apache.calcite.examples.foodmart.java.JdbcExample.Employee
- empid - Variable in class org.apache.calcite.test.JdbcTest.Dependent
- empid - Variable in class org.apache.calcite.test.JdbcTest.Employee
- empid - Variable in class RootEmployee
- EmpInitializerExpressionFactory - Class in org.apache.calcite.test.catalog
-
Default values for the "EMPDEFAULTS" table.
- EmpInitializerExpressionFactory() - Constructor for class org.apache.calcite.test.catalog.EmpInitializerExpressionFactory
- empListType - Variable in class org.apache.calcite.test.catalog.Fixture
- Employee(int, int, String, float, Integer) - Constructor for class org.apache.calcite.test.JdbcTest.Employee
- Employee(int, String) - Constructor for class org.apache.calcite.examples.foodmart.java.JdbcExample.Employee
- Employee(int, String, int) - Constructor for class com.example.Linq4jExample.Employee
- Employee(int, String, int) - Constructor for class org.apache.calcite.linq4j.test.Linq4jTest.Employee
- employees - Variable in class org.apache.calcite.linq4j.test.Linq4jTest.Department
- employees - Variable in class org.apache.calcite.test.JdbcTest.Department
- EmployeeWithHireDate(int, int, String, float, Integer, Date) - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest.EmployeeWithHireDate
- empno - Variable in class com.example.Linq4jExample.Employee
- empno - Variable in class org.apache.calcite.linq4j.test.Linq4jTest.Employee
- EMPNO - Variable in class org.apache.calcite.test.JdbcTest.LingualEmp
- EMPNO_EMP - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- empRecordType - Variable in class org.apache.calcite.test.catalog.Fixture
- emps - Variable in class org.apache.calcite.examples.foodmart.java.JdbcExample.Hr
- emps - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- emps - Variable in class org.apache.calcite.test.JdbcTest.HrSchema
- emps - Variable in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- emps - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.DateColumnSchema
- emps - Variable in class RootHr
- EMPS - Static variable in class com.example.Linq4jExample
- EMPS - Static variable in class org.apache.calcite.runtime.EnumerablesTest
- EMPS - Variable in class org.apache.calcite.test.JdbcTest.LingualSchema
- EMPTY - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates an empty connection.
- EMPTY - Static variable in class org.apache.calcite.test.CalciteAssert.AssertThat
- EMPTY_CONNECTION_FACTORY - Static variable in class org.apache.calcite.test.CalciteAssert
- emptyResult() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- enable - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- enable(boolean) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- enable(boolean) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- ENABLE - Static variable in class org.apache.calcite.adapter.tpch.TpchTest
- ENABLE_SLOW - Static variable in class org.apache.calcite.test.CalciteAssert
-
Whether to enable slow tests.
- enabled() - Static method in class org.apache.calcite.test.CassandraAdapterTest
-
Whether to run this test.
- enabled() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Whether to run this test.
- enabled() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Whether to run this test.
- enabled() - Method in class org.apache.calcite.test.SplunkAdapterTest
-
Whether this test is enabled.
- ENABLED - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- ENABLED - Static variable in class org.apache.calcite.test.DruidAdapterIT
-
Whether to run Druid tests.
- ENABLED - Static variable in class org.apache.calcite.test.DruidAdapterIT2
-
Whether to run Druid tests.
- ENABLED - Static variable in class org.apache.calcite.test.SplunkAdapterTest
-
Whether to run Splunk tests.
- enableDecorrelate - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- enableExpand - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- enableLateDecorrelate - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- enableMaterializations(boolean) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- enableTrim - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- end - Variable in class org.apache.calcite.adapter.generate.RangeTable
- end - Variable in class org.apache.calcite.test.CsvTest.Worker
-
The poison pill command.
- END - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- endTimeMillis - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator
- endTimeMillis - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator.TimedIterator
- EndToEndTest - Class in org.apache.calcite.chinook
-
Entry point for all end-to-end tests based on Chinook data in HSQLDB wrapped by Calcite schema.
- EndToEndTest(String) - Constructor for class org.apache.calcite.chinook.EndToEndTest
- enforceMongo() - Static method in class org.apache.calcite.test.MongoAdapterIT
- ensurePlan(Consumer<Integer>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- ensureRegistered(RelNode, RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- entries - Variable in class org.apache.calcite.test.ExceptionMessageTest.TestSchema
- Entry(int, String) - Constructor for class org.apache.calcite.test.ExceptionMessageTest.Entry
- enumerable - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- EnumerableCorrelateTest - Class in org.apache.calcite.test.enumerable
-
Unit test for
EnumerableCorrelate
. - EnumerableCorrelateTest() - Constructor for class org.apache.calcite.test.enumerable.EnumerableCorrelateTest
- EnumerablesTest - Class in org.apache.calcite.runtime
-
Unit tests for
Enumerables
. - EnumerablesTest() - Constructor for class org.apache.calcite.runtime.EnumerablesTest
- EnumerablesTest.Dept - Class in org.apache.calcite.runtime
-
Department record.
- EnumerablesTest.Emp - Class in org.apache.calcite.runtime
-
Employee record.
- enumerator() - Method in class org.apache.calcite.adapter.generate.RangeTable
- enumerator() - Method in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- enumeratorImpl(int[]) - Method in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- EOF - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- EOF_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- epsilon - Variable in class org.apache.calcite.test.Matchers.IsWithin
- EPSILON - Static variable in class org.apache.calcite.test.RelMetadataTest
- eq(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- eq(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- EQUAL_DEPTNO - Static variable in class org.apache.calcite.runtime.EnumerablesTest
- equals(Object) - Method in class org.apache.calcite.linq4j.test.Linq4jTest.Employee
- equals(Object) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- equals(Object) - Method in class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- equals(Object) - Method in class org.apache.calcite.test.JdbcTest.Customer
- equals(Object) - Method in class org.apache.calcite.test.JdbcTest.Department
- equals(Object) - Method in class org.apache.calcite.test.JdbcTest.Dependent
- equals(Object) - Method in class org.apache.calcite.test.JdbcTest.Employee
- equals(Object) - Method in class org.apache.calcite.test.JdbcTest.Event
- equals(Object) - Method in class org.apache.calcite.test.JdbcTest.LingualEmp
- equals(Object) - Method in class org.apache.calcite.test.JdbcTest.Location
- equals(Object) - Method in class org.apache.calcite.test.JdbcTest.SalesFact
- equals(Object) - Method in class org.apache.calcite.test.MockRelOptCost
- equals(Object) - Method in class org.apache.calcite.util.graph.DirectedGraphTest.DefaultAttributedEdge
- equals(RelOptCost) - Method in class org.apache.calcite.test.MockRelOptCost
- equals(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- equalsUnordered(E...) - Static method in class org.apache.calcite.test.Matchers
- ERR - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- ERR_AGG_IN_GROUP_BY - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- ERR_AGG_IN_GROUP_BY - Static variable in class org.apache.calcite.test.SqlValidatorTest
- ERR_AGG_IN_ORDER_BY - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- ERR_AGG_IN_ORDER_BY - Static variable in class org.apache.calcite.test.SqlValidatorTest
- ERR_IN_OPERANDS_INCOMPATIBLE - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- ERR_IN_OPERANDS_INCOMPATIBLE - Static variable in class org.apache.calcite.test.SqlValidatorTest
- ERR_IN_VALUES_INCOMPATIBLE - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- ERR_IN_VALUES_INCOMPATIBLE - Static variable in class org.apache.calcite.test.SqlValidatorTest
- ERR_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- ERR_NESTED_AGG - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- ERR_NESTED_AGG - Static variable in class org.apache.calcite.test.SqlValidatorTest
- error - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
First exception thrown by the thread.
- ERROR_SQL_STRINGS - Static variable in class org.apache.calcite.test.SplunkAdapterTest
- errorCommand - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Command throwing error *
- errorMatches(Throwable) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- escapeString(String) - Static method in class org.apache.calcite.test.CsvTest
-
Quotes a string for Java or JSON.
- escapeString(String) - Static method in class org.apache.calcite.util.TestUtil
-
Quotes a string for Java or JSON.
- escapeString(StringBuilder, String) - Static method in class org.apache.calcite.test.CsvTest
-
Quotes a string for Java or JSON, into a builder.
- escapeString(StringBuilder, String) - Static method in class org.apache.calcite.util.TestUtil
-
Quotes a string for Java or JSON, into a builder.
- eval() - Static method in class org.apache.calcite.util.Smalls.CountArgs0Function
- eval(boolean) - Static method in class org.apache.calcite.test.CountriesTableFunction
- eval(int) - Method in class org.apache.calcite.util.Smalls.AwkwardFunction
- eval(int) - Static method in class org.apache.calcite.util.Smalls.CountArgs1Function
- eval(int) - Static method in class org.apache.calcite.util.Smalls.MyDoubleFunction
- eval(int, int) - Static method in class org.apache.calcite.util.Smalls.CountArgs2Function
- eval(int, int) - Method in class org.apache.calcite.util.Smalls.MyDeterministicPlusFunction
- eval(int, int) - Method in class org.apache.calcite.util.Smalls.MyIncrement
- eval(int, int) - Method in class org.apache.calcite.util.Smalls.MyPlusFunction
- eval(Integer) - Method in class org.apache.calcite.util.Smalls.SimpleTableFunction
- eval(Integer, Integer, Integer, Integer, Integer) - Method in class org.apache.calcite.util.Smalls.MyAbcdeFunction
- eval(Object) - Static method in class org.apache.calcite.util.Smalls.MyToStringFunction
- eval(Short) - Static method in class org.apache.calcite.util.Smalls.CountArgs1NullableFunction
- eval(String) - Method in class org.apache.calcite.util.Smalls.MyTableFunction
- eval(String) - Static method in class org.apache.calcite.util.Smalls.Null4Function
- eval(String) - Static method in class org.apache.calcite.util.Smalls.Null8Function
- eval(String) - Static method in class org.apache.calcite.util.Smalls.StaticTableMacroFunction
- eval(String) - Method in class org.apache.calcite.util.Smalls.TableMacroFunction
- eval(String) - Static method in class org.apache.calcite.util.Smalls.TestStaticTableFunction
- eval(String, int) - Method in class org.apache.calcite.util.Smalls.MyLeftFunction
- eval(String, String, Integer) - Method in class org.apache.calcite.util.Smalls.TableMacroFunctionWithNamedParameters
- eval(RexNode) - Method in class org.apache.calcite.test.RexProgramTest
- Event(int, Timestamp) - Constructor for class org.apache.calcite.test.JdbcTest.Event
- eventid - Variable in class org.apache.calcite.test.JdbcTest.Event
- eventList - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- events - Variable in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- EveryType(boolean, byte, char, short, int, long, float, double, Boolean, Byte, Character, Short, Integer, Long, Float, Double, Date, Time, Timestamp, Date, String) - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- everyTypes - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- example0(RelBuilder) - Method in class org.apache.calcite.examples.RelBuilderExample
-
Creates a relational expression for a table scan.
- example1(RelBuilder) - Method in class org.apache.calcite.examples.RelBuilderExample
-
Creates a relational expression for a table scan.
- example2(RelBuilder) - Method in class org.apache.calcite.examples.RelBuilderExample
-
Creates a relational expression for a table scan and project.
- example3(RelBuilder) - Method in class org.apache.calcite.examples.RelBuilderExample
-
Creates a relational expression for a table scan, aggregate, filter.
- example4(RelBuilder) - Method in class org.apache.calcite.examples.RelBuilderExample
-
Sometimes the stack becomes so deeply nested it gets confusing.
- ExampleFunctionTest - Class in org.apache.calcite.test
-
Unit tests for example user-defined functions.
- ExampleFunctionTest() - Constructor for class org.apache.calcite.test.ExampleFunctionTest
- ExceptionMessageTest - Class in org.apache.calcite.test
-
Test cases to check that necessary information from underlying exceptions is correctly propagated via
SQLException
s. - ExceptionMessageTest() - Constructor for class org.apache.calcite.test.ExceptionMessageTest
- ExceptionMessageTest.Entry - Class in org.apache.calcite.test
-
Entries made available in the reflective TestSchema.
- ExceptionMessageTest.TestSchema - Class in org.apache.calcite.test
-
Simple reflective schema that provides valid and invalid entries.
- ExceptionResultChecker(Pattern...) - Constructor for class org.apache.calcite.sql.test.SqlOperatorBaseTest.ExceptionResultChecker
- exclusiveCleanDb(Connection) - Method in class org.apache.calcite.test.JdbcAdapterTest
-
Acquires an exclusive connection to a test database, and cleans it.
- Excn(String) - Constructor for exception org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable.Excn
- exDay - Variable in class org.apache.calcite.test.DruidDateRangeRulesTest.Fixture2
- exDayD - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- exDayTs - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- exec() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- execute() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Creates a
ConcurrentTestCommandExecutor
object for each define thread, and then runs them all. - execute() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Executes the script
- execute(Command.Context, boolean) - Method in class org.apache.calcite.test.BabelQuidemTest.ExplainValidatedCommand
- execute(ConcurrentTestCommandExecutor) - Method in interface org.apache.calcite.test.concurrent.ConcurrentTestCommand
-
Executes this command.
- execute(ConcurrentTestCommandExecutor) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- execute(ConcurrentTestPluginCommand.TestContext) - Method in interface org.apache.calcite.test.concurrent.ConcurrentTestPluginCommand
-
Implement this method to extend functionality of mtsql.
- execute(ConcurrentTestPluginCommand.TestContext) - Method in class org.apache.calcite.test.concurrent.SamplePlugin.DescribeResultSet
- executeCleanup() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- executeCommands(int, List<String>) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- executeQuery(FrameworkConfig, String, boolean) - Method in class org.apache.calcite.tools.FrameworksTest
- executeSetup() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- executor - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- executor - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- exists() - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
- exMonth - Variable in class org.apache.calcite.test.DruidDateRangeRulesTest.Fixture2
- exMonthD - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- exMonthTs - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- expand - Variable in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- expand(boolean) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- expand(boolean) - Method in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- expand(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- expand(String, String) - Method in class org.apache.calcite.test.DiffRepository
-
Expands a string containing one or more variables.
- EXPAND - org.apache.calcite.sql.test.SqlTester.VmName
- expandDots(T) - Static method in class org.apache.calcite.test.ElasticsearchChecker
-
Expands attributes with dots (
.
) into sub-nodes. - expandingConfig(Connection) - Static method in class org.apache.calcite.test.RelBuilderTest
-
Creates a config builder that will contain a view, "MYVIEW", and also the SCOTT JDBC schema, whose tables implement
TranslatableTable
. - expect - Variable in class org.apache.calcite.adapter.file.SqlTest.Fluent
- expect - Variable in class org.apache.calcite.test.CsvTest.Fluent
- expect(String...) - Static method in class org.apache.calcite.adapter.file.SqlTest
- expect(String...) - Static method in class org.apache.calcite.test.CsvTest
-
Returns a function that checks the contents of a result set against an expected string.
- expect(String...) - Static method in class org.apache.calcite.test.SplunkAdapterTest
- expected - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueOrExceptionResultChecker
- expected - Variable in class org.apache.calcite.sql.test.SqlTests.ApproximateResultChecker
- expected - Variable in class org.apache.calcite.sql.test.SqlTests.RefSetResultChecker
- expected - Variable in class org.apache.calcite.sql.test.SqlTests.StringTypeChecker
- expected - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- expectedValue - Variable in class org.apache.calcite.test.Matchers.IsWithin
- expectUnordered(String...) - Static method in class org.apache.calcite.adapter.file.SqlTest
-
Returns a function that checks the contents of a result set against an expected string.
- expectUnordered(String...) - Static method in class org.apache.calcite.test.CsvTest
-
Returns a function that checks the contents of a result set against an expected string.
- ExplainCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.ExplainCommand
- explainContains(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- explainContains(String) - Method in class org.apache.calcite.test.Fluent
- explainMatches(String, Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- explainTerms(RelWriter) - Method in class org.apache.calcite.plan.volcano.PlannerTests.TestLeafRel
- explainTerms(RelWriter) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestLeafRel
- ExplainValidatedCommand(List<String>, List<String>, Set<String>) - Constructor for class org.apache.calcite.test.BabelQuidemTest.ExplainValidatedCommand
- expr(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- EXPR_KEYWORDS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- expression - Variable in class org.apache.calcite.sql.parser.SqlParserTest.Sql
- expression() - Method in class org.apache.calcite.sql.parser.SqlParserTest.Sql
-
Flags that this is an expression, not a whole query.
- expressions() - Method in class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
- ExpressionTest - Class in org.apache.calcite.linq4j.test
-
Unit test for
Expression
and subclasses. - ExpressionTest() - Constructor for class org.apache.calcite.linq4j.test.ExpressionTest
- ExpressionTest.AllType - Class in org.apache.calcite.linq4j.test
-
A class with a field for each type of interest.
- ExpressionTest.MyEnum - Enum in org.apache.calcite.linq4j.test
-
An enum.
- extend(List<RelDataTypeField>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- extend(List<RelDataTypeField>) - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- extend(List<RelDataTypeField>) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- extend(Table) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- extend(Table) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- extend(Table, RelProtoDataType, ImmutableIntList) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable
- EXTENDED_CATALOG_TESTER - Static variable in class org.apache.calcite.test.SqlValidatorTestCase
- EXTENDED_CATALOG_TESTER_2003 - Static variable in class org.apache.calcite.test.SqlValidatorTestCase
- EXTENDED_CATALOG_TESTER_LENIENT - Static variable in class org.apache.calcite.test.SqlValidatorTestCase
- EXTENDED_COLUMNS - Static variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- EXTENDED_TEST_FACTORY - Static variable in class org.apache.calcite.test.SqlValidatorTestCase
- exYear - Variable in class org.apache.calcite.test.DruidDateRangeRulesTest.Fixture2
- exYearD - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- exYearTs - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
F
- f - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- f - Variable in class org.apache.calcite.sql.type.SqlTypeUtilTest
- f - Variable in class org.apache.calcite.test.Matchers.ComposingMatcher
- factory - Variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- factory - Variable in class org.apache.calcite.sql.test.AbstractSqlTester
- factory(Supplier<Profiler>) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- Factory() - Constructor for class org.apache.calcite.adapter.generate.RangeTable.Factory
- Factory() - Constructor for class org.apache.calcite.jdbc.CalciteRemoteDriverTest.Factory
- FACTORY - Static variable in class org.apache.calcite.test.FoodMartLatticeStatisticProvider
- Factory2() - Constructor for class org.apache.calcite.jdbc.CalciteRemoteDriverTest.Factory2
- failComment - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- failed() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Returns whether any test thread failed.
- FailedThread(String, String, Throwable) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FailedThread
- failedThreads - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Collects threads that failed.
- failPattern - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- fails(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.Sql
- fails(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- failsAtValidation() - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Utility method so that one doesn't have to call
CalciteAssert.AssertQuery.failsAtValidation(java.lang.String)
withnull
- failsAtValidation(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Used to check whether a sql statement fails at the SQL Validation phase.
- failsIf(boolean, String) - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- failure - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FailedThread
- failureExpected - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- FALSE - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- FALSE_B - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- FALSE_TRUE - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- falseLiteral - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- falseRex - Variable in class org.apache.calcite.test.RexTransformerTest
- FarragoTestValidator(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory, SqlConformance) - Constructor for class org.apache.calcite.test.SqlToRelTestBase.FarragoTestValidator
- FEATURE_DISABLED - Static variable in class org.apache.calcite.test.SqlValidatorFeatureTest
- FeatureValidator(SqlOperatorTable, SqlValidatorCatalogReader, RelDataTypeFactory, SqlConformance) - Constructor for class org.apache.calcite.test.SqlValidatorFeatureTest.FeatureValidator
- FENNEL - org.apache.calcite.sql.test.SqlTester.VmName
- FETCH - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- FETCH_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- FETCH_OFFSET - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- FetchAndCompareCommand(int, String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- FetchAndPrintCommand(long) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.FetchAndPrintCommand
- FIBONACCI_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- FIBONACCI2_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- fibonacciTable() - Static method in class org.apache.calcite.util.Smalls
-
A function that generates the Fibonacci sequence.
- fibonacciTableWithLimit(long) - Static method in class org.apache.calcite.util.Smalls
-
A function that generates the Fibonacci sequence.
- fieldAccessEqualsHashCode() - Method in class org.apache.calcite.test.RexProgramTest
- fields() - Static method in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- file(String) - Static method in class org.apache.calcite.adapter.file.FileReaderTest
-
Converts a path that is relative to the module into a path that is relative to where the test is running.
- fileContents(File) - Static method in class org.apache.calcite.test.DiffTestCase
-
Returns the contents of a file as a string.
- fileLines(File) - Static method in class org.apache.calcite.test.DiffTestCase
-
Returns a list of the lines in a given file.
- FileReaderTest - Class in org.apache.calcite.adapter.file
-
Unit tests for FileReader.
- FileReaderTest() - Constructor for class org.apache.calcite.adapter.file.FileReaderTest
- files - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- FileSuite - Class in org.apache.calcite.adapter.file
-
Unit test suite for Calcite File adapter.
- FileSuite() - Constructor for class org.apache.calcite.adapter.file.FileSuite
- fill(char[], char) - Static method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- filter - Variable in class org.apache.calcite.test.DiffRepository
- filter(DiffRepository, String, String, String, String) - Method in interface org.apache.calcite.test.DiffRepository.Filter
-
Filters a string.
- FilteratorTest - Class in org.apache.calcite.test
-
Unit test for
Filterator
. - FilteratorTest() - Constructor for class org.apache.calcite.test.FilteratorTest
- findBestExp() - Method in class org.apache.calcite.test.MockRelOptPlanner
- findFile(Class, String) - Static method in class org.apache.calcite.test.DiffRepository
- findMethod(String) - Method in class org.apache.calcite.test.QuidemTest
- first - Variable in class org.apache.calcite.test.catalog.CompoundNameColumn
- firstWord(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
-
Returns the first word of the given line, assuming the line is trimmed.
- fixture - Variable in class org.apache.calcite.test.catalog.MockCatalogReaderSimple
- Fixture - Class in org.apache.calcite.test.catalog
-
Types used during initialization.
- Fixture() - Constructor for class org.apache.calcite.adapter.druid.DruidQueryFilterTest.Fixture
- Fixture() - Constructor for class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- Fixture(RelDataTypeFactory) - Constructor for class org.apache.calcite.test.catalog.Fixture
- Fixture2() - Constructor for class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- Fixture2() - Constructor for class org.apache.calcite.test.DruidDateRangeRulesTest.Fixture2
- fl - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- floatDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- floatLiteral(double) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- floorDay - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- floorHour - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- floorMinute - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- floorMonth - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- floorYear - Variable in class org.apache.calcite.rel.rules.DateRangeRulesTest.Fixture2
- Fluent - Class in org.apache.calcite.test
-
Fluent API to perform Piglet test actions.
- Fluent(String) - Constructor for class org.apache.calcite.test.Fluent
- Fluent(String, String, Consumer<ResultSet>) - Constructor for class org.apache.calcite.test.CsvTest.Fluent
- Fluent(String, String, Function<ResultSet, Void>) - Constructor for class org.apache.calcite.adapter.file.SqlTest.Fluent
- Fluid(CalciteAssert.Config, String, Supplier<Profiler>, Predicate<Profiler.Statistic>, Comparator<Profiler.Statistic>, int, List<String>) - Constructor for class org.apache.calcite.profile.ProfilerTest.Fluid
- flushDoc() - Method in class org.apache.calcite.test.DiffRepository
-
Flushes the reference document to the file system.
- fold(String...) - Static method in class org.apache.calcite.util.TestUtil
-
Combines an array of strings, each representing a line, into a single string containing line separators.
- foo(int) - Static method in class org.apache.calcite.linq4j.test.ExpressionTest
- foo(int) - Method in class org.apache.calcite.test.JdbcTest.HrSchema
- foo(int) - Method in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- foo(int, int) - Static method in class org.apache.calcite.util.UtilTest
-
Dummy method for
UtilTest.testParameterName()
to inspect. - foo(String...) - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- foo(RelNode) - Static method in class org.apache.calcite.test.SqlToRelConverterExtendedTest
- foo(CalciteAssert.AssertThat, String, int) - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- foodmart - Variable in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- foodmart() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- foodmart() - Method in class org.apache.calcite.profile.ProfilerTest
- Foodmart() - Constructor for class org.apache.calcite.examples.foodmart.java.JdbcExample.Foodmart
- FOODMART - Static variable in class org.apache.calcite.test.DruidAdapterIT
-
URL of the "druid-foodmart" model.
- FOODMART - Static variable in class org.apache.calcite.test.DruidAdapterIT2
-
URL of the "druid-foodmart" model.
- FOODMART_CLONE - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that contains an in-memory clone of the FoodMart database.
- FOODMART_MODEL - Static variable in class org.apache.calcite.test.JdbcTest
- FOODMART_QUERIES - Static variable in class org.apache.calcite.test.JdbcTest
- FOODMART_SCHEMA - Static variable in class org.apache.calcite.test.JdbcTest
- FOODMART_TABLE - Static variable in class org.apache.calcite.test.DruidAdapterIT
- FOODMART_TABLE - Static variable in class org.apache.calcite.test.DruidAdapterIT2
- foodmartApprox(String) - Method in class org.apache.calcite.test.DruidAdapterIT
-
Creates a query against FOODMART with approximate parameters
- foodmartApprox(String) - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Creates a query against FOODMART with approximate parameters
- FoodmartColumn() - Constructor for class org.apache.calcite.test.FoodMartQuerySet.FoodmartColumn
- FoodmartJdbcSchema(DataSource, SqlDialect, JdbcConvention, String, String) - Constructor for class org.apache.calcite.test.JdbcTest.FoodmartJdbcSchema
- foodmartLatticeModel(String) - Static method in class org.apache.calcite.test.LatticeTest
- FoodMartLatticeStatisticProvider - Class in org.apache.calcite.test
-
Implementation of
LatticeStatisticProvider
that has hard-coded values for various attributes in the FoodMart lattice. - FoodMartLatticeStatisticProvider(Lattice, LatticeStatisticProvider) - Constructor for class org.apache.calcite.test.FoodMartLatticeStatisticProvider
- foodmartModel(String...) - Static method in class org.apache.calcite.test.LatticeTest
- foodmartModelWithOneTile() - Method in class org.apache.calcite.test.LatticeTest
- FoodmartQuery() - Constructor for class org.apache.calcite.test.FoodMartQuerySet.FoodmartQuery
- FoodMartQuerySet - Class in org.apache.calcite.test
-
Set of queries against the FoodMart database.
- FoodMartQuerySet() - Constructor for class org.apache.calcite.test.FoodMartQuerySet
- FoodMartQuerySet.FoodmartColumn - Class in org.apache.calcite.test
-
JSON column element.
- FoodMartQuerySet.FoodmartQuery - Class in org.apache.calcite.test
-
JSON query element.
- FoodMartQuerySet.FoodmartRoot - Class in org.apache.calcite.test
-
JSON root element.
- FoodmartRoot() - Constructor for class org.apache.calcite.test.FoodMartQuerySet.FoodmartRoot
- FoodmartSchema() - Constructor for class org.apache.calcite.test.JdbcTest.FoodmartSchema
- FoodmartTest - Class in org.apache.calcite.test
-
Test case that runs the FoodMart reference queries.
- FoodmartTest(int) - Constructor for class org.apache.calcite.test.FoodmartTest
- FOUR - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- FrameworksTest - Class in org.apache.calcite.tools
-
Unit tests for methods in
Frameworks
. - FrameworksTest() - Constructor for class org.apache.calcite.tools.FrameworksTest
- FrameworksTest.HiveLikeTypeSystem - Class in org.apache.calcite.tools
-
Dummy type system, similar to Hive's, accessed via an INSTANCE member.
- FrameworksTest.HiveLikeTypeSystem2 - Class in org.apache.calcite.tools
-
Dummy type system, similar to Hive's, accessed via a public default constructor.
- FrameworksTest.TableImpl - Class in org.apache.calcite.tools
-
Modifiable, filterable table.
- FROM_KEYWORDS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- fromTable - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- fun1(int) - Static method in class org.apache.calcite.util.Smalls.MultipleFunction
- fun1(int, int) - Static method in class org.apache.calcite.util.Smalls.MultipleFunction
- fun1(String) - Static method in class org.apache.calcite.util.Smalls.MultipleFunction
- fun2(int) - Static method in class org.apache.calcite.util.Smalls.MultipleFunction
- function - Variable in class org.apache.calcite.test.CalciteAssert.AssertMetaData
- FunctionTest - Class in org.apache.calcite.linq4j.function
-
Test for
Functions
. - FunctionTest() - Constructor for class org.apache.calcite.linq4j.function.FunctionTest
- fuzzCase(Random, int, Function<Random, RexNode>) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
- fuzzOperator(Random, SqlOperator[], int, Function<Random, RexNode>) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
- fuzzOperator(Random, SqlOperator[], RexNode...) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
G
- ge(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- ge(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- generate(int, int, int) - Static method in class org.apache.calcite.util.Smalls.MazeTable
- GENERATE_STRINGS_METHOD - Static variable in class org.apache.calcite.util.Smalls
- generate2(int, int, Integer) - Static method in class org.apache.calcite.util.Smalls.MazeTable
- generate3(String) - Static method in class org.apache.calcite.util.Smalls.MazeTable
- generateAggQuery(String, String[]) - Static method in class org.apache.calcite.sql.test.SqlTests
- generateAggQueryWithMultipleArgs(String, String[][]) - Static method in class org.apache.calcite.sql.test.SqlTests
- generateRexAndCheckTrueFalse(RexFuzzer, Random) - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- generateStrings(Integer) - Static method in class org.apache.calcite.util.Smalls
-
A function that generates a table that generates a sequence of
Smalls.IntString
values. - generateWinAggQuery(String, String, String[]) - Static method in class org.apache.calcite.sql.test.SqlTests
- generationStrategy(RelOptTable, int) - Method in class org.apache.calcite.test.catalog.CountingFactory
- generationStrategy(RelOptTable, int) - Method in class org.apache.calcite.test.catalog.EmpInitializerExpressionFactory
- genericMethodCall() - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest
-
CALCITE-2413: RexToLixTranslator does not generate correct declaration of Methods with generic return types
- genValidatorTest() - Method in class org.apache.calcite.test.SqlTestGen
- GEO - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that contains geo-spatial functions.
- GEO - org.apache.calcite.test.CalciteAssert.SchemaSpec
- GeodeAllDataTypesTest - Class in org.apache.calcite.adapter.geode.rel
-
Test with different types of data like boolean, time, timestamp
- GeodeAllDataTypesTest() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- GeodeAssertions - Class in org.apache.calcite.adapter.geode.rel
-
Various validations for geode tests.
- GeodeAssertions() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeAssertions
- GeodeBookstoreTest - Class in org.apache.calcite.adapter.geode.rel
-
Tests using
Bookshop
schema. - GeodeBookstoreTest() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- GeodeEmbeddedPolicy - Class in org.apache.calcite.adapter.geode.rel
-
Manages embedded Geode instance using native
ServerLauncher
. - GeodeEmbeddedPolicy(ServerLauncher) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy
- GeodeEmbeddedPolicy.RefCountPolicy - Class in org.apache.calcite.adapter.geode.rel
-
Calls
before()
andafter()
methods only once (for first and last subscriber respectively). - GeodeZipsTest - Class in org.apache.calcite.adapter.geode.rel
-
Tests based on
zips-min.json
dataset. - GeodeZipsTest() - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- get(String) - Method in class org.apache.calcite.rex.RexExecutorTest.TestDataContext
- get(String) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- get(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- get(String) - Method in class org.apache.calcite.test.InterpreterTest.MyDataContext
- get(String) - Method in class org.apache.calcite.test.RexProgramBuilderBase.DummyTestDataContext
- get(String, String) - Method in class org.apache.calcite.test.DiffRepository
-
Returns a given resource from a given test case.
- get(ResultSet) - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- GET_CATALOGS - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- GET_COLUMNS - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- GET_SCHEMAS - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- GET_TABLE_TYPES - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- GET_TYPEINFO - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- getA(DefaultDirectedGraph<String, DefaultEdge>, String) - Method in class org.apache.calcite.util.graph.DirectedGraphTest
- getAllowedAccess() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getApplyTimes() - Method in class org.apache.calcite.test.HepPlannerTest.HepTestListener
- getB(DefaultDirectedGraph<String, DefaultEdge>, String) - Method in class org.apache.calcite.util.graph.DirectedGraphTest
- getBoolExpression(Random, int) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
- getCalendarNotTooNear(int) - Static method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Returns a Calendar that is the current time, pausing if we are within 2 minutes of midnight or the top of the hour.
- getCastString(String, String, boolean) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- getCatalogName() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- getCharset() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getCollation() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getCollationList() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getCollationList() - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getCollationList() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getColType(int) - Method in interface org.apache.calcite.test.RelMetadataTest.ColType
- getColType(Aggregate, RelMetadataQuery, int) - Method in class org.apache.calcite.test.RelMetadataTest.PartialColTypeImpl
-
Implementation of
RelMetadataTest.ColType.getColType(int)
forLogicalAggregate
, called via reflection. - getColType(RelNode, RelMetadataQuery, int) - Method in interface org.apache.calcite.test.RelMetadataTest.ColType.Handler
- getColType(RelNode, RelMetadataQuery, int) - Method in class org.apache.calcite.test.RelMetadataTest.ColTypeImpl
-
Implementation of
RelMetadataTest.ColType.getColType(int)
forRelNode
, called via reflection. - getColumnMapping() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableView
- getColumnStrategies() - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getColumnStrategies() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getColumnType(String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- getColumnType(String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Returns the data type of the sole column of a SQL query.
- getCommandFor(String, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestPlugin
-
Create and return plugin command for given name.
- getCommandFor(String, String) - Method in class org.apache.calcite.test.concurrent.SamplePlugin
- getCommandIterable(int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Returns an
Iterator
ofConcurrentTestCommand
objects for the given thread ID. - getCommandIterable(int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator
-
Retrieves an Iterator based on the configured commands.
- getCommands(int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Returns a
Collection
ofConcurrentTestCommand
objects for the given thread ID. - getComparability() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getComparableExpression(Random, int) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
- getComponentType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getConformance() - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- getConformance() - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns the SQL dialect to test.
- getConformance() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- getConformance() - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
- getConnection() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Obtains the thread's JDBC connection.
- getConnection() - Method in interface org.apache.calcite.test.concurrent.ConcurrentTestPluginCommand.TestContext
-
Get connection for thread.
- getConnectionWithMultiplyFunction() - Method in class org.apache.calcite.test.TableFunctionTest
- getConstraint(RexBuilder, RelDataType) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- getConstraint(RexBuilder, RelDataType) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableView
- getCpu() - Method in class org.apache.calcite.test.MockRelOptCost
- getCurrentStatement() - Method in interface org.apache.calcite.test.concurrent.ConcurrentTestPluginCommand.TestContext
-
Get current statement for thread, or null if none.
- getCurrentTestCaseName(boolean) - Method in class org.apache.calcite.test.DiffRepository
-
Returns the name of the current test case by looking up the call stack for a method whose name starts with "test", for example "testFoo".
- getDataSetPath() - Static method in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- getDateFormat(SqlTypeName) - Method in class org.apache.calcite.test.SqlLimitsTest
- getDef() - Method in class org.apache.calcite.test.RelMetadataTest.PartialColTypeImpl
- getDefault() - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationTraitDef
- getDefault() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.ConvertRelDistributionTraitDef
- getDefault() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitDef
- getDescription() - Method in exception org.apache.calcite.test.concurrent.ConcurrentTestCommand.ShouldHaveFailedException
- getDiffRepos() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- getDiffRepos() - Method in class org.apache.calcite.test.HepPlannerTest
- getDiffRepos() - Method in class org.apache.calcite.test.RelOptRulesTest
- getDiffRepos() - Method in class org.apache.calcite.test.SqlLimitsTest
- getDiffRepos() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- getDiffRepos() - Method in class org.apache.calcite.test.SqlToRelTestBase
-
Returns the default diff repository for this test, or null if there is no repository.
- getDiffRepos() - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns the diff repository.
- getDiffRepos() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- getDistribution() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getDistribution() - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getDistribution() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getDynamicParam(RelDataType, String) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- getElementType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- getElementType() - Method in class org.apache.calcite.tools.FrameworksTest.TableImpl
- getEnv(String) - Static method in class org.apache.calcite.test.QuidemTest
- getEventList() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- getExpression(Class) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getExpression(Class) - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getExpression(Class) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getExpression(Random, int) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- getExpression(SchemaPlus, String, Class) - Method in class org.apache.calcite.tools.FrameworksTest.TableImpl
- getExtendedColumnOffset() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- getExtendedTester() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- getFactory() - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- getFactory() - Method in interface org.apache.calcite.sql.test.SqlTester
- getFailedThreads() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- getFailureCause() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Checks whether an exception occurred during execution.
- getFailureCommand() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
- getFailureLocation() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Returns location (e.g., command number) for exception returned by
ConcurrentTestCommandExecutor.getFailureCause()
. - getFamily() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getField(String, boolean, boolean) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getFieldCount() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getFieldList() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getFieldNames() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getFilter(boolean, List<RexNode>) - Static method in class org.apache.calcite.test.ScannableTableTest
- getFoodmartQueries() - Static method in class org.apache.calcite.test.JdbcTest
- getFormattedThreadName(Integer) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- getFromKeywords() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- getFullPathForTestDataFile(String) - Method in class org.apache.calcite.test.AbstractPigTest
- getFullTypeString() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getImplementor() - Method in class org.apache.calcite.test.UdfTest.ArrayAppendScalarFunction
- getIntervalQualifier() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getIntExpression(Random, int) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
- getIo() - Method in class org.apache.calcite.test.MockRelOptCost
- getJavaMajorVersion() - Static method in class org.apache.calcite.util.TestUtil
-
Returns the Java major version: 7 for JDK 1.7, 8 for JDK 8, 10 for JDK 10, etc.
- getJdbcTableType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.WrapperTable
- getJdbcTableType() - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionTable
- getJdbcTableType() - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionWithAnyTypeTable
- getJdbcTableType() - Method in class org.apache.calcite.test.StreamTest.BaseOrderStreamTable
- getJdbcTableType() - Method in class org.apache.calcite.test.StreamTest.ProductsTable
- getJoinKeywords() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- getJunitMethods(Class<SqlTestGen.SqlValidatorSpooler>) - Static method in class org.apache.calcite.test.SqlTestGen
-
Returns a list of all of the Junit methods in a given class.
- getKeyType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getKind() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getLabel() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestLeafRel
- getListEnumerator(ResultSet, int) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- getMaxNumericPrecision() - Method in class org.apache.calcite.tools.FrameworksTest.HiveLikeTypeSystem
- getMaxNumericPrecision() - Method in class org.apache.calcite.tools.FrameworksTest.HiveLikeTypeSystem2
- getMethod(Class<?>, String, Class<?>...) - Static method in class org.apache.calcite.linq4j.test.DeterministicTest
- getModifiableCollection() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- getModifiableCollection() - Method in class org.apache.calcite.tools.FrameworksTest.TableImpl
- getMonotonicity(String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- getMonotonicity(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getMonotonicity(String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Given a SQL query, returns the monotonicity of the first item in the SELECT clause.
- getName() - Method in class org.apache.calcite.test.catalog.CompoundNameColumn
- getName() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- getNamedType(SqlIdentifier) - Method in class org.apache.calcite.test.catalog.MockCatalogReaderSimple
- getOperatorTable() - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns the
SqlOperatorTable
to use. - getOperatorTable() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.LeafTraitRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.SingleNodeRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.ComboRuleTest.AddIntermediateNodeRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.ComboRuleTest.ComboRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.PlannerTests.GoodSingleRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.PlannerTests.PhysLeafRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.RandomSingleTraitRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.SingleLeafTraitRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.GoodRemoveSingleRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.PhysProjectRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.ReformedRemoveSingleRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.ReformedSingleRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.SubsetRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRule
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRule2
- getOutConvention() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysLeafRule
- getOutTrait() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRule
- getOutTrait() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRule2
- getParameters() - Method in class org.apache.calcite.test.UdfTest.ArrayAppendScalarFunction
- getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.tools.PlannerTest.MyCountAggFunction
- getParams() - Method in class org.apache.calcite.test.UdfTest.ArrayAppendDoubleFunction
- getParams() - Method in class org.apache.calcite.test.UdfTest.ArrayAppendIntegerFunction
- getParams() - Method in class org.apache.calcite.test.UdfTest.ArrayAppendScalarFunction
- getParserConfig() - Method in class org.apache.calcite.sql.test.SqlTestFactory
- getPigScript(RelNode, Schema) - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- getPlanner() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- getPlanner(List<RelTraitDef>, SqlParser.Config, SchemaPlus, SqlToRelConverter.Config, Program...) - Static method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- getPlanner(List<RelTraitDef>, SqlParser.Config, Program...) - Static method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- getPlanner(List<RelTraitDef>, SqlParser.Config, Program...) - Method in class org.apache.calcite.tools.PlannerTest
- getPlanner(List<RelTraitDef>, Program...) - Method in class org.apache.calcite.tools.PlannerTest
- getPrecedenceList() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getPrecision() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getQualifiedName() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getQualifiedName() - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getQualifiedName() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getQueryProvider() - Method in class org.apache.calcite.rex.RexExecutorTest.TestDataContext
- getQueryProvider() - Method in class org.apache.calcite.test.InterpreterTest.MyDataContext
- getQueryProvider() - Method in class org.apache.calcite.test.RexProgramBuilderBase.DummyTestDataContext
- getReferentialConstraints() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getReferentialConstraints() - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getReferentialConstraints() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getRelMetadataTimestamp(RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- getRelOptSchema() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getRelOptSchema() - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getRelOptSchema() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getRemoteConnection() - Static method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- getReservedKeywords() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- getResourceElement(Element, String) - Static method in class org.apache.calcite.test.DiffRepository
-
Returns a given resource from a given test case.
- getResourceElement(Element, String, boolean) - Static method in class org.apache.calcite.test.DiffRepository
-
Returns a given resource from a given test case.
- getResultType(String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- getResultType(String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
-
Returns the data type of the row returned by a SQL query.
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.test.UdfTest.ArrayAppendDoubleFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.test.UdfTest.ArrayAppendIntegerFunction
- getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.tools.PlannerTest.MyCountAggFunction
- getRoot() - Method in class org.apache.calcite.test.MockRelOptPlanner
- getRootPrefix() - Static method in class org.apache.calcite.util.SourceTest
- getRootSchema() - Method in class org.apache.calcite.rex.RexExecutorTest.TestDataContext
- getRootSchema() - Method in class org.apache.calcite.test.InterpreterTest.MyDataContext
- getRootSchema() - Method in class org.apache.calcite.test.RexProgramBuilderBase.DummyTestDataContext
- getRowCount() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getRowCount() - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getRowCount() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getRowList() - Static method in class org.apache.calcite.test.StreamTest.OrdersStreamTableFactory
- getRows() - Method in class org.apache.calcite.test.MockRelOptCost
- getRows(PreparedStatement) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- getRowType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- getRowType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- getRowType() - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- getRowType() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.adapter.generate.RangeTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableView
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.WrapperTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionWithAnyTypeTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.ScannableTableTest.BeatlesFilterableTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.ScannableTableTest.BeatlesProjectableFilterableTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.ScannableTableTest.BeatlesTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.ScannableTableTest.SimpleTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.StreamTest.BaseOrderStreamTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.StreamTest.ProductsTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.tools.FrameworksTest.TableImpl
- getRowType(RelDataTypeFactory) - Method in class org.apache.calcite.util.Smalls.MazeTable
- getRules() - Method in class org.apache.calcite.test.MockRelOptPlanner
- getSalesTables() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
-
Returns a list of the tables in the SALES schema.
- getScale() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getSelectKeywords() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- getSimpleBool(Random) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
- getSimpleInt(Random) - Method in class org.apache.calcite.test.fuzzer.RexFuzzer
- getSimpleName() - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationTraitDef
- getSimpleName() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.ConvertRelDistributionTraitDef
- getSimpleName() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitDef
- getSortedList() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- getSqlIdentifier() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getSqlParser(Reader) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- getSqlParser(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- getSqls() - Static method in class org.apache.calcite.test.FoodmartTest
- getSqlTypeName() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getStatement() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Obtains the thread's current JDBC statement.
- getStatistic() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.WrapperTable
- getStatistic() - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionTable
- getStatistic() - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionWithAnyTypeTable
- getStatistic() - Method in class org.apache.calcite.test.StreamTest.BaseOrderStreamTable
- getStatistic() - Method in class org.apache.calcite.test.StreamTest.ProductsTable
- getStatistic() - Method in class org.apache.calcite.tools.FrameworksTest.TableImpl
- getString(ImmutableMap<RexNode, RexNode>) - Static method in class org.apache.calcite.test.RexProgramTest
-
Converts a map to a string, sorting on the string representation of its keys.
- getStructKind() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getSupportedPreSetupCommands() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestPlugin
-
What commands are supported by this plugin before the setup section.
- getSupportedThreadCommands() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestPlugin
-
What commands are supported by this plugin within a thread or repeat section.
- getSupportedThreadCommands() - Method in class org.apache.calcite.test.concurrent.SamplePlugin
- getSynchronizer() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Retrieves the object used to synchronize threads at a point in the list of commands.
- getTable() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableView
- getTableForMember(List<String>) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- getTableForMember(List<String>, String, boolean[]) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- getTablePath() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableView
- getTestCaseElement(String, boolean, List<Pair<String, Element>>) - Method in class org.apache.calcite.test.DiffRepository
-
Returns the <TestCase> element corresponding to the current test case.
- getTester() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- getTester() - Method in class org.apache.calcite.sql.parser.SqlUnParserTest
- getTester() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- getTester() - Method in class org.apache.calcite.test.ServerUnParserTest
- getTester() - Method in class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler
- getTester() - Method in class org.apache.calcite.test.SqlValidatorDynamicTest
- getTester() - Method in class org.apache.calcite.test.SqlValidatorFeatureTest
- getTester() - Method in class org.apache.calcite.test.SqlValidatorTestCase
-
Returns a tester.
- getTesterWithDynamicTable() - Method in class org.apache.calcite.test.SqlToRelTestBase
- getTestlogRoot() - Method in class org.apache.calcite.test.DiffTestCase
- getText(Element) - Static method in class org.apache.calcite.test.DiffRepository
-
Returns the text under an element.
- getThreadId() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
- getThreadIds() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Returns a set of thread IDs.
- getThreadName(Integer) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Retrieves the name of a given thread.
- getThreadWriter(Integer) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Retrieves the output stream for the given thread id.
- getTraitClass() - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationTraitDef
- getTraitClass() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.ConvertRelDistributionTraitDef
- getTraitClass() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitDef
- getTraitDef() - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationImpl
- getTraitDef() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.SimpleDistribution
- getTraitDef() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- getTypeFactory() - Method in class org.apache.calcite.rex.RexExecutorTest.TestDataContext
- getTypeFactory() - Method in class org.apache.calcite.test.InterpreterTest.MyDataContext
- getTypeFactory() - Method in class org.apache.calcite.test.RexProgramBuilderBase.DummyTestDataContext
- getTypeFactory() - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- getTypeFactory() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- getTypes(RelDataTypeFactory) - Static method in class org.apache.calcite.test.SqlLimitsTest
-
Returns a list of typical types.
- getTypeString(RelDataType) - Static method in class org.apache.calcite.sql.test.SqlTests
-
Helper function to get the string representation of a RelDataType (include precision/scale but no charset or collation)
- getUrl() - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest.TempDb
-
Allocates a URL for a new Hsqldb database.
- getValidator() - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- getValidator() - Method in class org.apache.calcite.sql.test.SqlTestFactory
- getValidator() - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns the validator.
- getValidator() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- getValidator() - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
- getValues(BasicSqlType, boolean) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- getValueType() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- getVolcanoPlanner(RelNode) - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- GoodRemoveSingleRule() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTest.GoodRemoveSingleRule
- GoodSingleRule() - Constructor for class org.apache.calcite.plan.volcano.PlannerTests.GoodSingleRule
- greaterThan(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- greaterThanOrEqual(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- groupBy() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- groupingKeyExtractor() - Static method in class org.apache.calcite.linq4j.test.Linq4jTest
- groupMap - Variable in class org.apache.calcite.test.catalog.CompoundNameColumnResolver
- gt(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- gt(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
H
- H2 - org.apache.calcite.test.CalciteAssert.DatabaseInstance
- handleError(Throwable, String, ConcurrentTestCommand) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Handles details of an exception during execution.
- handler(boolean, int) - Static method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- HandlerDriver() - Constructor for class org.apache.calcite.test.JdbcTest.HandlerDriver
- HANDLERS - Static variable in class org.apache.calcite.test.JdbcTest.HandlerDriver
- hasDerivedColumnNames(int, String...) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- hasGit() - Static method in class org.apache.calcite.adapter.os.OsAdapterTest
-
Returns whether there is a ".git" directory in this directory or in a directory between this directory and root.
- hashCode() - Method in class org.apache.calcite.linq4j.test.Linq4jTest.Employee
- hashCode() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- hashCode() - Method in class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- hashCode() - Method in class org.apache.calcite.test.MockRelOptCost
- hashCode() - Method in class org.apache.calcite.util.graph.DirectedGraphTest.DefaultAttributedEdge
- hasMeasureNames(int, String...) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- hasNext() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator.TimedIterator
- hasTree(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches a
RelNode
its string representation, after converting Windows-style line endings ("\r\n") to Unix-style line endings ("\n"), is equal to the givenvalue
. - hasValidSynchronization() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Validates that all threads have the same number of SynchronizationCommands (otherwise a deadlock is guaranteed).
- hasWildcard(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ShellCommand
- hazNetwork() - Static method in class org.apache.calcite.adapter.file.FileSuite
- hepPlanner - Variable in class org.apache.calcite.test.RelOptTestBase.Sql
- HepPlannerTest - Class in org.apache.calcite.test
-
HepPlannerTest is a unit test for
HepPlanner
. - HepPlannerTest() - Constructor for class org.apache.calcite.test.HepPlannerTest
- HepPlannerTest.HepTestListener - Class in org.apache.calcite.test
-
Listener for HepPlannerTest; counts how many times rules fire.
- HepTestListener(long) - Constructor for class org.apache.calcite.test.HepPlannerTest.HepTestListener
- hireDate - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EmployeeWithHireDate
- HiveLikeTypeSystem() - Constructor for class org.apache.calcite.tools.FrameworksTest.HiveLikeTypeSystem
- HiveLikeTypeSystem2() - Constructor for class org.apache.calcite.tools.FrameworksTest.HiveLikeTypeSystem2
- hooks - Variable in class org.apache.calcite.test.CalciteAssert.AssertQuery
- hooks - Variable in class org.apache.calcite.test.RelOptTestBase.Sql
- hr() - Static method in class org.apache.calcite.test.CalciteAssert
-
Short-hand for
CalciteAssert.that().with(Config.REGULAR)
. - Hr() - Constructor for class org.apache.calcite.examples.foodmart.java.JdbcExample.Hr
- HR - org.apache.calcite.test.CalciteAssert.SchemaSpec
- HR_FKUK_MODEL - Static variable in class org.apache.calcite.test.MaterializationTest
- HR_FKUK_SCHEMA - Static variable in class org.apache.calcite.test.MaterializationTest
- HR_MODEL - Static variable in class org.apache.calcite.test.JdbcTest
- HR_SCHEMA - Static variable in class org.apache.calcite.test.JdbcTest
- HrFKUKSchema() - Constructor for class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- HrSchema() - Constructor for class org.apache.calcite.test.JdbcTest.HrSchema
- HSQLDB - org.apache.calcite.test.CalciteAssert.DatabaseInstance
- httpAddress() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
-
Returns current address to connect to with HTTP client.
- httpAddress() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
-
HTTP address for rest clients (can be ES native or any other).
- httpHost() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
I
- i - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- i - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- id - Variable in class org.apache.calcite.test.ExceptionMessageTest.Entry
- id - Variable in class org.apache.calcite.test.FoodMartQuerySet.FoodmartQuery
- id - Variable in class org.apache.calcite.test.MultiJdbcSchemaJoinTest.TempDb
- id - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.IntAndString
- Identity() - Constructor for class org.apache.calcite.linq4j.test.BlockBuilderTest.Identity
- ignorePatterns - Variable in class org.apache.calcite.test.DiffTestCase
- ImmutableBitSetTest - Class in org.apache.calcite.util
-
Unit test for
ImmutableBitSet
. - ImmutableBitSetTest() - Constructor for class org.apache.calcite.util.ImmutableBitSetTest
- impl - Variable in class org.apache.calcite.linq4j.test.LookupImplTest
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterMergedRel
- implement(EnumerableRelImplementor, EnumerableRel.Prefer) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRel
- implement(JdbcImplementor) - Method in class org.apache.calcite.tools.PlannerTest.MockJdbcTableScan
- in(RexNode, RexNode...) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Generates
x IN (y, z)
expression when called asin(x, y, z)
. - INCLUDE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- INCLUDE_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- INCURIOUS_PROFILER_FACTORY - Static variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- IndecisiveNumberNegater() - Constructor for class org.apache.calcite.util.ReflectVisitorTest.IndecisiveNumberNegater
- indent - Variable in class org.apache.calcite.test.DiffRepository
- indent() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- InduceGroupingTypeTest - Class in org.apache.calcite.test
-
Unit test for
Aggregate.Group.induce(ImmutableBitSet, List)
. - InduceGroupingTypeTest() - Constructor for class org.apache.calcite.test.InduceGroupingTypeTest
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.test.MockSqlOperatorTable.DedupFunction
- inferReturnType(SqlOperatorBinding) - Method in class org.apache.calcite.test.MockSqlOperatorTable.RampFunction
- INFINITE_STREAM_SCHEMA_NAME - Static variable in class org.apache.calcite.test.StreamTest
- InfiniteOrdersStreamTableFactory() - Constructor for class org.apache.calcite.test.StreamTest.InfiniteOrdersStreamTableFactory
- InfiniteOrdersTable() - Constructor for class org.apache.calcite.test.StreamTest.InfiniteOrdersTable
- inIde() - Static method in class org.apache.calcite.test.DiffTestCase
-
Returns whether this test is running inside the IntelliJ IDE.
- init() - Method in class org.apache.calcite.test.catalog.MockCatalogReader
-
Initializes this catalog reader.
- init() - Method in class org.apache.calcite.test.catalog.MockCatalogReaderDynamic
- init() - Method in class org.apache.calcite.test.catalog.MockCatalogReaderExtended
- init() - Method in class org.apache.calcite.test.catalog.MockCatalogReaderSimple
- init() - Method in interface org.apache.calcite.util.Smalls.MyGenericAggFunction
- init() - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- init() - Method in class org.apache.calcite.util.Smalls.MySum3
- init() - Method in class org.apache.calcite.util.Smalls.MySumFunction
- init() - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- init() - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- init() - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- init() - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- init() - Method in class org.apache.calcite.util.Smalls.SumFunctionBadIAdd
- initCassandraIfEnabled() - Static method in class org.apache.calcite.test.CassandraAdapterTest
- initializerFactory - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- InlinerTest - Class in org.apache.calcite.linq4j.test
-
Tests expression inlining in BlockBuilder.
- InlinerTest() - Constructor for class org.apache.calcite.linq4j.test.InlinerTest
- innerExecute() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- input(RelDataType, int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Generates input ref with given type and index.
- insertBulk(String, List<ObjectNode>) - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- InsertCommand(int, String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.InsertCommand
- insertDocument(String, ObjectNode) - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- instance() - Static method in class org.apache.calcite.test.FoodMartQuerySet
-
Returns the singleton instance of the query set.
- INSTANCE - Static variable in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysAggRule
- INSTANCE - Static variable in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysProjRule
- INSTANCE - Static variable in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysSortRule
- INSTANCE - Static variable in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysTableRule
- INSTANCE - Static variable in class org.apache.calcite.sql.test.SqlTestFactory
- INSTANCE - Static variable in class org.apache.calcite.test.MultiJdbcSchemaJoinTest.TempDb
- INSTANCE - Static variable in class org.apache.calcite.tools.FrameworksTest.HiveLikeTypeSystem
- INSTANCE_COUNT - Static variable in class org.apache.calcite.util.Smalls.MyDeterministicPlusFunction
- INSTANCE_COUNT - Static variable in class org.apache.calcite.util.Smalls.MyPlusFunction
- int_(String) - Static method in class org.apache.calcite.linq4j.test.BlockBuilderBase
- INT_VALUES - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- IntAndString(int, String) - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest.IntAndString
- integer - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.BadType
- integer(String) - Static method in class org.apache.calcite.linq4j.test.BlockBuilderBase
- INTEGER_TYPE_CHECKER - Static variable in class org.apache.calcite.sql.test.SqlTests
- integerCat() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
-
Group by number data type.
- integerDataType - Variable in class org.apache.calcite.test.SqlOperatorBindingTest
- integerType - Variable in class org.apache.calcite.test.SqlOperatorBindingTest
- IntermediateNode(RelOptCluster, RelNode, int) - Constructor for class org.apache.calcite.plan.volcano.ComboRuleTest.IntermediateNode
- InterpreterTest - Class in org.apache.calcite.test
-
Unit tests for
Interpreter
. - InterpreterTest() - Constructor for class org.apache.calcite.test.InterpreterTest
- InterpreterTest.MyDataContext - Class in org.apache.calcite.test
-
Implementation of
DataContext
for executing queries without a connection. - intersect(List<T>, List<T>) - Static method in class org.apache.calcite.runtime.EnumerablesTest
- IntHolder(int) - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest.IntHolder
- intRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- IntString(int, String) - Constructor for class org.apache.calcite.util.Smalls.IntString
- intType - Variable in class org.apache.calcite.test.catalog.Fixture
- intType - Variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- intTypeNull - Variable in class org.apache.calcite.test.catalog.Fixture
- INVALID_ARG_FOR_POWER - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- INVALID_CHAR_MESSAGE - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- INVALID_EXTRACT_UNIT_CONVERTLET_ERROR - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- INVALID_EXTRACT_UNIT_VALIDATION_ERROR - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- invalidCount - Variable in class org.apache.calcite.test.SqlToRelConverterTest.RelValidityChecker
- INVENTORY_LATTICE - Static variable in class org.apache.calcite.test.LatticeTest
- INVOC_DESC_DEJSONIZE - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_IS_JSON_ARRAY - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_IS_JSON_OBJECT - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_IS_JSON_SCALAR - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_IS_JSON_VALUE - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_API_COMMON_SYNTAX - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_ARRAY - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_ARRAY_AGG_ADD - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_EXISTS - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_OBJECT - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_OBJECT_AGG_ADD - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_QUERY - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_STRUCTURED_VALUE_EXPRESSION - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_VALUE_ANY - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSON_VALUE_EXPRESSION - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- INVOC_DESC_JSONIZE - Static variable in class org.apache.calcite.test.SqlJsonFunctionsTest
- invocationDesc(String, Object...) - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- isAtomic(Expression) - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- isBitSubset(int, int) - Static method in class org.apache.calcite.util.PartiallyOrderedSetTest
-
As an ordering, integers are ordered by bit inclusion.
- isBitSuperset(Integer, Integer) - Static method in class org.apache.calcite.util.PartiallyOrderedSetTest
-
As an ordering, integers are ordered by bit inclusion.
- isCaseSensitive() - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- isComment(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Identifies the start of a comment line; same rules as sqlline
- isConstant(Expression) - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- isDdl() - Static method in class org.apache.calcite.sql.parser.SqlParserTest
-
Returns a
Matcher
that succeeds if the givenSqlNode
is a DDL statement. - isDefined(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- isDisabled() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- isDistinctFrom(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isDivisor(int, int) - Static method in class org.apache.calcite.util.PartiallyOrderedSetTest
-
As an ordering, integers are ordered by division.
- isDivisorInverse(Integer, Integer) - Static method in class org.apache.calcite.util.PartiallyOrderedSetTest
-
As an ordering, bottom is 1, parents are primes, etc.
- isDynamicStruct() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- isEmpty() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- isEqWithEpsilon(RelOptCost) - Method in class org.apache.calcite.test.MockRelOptCost
- isFailureExpected() - Method in interface org.apache.calcite.test.concurrent.ConcurrentTestCommand
-
Returns true if the command should fail.
- isFailureExpected() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- isFalse(String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.OverlapChecker
- isFalse(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isFalse(RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- isGraphs(String...) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
-
Creates a matcher that matches query graphs to strings.
- isGuaranteed() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitConverterRule
- isInfinite() - Method in class org.apache.calcite.test.MockRelOptCost
- isIterable(Iterable<E>) - Static method in class org.apache.calcite.util.UtilTest
- isKey(ImmutableBitSet) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- isKey(ImmutableBitSet) - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- isKey(ImmutableBitSet) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- isLateDecorrelate() - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
- isLateDecorrelate() - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- isLe(RelOptCost) - Method in class org.apache.calcite.test.MockRelOptCost
- isLinux(String) - Static method in class org.apache.calcite.test.Matchers
-
Creates a Matcher that matches when the examined string is equal to the specified
value
when all Windows-style line endings ("\r\n") have been converted to Unix-style line endings ("\n"). - isLt(RelOptCost) - Method in class org.apache.calcite.test.MockRelOptCost
- isNotDistinctFrom(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isNotFalse(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isNotNull(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isNotNull(RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- isNotSubclass() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- isNotTrue(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isNull(RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- isNull(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isNullable() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- isNumeric(Class) - Static method in class org.apache.calcite.test.ReflectiveSchemaTest
- isRegistered(RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- isReserved(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Returns whether a word is reserved in this parser.
- isRolledUp(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.WrapperTable
- isRolledUp(String) - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionTable
- isRolledUp(String) - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionWithAnyTypeTable
- isRolledUp(String) - Method in class org.apache.calcite.test.StreamTest.BaseOrderStreamTable
- isRolledUp(String) - Method in class org.apache.calcite.test.StreamTest.OrdersTable
- isRolledUp(String) - Method in class org.apache.calcite.test.StreamTest.ProductsTable
- isSelect(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Determines whether a block of SQL is a SELECT statement.
- isStarted - Variable in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
- isStruct() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- isTestDisabled() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestPlugin
-
Should containing test be disabled?
- isTrue(String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.OverlapChecker
- isTrue(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isTrue(RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- isUnique(Set<ImmutableBitSet>, ImmutableBitSet) - Method in class org.apache.calcite.test.RelMetadataTest
-
Returns whether
keys
is unique, that is, whether it or a superset is inkeySets
. - isUnknown(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- isUnparserTest() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Whether this is a sub-class that tests un-parsing as well as parsing.
- isUnparserTest() - Method in class org.apache.calcite.sql.parser.SqlUnParserTest
- isUnparserTest() - Method in class org.apache.calcite.test.ServerUnParserTest
- isWhitespace(String) - Static method in class org.apache.calcite.test.DiffRepository
- isWindows() - Static method in class org.apache.calcite.adapter.os.OsAdapterTest
- isWithin(Object, Number, double) - Static method in class org.apache.calcite.test.Matchers.IsWithin
- IsWithin(T, double) - Constructor for class org.apache.calcite.test.Matchers.IsWithin
- iterator() - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest.TopN
- iterator() - Method in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- IterMergedRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterMergedRel
- IterSinglePhysMergeRule() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSinglePhysMergeRule
- IterSingleRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRel
- IterSingleRule() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRule
- IterSingleRule2() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRule2
J
- JAVA - org.apache.calcite.sql.test.SqlTester.VmName
- JAVA_VERSION - Static variable in class org.apache.calcite.util.TestUtil
- javaMajorVersionExceeds6() - Method in class org.apache.calcite.util.TestUtilTest
- jb - Variable in class org.apache.calcite.profile.ProfilerTest.Fluid.StatisticToJson
- JDBC_FOODMART - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates a connection to a MySQL server.
- JDBC_FOODMART - org.apache.calcite.test.CalciteAssert.SchemaSpec
- JDBC_FOODMART_WITH_LATTICE - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that contains an in-memory clone of the FoodMart database, plus a lattice to enable on-the-fly materializations.
- JDBC_FOODMART_WITH_LATTICE - org.apache.calcite.test.CalciteAssert.SchemaSpec
- JDBC_SCOTT - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates a connection to hsqldb containing the Scott schema via the JDBC adapter.
- JDBC_SCOTT - org.apache.calcite.test.CalciteAssert.SchemaSpec
- JdbcAdapterTest - Class in org.apache.calcite.test
-
Tests for the
org.apache.calcite.adapter.jdbc
package. - JdbcAdapterTest() - Constructor for class org.apache.calcite.test.JdbcAdapterTest
- JdbcAdapterTest.LockWrapper - Class in org.apache.calcite.test
-
Acquires a lock, and releases it when closed.
- JdbcExample - Class in org.apache.calcite.examples.foodmart.java
-
Example of using Calcite via JDBC.
- JdbcExample() - Constructor for class org.apache.calcite.examples.foodmart.java.JdbcExample
- JdbcExample.Employee - Class in org.apache.calcite.examples.foodmart.java
-
Object that will be used via reflection to create the "emps" table.
- JdbcExample.Foodmart - Class in org.apache.calcite.examples.foodmart.java
-
Object that will be used via reflection to create the "foodmart" schema.
- JdbcExample.Hr - Class in org.apache.calcite.examples.foodmart.java
-
Object that will be used via reflection to create the "hr" schema.
- JdbcExample.SalesFact - Class in org.apache.calcite.examples.foodmart.java
-
Object that will be used via reflection to create the "sales_fact_1997" fact table.
- JdbcFrontJdbcBackLinqMiddleTest - Class in org.apache.calcite.test
-
Tests for a JDBC front-end and JDBC back-end where the processing is not pushed down to JDBC (as in
JdbcFrontJdbcBackTest
) but is executed in a pipeline of linq4j operators. - JdbcFrontJdbcBackLinqMiddleTest() - Constructor for class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- JdbcFrontJdbcBackTest - Class in org.apache.calcite.test
-
Tests for a JDBC front-end and JDBC back-end.
- JdbcFrontJdbcBackTest() - Constructor for class org.apache.calcite.test.JdbcFrontJdbcBackTest
- JdbcFrontLinqBackTest - Class in org.apache.calcite.test
-
Tests for a JDBC front-end (with some quite complex SQL) and Linq4j back-end (based on in-memory collections).
- JdbcFrontLinqBackTest() - Constructor for class org.apache.calcite.test.JdbcFrontLinqBackTest
- jdbcProps - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
JDBC Connection properties.
- jdbcProps - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- JdbcTest - Class in org.apache.calcite.test
-
Tests for using Calcite via JDBC.
- JdbcTest() - Constructor for class org.apache.calcite.test.JdbcTest
- JdbcTest.AbstractModifiableTable - Class in org.apache.calcite.test
-
Abstract base class for implementations of
ModifiableTable
. - JdbcTest.AbstractModifiableView - Class in org.apache.calcite.test
-
Abstract base class for implementations of
ModifiableView
. - JdbcTest.AutoTempDriver - Class in org.apache.calcite.test
-
Mock driver that has a handler that stores the results of each query in a temporary table.
- JdbcTest.Customer - Class in org.apache.calcite.test
- JdbcTest.Department - Class in org.apache.calcite.test
- JdbcTest.Dependent - Class in org.apache.calcite.test
- JdbcTest.EmpDeptTableFactory - Class in org.apache.calcite.test
-
Factory for EMP and DEPT tables.
- JdbcTest.Employee - Class in org.apache.calcite.test
- JdbcTest.Event - Class in org.apache.calcite.test
- JdbcTest.FoodmartJdbcSchema - Class in org.apache.calcite.test
- JdbcTest.FoodmartSchema - Class in org.apache.calcite.test
- JdbcTest.HandlerDriver - Class in org.apache.calcite.test
-
Mock driver that a given
Handler
. - JdbcTest.HrSchema - Class in org.apache.calcite.test
- JdbcTest.LingualEmp - Class in org.apache.calcite.test
- JdbcTest.LingualSchema - Class in org.apache.calcite.test
- JdbcTest.Location - Class in org.apache.calcite.test
- JdbcTest.MockDdlDriver - Class in org.apache.calcite.test
-
Mock driver that can execute a trivial DDL statement.
- JdbcTest.MySchema - Class in org.apache.calcite.test
-
Schema containing dummy tables.
- JdbcTest.MySchemaFactory - Class in org.apache.calcite.test
-
Schema factory that creates
JdbcTest.MySchema
objects. - JdbcTest.MyTable - Class in org.apache.calcite.test
-
Dummy table.
- JdbcTest.MyTable2 - Class in org.apache.calcite.test
-
Another dummy table.
- JdbcTest.SalesFact - Class in org.apache.calcite.test
- jdbcURL - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
JDBC URL to connect with.
- jdbcURL - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- jethroDataSqlDialect() - Static method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- JOIN_KEYWORDS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- JsonLoader - Class in org.apache.calcite.adapter.geode.rel
-
Populates a geode region from a file having JSON entries (line by line).
- JsonLoader(Region<?, ?>) - Constructor for class org.apache.calcite.adapter.geode.rel.JsonLoader
- jsonPath(String) - Method in class org.apache.calcite.test.CsvTest
K
- keyList - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- keywords(String) - Static method in class org.apache.calcite.sql.parser.SqlParserTest
- kind - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
L
- l - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- l1(E) - Method in class org.apache.calcite.util.UtilTest
- l2(E, E) - Method in class org.apache.calcite.util.UtilTest
- l3(E, E, E) - Method in class org.apache.calcite.util.UtilTest
- label - Variable in class org.apache.calcite.plan.volcano.PlannerTests.TestLeafRel
- label - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestLeafRel
- labels - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- latitude - Variable in class org.apache.calcite.test.BookstoreSchema.Coordinate
- lattice - Variable in class org.apache.calcite.test.FoodMartLatticeStatisticProvider
- LatticeSuggesterTest - Class in org.apache.calcite.materialize
-
Unit tests for
LatticeSuggester
. - LatticeSuggesterTest() - Constructor for class org.apache.calcite.materialize.LatticeSuggesterTest
- LatticeSuggesterTest.Tester - Class in org.apache.calcite.materialize
-
Test helper.
- LatticeTest - Class in org.apache.calcite.test
-
Unit test for lattices.
- LatticeTest() - Constructor for class org.apache.calcite.test.LatticeTest
- launcher - Variable in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy
- le(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- le(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- LEAF_COLLATION - Static variable in class org.apache.calcite.plan.volcano.CollationConversionTest
- LeafRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.LeafRel
- LeafTraitRule() - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.LeafTraitRule
- LEFT_BRACKET - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- leftOuterJoinCorrelate() - Method in class org.apache.calcite.test.enumerable.EnumerableCorrelateTest
- lessThan(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- lessThanOrEqual(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- LexCaseSensitiveTest - Class in org.apache.calcite.sql.validate
-
Testing
SqlValidator
andLex
. - LexCaseSensitiveTest() - Constructor for class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- lg - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- limit - Variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- limit - Variable in class org.apache.calcite.test.CalciteAssert.AssertQuery
- limit(int) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- limit(int) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Sets a limit on the number of rows returned.
- limit2() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- LINE_BREAK - Static variable in class org.apache.calcite.util.TestUtil
- LINE_BREAK_PATTERN - Static variable in class org.apache.calcite.util.TestUtil
- LINE_COL_PATTERN - Static variable in class org.apache.calcite.sql.test.SqlTests
- LINE_COL_TWICE_PATTERN - Static variable in class org.apache.calcite.sql.test.SqlTests
- lines - Variable in class org.apache.calcite.test.BabelQuidemTest.ExplainValidatedCommand
- LINGUAL - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates a connection with an in-memory data set similar to the smoke test in Cascading Lingual.
- LINGUAL - org.apache.calcite.test.CalciteAssert.SchemaSpec
- LingualEmp(int, int) - Constructor for class org.apache.calcite.test.JdbcTest.LingualEmp
- LingualSchema() - Constructor for class org.apache.calcite.test.JdbcTest.LingualSchema
- LINQ4J_AS_ENUMERABLE_METHOD - Static variable in class org.apache.calcite.test.ReflectiveSchemaTest
- Linq4jExample - Class in com.example
-
Example using linq4j to query in-memory collections.
- Linq4jExample() - Constructor for class com.example.Linq4jExample
- Linq4jExample.Employee - Class in com.example
-
Employee.
- Linq4jSuite - Class in org.apache.calcite.linq4j.test
-
Suite of all Linq4j tests.
- Linq4jSuite() - Constructor for class org.apache.calcite.linq4j.test.Linq4jSuite
- Linq4jTest - Class in org.apache.calcite.linq4j.test
-
Tests for LINQ4J.
- Linq4jTest() - Constructor for class org.apache.calcite.linq4j.test.Linq4jTest
- Linq4jTest.Department - Class in org.apache.calcite.linq4j.test
-
Department.
- Linq4jTest.Employee - Class in org.apache.calcite.linq4j.test
-
Employee.
- LinqFrontJdbcBackTest - Class in org.apache.calcite.test
-
Tests for a linq4j front-end and JDBC back-end.
- LinqFrontJdbcBackTest() - Constructor for class org.apache.calcite.test.LinqFrontJdbcBackTest
- linux(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- LINUXIFY - Static variable in class org.apache.calcite.sql.parser.SqlParserTest
- list - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- list - Variable in class org.apache.calcite.util.graph.DirectedGraphTest.DefaultAttributedEdge
- list(String...) - Method in class org.apache.calcite.util.UtilTest
- list(String, String, int) - Static method in class org.apache.calcite.test.SqlValidatorTest
- list2(E[][]) - Static method in class org.apache.calcite.test.MaterializationTest
- list3(E[][][]) - Static method in class org.apache.calcite.test.MaterializationTest
- listOpTab - Variable in class org.apache.calcite.test.MockSqlOperatorTable
- literal(boolean) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- literal(int) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- literal(int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- literal(Boolean) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- literal(Integer) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- literal(String) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- literal(BigDecimal) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- literal(BigDecimal, RelDataType) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- literal(RelDataType, Object) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueType
- LITERAL_OUT_OF_RANGE_MESSAGE - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- LJS - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- load(Reader) - Method in class org.apache.calcite.adapter.geode.rel.JsonLoader
- load(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
-
Parses a multi-threaded script and converts it into test commands.
- loadClasspathResource(String) - Method in class org.apache.calcite.adapter.geode.rel.JsonLoader
- loadCommand(String, String, BufferedReader) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- loadDriverClass() - Method in class org.apache.calcite.test.SplunkAdapterTest
- loadMapList(List<Map<String, Object>>) - Method in class org.apache.calcite.adapter.geode.rel.JsonLoader
- loadSql(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- LOCAL_TZ - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- localConnection - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- LocalNode(Settings, Collection<Class<? extends Plugin>>) - Constructor for class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode.LocalNode
- LocalServiceModifiableFactory() - Constructor for class org.apache.calcite.jdbc.CalciteRemoteDriverTest.LocalServiceModifiableFactory
- LocalServiceMoreFactory() - Constructor for class org.apache.calcite.jdbc.CalciteRemoteDriverTest.LocalServiceMoreFactory
- location - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FailedThread
- location - Variable in class org.apache.calcite.test.JdbcTest.Department
- Location(int, int) - Constructor for class org.apache.calcite.test.JdbcTest.Location
- locations - Variable in class org.apache.calcite.test.JdbcTest.HrSchema
- locations - Variable in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- lock - Variable in class org.apache.calcite.test.JdbcAdapterTest.LockWrapper
- lock(Lock) - Static method in class org.apache.calcite.test.JdbcAdapterTest.LockWrapper
-
Acquires a lock and returns a closeable wrapper.
- LOCK - Static variable in class org.apache.calcite.test.JdbcAdapterTest
-
Ensures that tests that are modifying data (doing DML) do not run at the same time.
- LOCK - Static variable in class org.apache.calcite.test.RelMetadataTest
-
Ensures that tests that use a lot of memory do not run at the same time.
- lockstep - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- LOCKSTEP - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- LockWrapper(Lock) - Constructor for class org.apache.calcite.test.JdbcAdapterTest.LockWrapper
- logFile - Variable in class org.apache.calcite.test.DiffRepository
- logFile - Variable in class org.apache.calcite.test.DiffTestCase
-
Name of current .log file.
- LOGGER - Static variable in class org.apache.calcite.adapter.geode.rel.RelationalJdbcExample
- LOGGER - Static variable in class org.apache.calcite.adapter.geode.simple.SimpleJdbcExample
- LOGGER - Static variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- LOGGER - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- LOGGER - Static variable in class org.apache.calcite.test.SqlValidatorTest
- logOutputStream - Variable in class org.apache.calcite.test.DiffTestCase
-
OutputStream for current test log.
- longLiteral(long) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- longRelDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- longtitude - Variable in class org.apache.calcite.test.BookstoreSchema.Coordinate
- lookup(Class) - Static method in class org.apache.calcite.test.DiffRepository
-
Finds the repository instance for a given class, with no base repository or filter.
- lookup(Class, DiffRepository) - Static method in class org.apache.calcite.test.DiffRepository
-
Finds the repository instance for a given class and inheriting from a given repository.
- lookup(Class, DiffRepository, DiffRepository.Filter) - Static method in class org.apache.calcite.test.DiffRepository
-
Finds the repository instance for a given class.
- LookupImplTest - Class in org.apache.calcite.linq4j.test
-
Unit tests for LookupImpl.java
- LookupImplTest() - Constructor for class org.apache.calcite.linq4j.test.LookupImplTest
- LookupOperatorOverloadsTest - Class in org.apache.calcite.prepare
-
Test for lookupOperatorOverloads() in
CalciteCatalogReader
. - LookupOperatorOverloadsTest() - Constructor for class org.apache.calcite.prepare.LookupOperatorOverloadsTest
- lookupState(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
-
Manages state transitions.
- lt(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- lt(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
M
- main(String[]) - Static method in class com.example.Linq4jExample
- main(String[]) - Static method in class org.apache.calcite.adapter.geode.rel.RelationalJdbcExample
- main(String[]) - Static method in class org.apache.calcite.adapter.geode.simple.BookMasterRegionTest
- main(String[]) - Static method in class org.apache.calcite.adapter.geode.simple.SimpleJdbcExample
- main(String[]) - Static method in class org.apache.calcite.chinook.EndToEndTest
-
Runs a test from the command line.
- main(String[]) - Static method in class org.apache.calcite.examples.foodmart.java.JdbcExample
- main(String[]) - Static method in class org.apache.calcite.examples.RelBuilderExample
- main(String[]) - Static method in class org.apache.calcite.test.BabelQuidemTest
-
Runs a test from the command line.
- main(String[]) - Static method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Client tool that connects via jdbc and runs one or more mtsql on that connection.
- main(String[]) - Static method in class org.apache.calcite.test.CoreQuidemTest
-
Runs a test from the command line.
- main(String[]) - Static method in class org.apache.calcite.test.ServerQuidemTest
-
Runs a test from the command line.
- main(String[]) - Static method in class org.apache.calcite.test.SqlTestGen
- majorVersionFromString() - Method in class org.apache.calcite.util.TestUtilTest
- majorVersionFromString(String) - Static method in class org.apache.calcite.util.TestUtil
-
Detects java major version given long format of full JDK version.
- makeConnection() - Static method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- makeConnection() - Static method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Creates a connection with an empty modifiable table with
JdbcTest.Employee
schema. - makeConnection(List<JdbcTest.Employee>) - Static method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Method to be shared with
RemoteDriverTest
. - makeConsList(int, int) - Method in class org.apache.calcite.util.UtilTest
- makePostProcessor(List<JdbcTest.Employee>) - Static method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Creates the post processor routine to be applied against a Connection.
- map - Variable in class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- map - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- map - Variable in class org.apache.calcite.test.RexProgramBuilderBase.DummyTestDataContext
- MAP_CLASS_TO_REPOSITORY - Static variable in class org.apache.calcite.test.DiffRepository
-
Holds one diff-repository per class.
- MapConnectionFactory(ImmutableMap<String, String>, ImmutableList<CalciteAssert.ConnectionPostProcessor>) - Constructor for class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- mapper - Variable in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- mapper - Variable in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- mapper - Variable in class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
- mapper - Variable in class org.apache.calcite.adapter.geode.rel.JsonLoader
- mapper() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
-
Exposes Jackson API to be used to parse search results.
- mapper() - Method in class org.apache.calcite.test.ModelTest
- MAPPER - Static variable in class org.apache.calcite.test.ElasticsearchChecker
- mapping - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- MappingTest - Class in org.apache.calcite.util.mapping
-
Unit test for mappings.
- MappingTest() - Constructor for class org.apache.calcite.util.mapping.MappingTest
- mapToPdx(String, Map<String, Object>) - Method in class org.apache.calcite.adapter.geode.rel.JsonLoader
- markToFail() - Method in interface org.apache.calcite.test.concurrent.ConcurrentTestCommand
-
Set this command to expect a patternless failure.
- markToFail() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- markToFail(String, String) - Method in interface org.apache.calcite.test.concurrent.ConcurrentTestCommand
-
Marks a command to show that it is expected to fail, and indicates how.
- markToFail(String, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- match(RelOptRuleOperand, RelNode, List<RelNode>) - Method in class org.apache.calcite.test.MockRelOptPlanner
-
Matches a relational expression to a rule.
- matchAll() - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
- matcher - Variable in class org.apache.calcite.test.Matchers.ComposingMatcher
- Matchers - Class in org.apache.calcite.test
-
Matchers for testing SQL queries.
- Matchers() - Constructor for class org.apache.calcite.test.Matchers
- Matchers.ComposingMatcher<F,T> - Class in org.apache.calcite.test
-
Matcher that transforms the input value using a function before passing to another matcher.
- Matchers.IsWithin<T extends java.lang.Number> - Class in org.apache.calcite.test
-
Is the numeric value within a given difference another value?
- matches(Object) - Method in class org.apache.calcite.test.Matchers.IsWithin
- matches(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.ComboRuleTest.ComboRule
- matchesSafely(F) - Method in class org.apache.calcite.test.Matchers.ComposingMatcher
- matchesVarDefn - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- matchIgnorePatterns(String) - Method in class org.apache.calcite.test.DiffTestCase
- matchRecursive(RelNode, RelNode, int) - Method in class org.apache.calcite.test.MockRelOptPlanner
-
Recursively matches a rule.
- materializationsEnabled - Variable in class org.apache.calcite.test.CalciteAssert.AssertQuery
- MaterializationTest - Class in org.apache.calcite.test
-
Unit test for the materialized view rewrite mechanism.
- MaterializationTest() - Constructor for class org.apache.calcite.test.MaterializationTest
- MaterializationTest.HrFKUKSchema - Class in org.apache.calcite.test
-
Hr schema with FK-UK relationship.
- MaterializationTest.TableNameVisitor - Class in org.apache.calcite.test
-
Implementation of RelVisitor to extract substituted table names.
- matview() - Method in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- MAX_FAILURES - Static variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- MAX_FIELDS - Static variable in class org.apache.calcite.test.RexProgramBuilderBase
-
Input variables for tests should come from a struct type, so a struct is created where the first
MAX_FIELDS
are nullable, and the nextMAX_FIELDS
are not nullable. - MAX_NUMERIC_STRINGS - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- MAX_OVERFLOW_NUMERIC_STRINGS - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- MAX_VARS - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- MAZE_METHOD - Static variable in class org.apache.calcite.test.ExampleFunctionTest
- MAZE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- MAZE2_METHOD - Static variable in class org.apache.calcite.util.Smalls
- MAZE3_METHOD - Static variable in class org.apache.calcite.util.Smalls
- MazeTable(String) - Constructor for class org.apache.calcite.util.Smalls.MazeTable
- merge(int, int) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- merge(long, long) - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- merge(long, long) - Method in class org.apache.calcite.util.Smalls.MySumFunction
- merge(long, long) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- merge(long, long) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- merge(long, long) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- merge(A, A) - Method in interface org.apache.calcite.util.Smalls.MyGenericAggFunction
- merge(Integer, Integer) - Method in class org.apache.calcite.util.Smalls.MySum3
- metaData(Function<Connection, ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- metadataTimestamp - Variable in class org.apache.calcite.test.MockRelOptPlanner
- method - Variable in class org.apache.calcite.test.QuidemTest
- method(Object, String, Object[]) - Static method in class org.apache.calcite.test.CalciteAssert
-
Finds a non-static method based on its target, name and arguments.
- METHOD - Static variable in interface org.apache.calcite.test.RelMetadataTest.ColType
- millis - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.SleepCommand
- MIN_NUMERIC_STRINGS - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- MIN_OVERFLOW_NUMERIC_STRINGS - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- minus(RelOptCost) - Method in class org.apache.calcite.test.MockRelOptCost
- mismatchDescription(Matcher, Object) - Static method in class org.apache.calcite.util.UtilTest
- mm(int, int) - Method in class org.apache.calcite.test.JdbcTest
- MockCatalogReader - Class in org.apache.calcite.test.catalog
-
Mock implementation of
SqlValidatorCatalogReader
which returns tables "EMP", "DEPT", "BONUS", "SALGRADE" (same as Oracle's SCOTT schema). - MockCatalogReader(RelDataTypeFactory, boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader
-
Creates a MockCatalogReader.
- MockCatalogReader.ColumnResolver - Interface in org.apache.calcite.test.catalog
-
Column resolver
- MockCatalogReader.DelegateStructType - Class in org.apache.calcite.test.catalog
-
Struct type based on another struct type.
- MockCatalogReader.MockDynamicTable - Class in org.apache.calcite.test.catalog
-
Mock implementation of
Prepare.PreparingTable
with dynamic record type. - MockCatalogReader.MockModifiableViewRelOptTable - Class in org.apache.calcite.test.catalog
-
Alternative to MockViewTable that exercises code paths in ModifiableViewTable and ModifiableViewTableInitializerExpressionFactory.
- MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable - Class in org.apache.calcite.test.catalog
-
A mock of ModifiableViewTable that can unwrap a mock RelOptTable.
- MockCatalogReader.MockModifiableViewRelOptTable.MockViewTableMacro - Class in org.apache.calcite.test.catalog
-
A TableMacro that creates mock ModifiableViewTable.
- MockCatalogReader.MockSchema - Class in org.apache.calcite.test.catalog
-
Mock schema.
- MockCatalogReader.MockTable - Class in org.apache.calcite.test.catalog
-
Mock implementation of
Prepare.PreparingTable
. - MockCatalogReader.MockTable.ModifiableTable - Class in org.apache.calcite.test.catalog
-
Implementation of AbstractModifiableTable.
- MockCatalogReader.MockTable.ModifiableTableWithCustomColumnResolving - Class in org.apache.calcite.test.catalog
-
Subclass of
MockCatalogReader.MockTable.ModifiableTable
that also implementsCustomColumnResolvingTable
. - MockCatalogReader.MockViewTable - Class in org.apache.calcite.test.catalog
-
Mock implementation of
Prepare.PreparingTable
for views. - MockCatalogReader.MockViewTable.ModifiableView - Class in org.apache.calcite.test.catalog
-
Implementation of AbstractModifiableView.
- MockCatalogReader.MockViewTable.ModifiableViewWithCustomColumnResolving - Class in org.apache.calcite.test.catalog
-
Subclass of ModifiableView that also implements CustomColumnResolvingTable.
- MockCatalogReader.StreamableWrapperTable - Class in org.apache.calcite.test.catalog
-
Wrapper around a
MockCatalogReader.MockTable
, giving it aStreamableTable
interface. - MockCatalogReader.WrapperTable - Class in org.apache.calcite.test.catalog
-
Wrapper around a
MockCatalogReader.MockTable
, giving it aTable
interface. - MockCatalogReaderDynamic - Class in org.apache.calcite.test.catalog
-
Registers dynamic tables.
- MockCatalogReaderDynamic(RelDataTypeFactory, boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReaderDynamic
-
Creates a MockCatalogReader.
- MockCatalogReaderExtended - Class in org.apache.calcite.test.catalog
-
Adds some extra tables to the mock catalog.
- MockCatalogReaderExtended(RelDataTypeFactory, boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReaderExtended
-
Creates a MockCatalogReader.
- MockCatalogReaderSimple - Class in org.apache.calcite.test.catalog
-
Simple catalog reader for testing.
- MockCatalogReaderSimple(RelDataTypeFactory, boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReaderSimple
-
Creates a MockCatalogReader.
- MockColumnSet(List<String>, RelDataType, List<RelCollation>) - Constructor for class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- MockDdlDriver() - Constructor for class org.apache.calcite.test.JdbcTest.MockDdlDriver
- MockDynamicTable(MockCatalogReader, String, String, String, boolean, double) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockDynamicTable
- MockJdbcProjectRule(JdbcConvention) - Constructor for class org.apache.calcite.tools.PlannerTest.MockJdbcProjectRule
- MockJdbcTableRule(JdbcConvention) - Constructor for class org.apache.calcite.tools.PlannerTest.MockJdbcTableRule
- MockJdbcTableScan(RelOptCluster, RelOptTable, JdbcConvention) - Constructor for class org.apache.calcite.tools.PlannerTest.MockJdbcTableScan
- MockModifiableViewRelOptTable(MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable, MockCatalogReader, boolean, double, List<Map.Entry<String, RelDataType>>, List<Integer>, RelDataType, List<RelCollation>, List<String>, Set<String>, StructKind, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
-
Copy constructor.
- MockModifiableViewRelOptTable(MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable, MockCatalogReader, String, String, String, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- MockModifiableViewTable(Type, RelProtoDataType, String, List<String>, List<String>, Table, Path, RexNode, ImmutableIntList) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable
- MockRelOptCost - Class in org.apache.calcite.test
-
MockRelOptCost is a mock implementation of the
RelOptCost
interface. - MockRelOptCost() - Constructor for class org.apache.calcite.test.MockRelOptCost
- MockRelOptPlanner - Class in org.apache.calcite.test
-
MockRelOptPlanner is a mock implementation of the
RelOptPlanner
interface. - MockRelOptPlanner(Context) - Constructor for class org.apache.calcite.test.MockRelOptPlanner
-
Creates MockRelOptPlanner.
- MockRelOptPlanner.MockRuleCall - Class in org.apache.calcite.test
-
Mock call to a planner rule.
- MockRelOptSchema(SqlValidatorCatalogReader, RelDataTypeFactory) - Constructor for class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- MockRuleCall(RelOptPlanner, RelOptRuleOperand, RelNode[]) - Constructor for class org.apache.calcite.test.MockRelOptPlanner.MockRuleCall
-
Creates a MockRuleCall.
- MockSchema(String) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- MockSqlOperatorTable - Class in org.apache.calcite.test
-
Mock operator table for testing purposes.
- MockSqlOperatorTable(SqlOperatorTable) - Constructor for class org.apache.calcite.test.MockSqlOperatorTable
- MockSqlOperatorTable.DedupFunction - Class in org.apache.calcite.test
-
"DEDUP" user-defined function.
- MockSqlOperatorTable.RampFunction - Class in org.apache.calcite.test
-
"RAMP" user-defined function.
- MockTable(MockCatalogReader, boolean, double, List<Map.Entry<String, RelDataType>>, List<Integer>, RelDataType, List<RelCollation>, List<String>, Set<String>, StructKind, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
-
Copy constructor.
- MockTable(MockCatalogReader, String, String, String, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- MockTable(MockCatalogReader, List<String>, boolean, double, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- MockViewTable(MockCatalogReader, String, String, String, boolean, double, MockCatalogReader.MockTable, ImmutableIntList, MockCatalogReader.ColumnResolver, InitializerExpressionFactory) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- MockViewTableMacro(CalciteSchema, String, List<String>, List<String>, Boolean) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable.MockViewTableMacro
- model - Variable in class org.apache.calcite.adapter.file.SqlTest.Fluent
- model - Variable in class org.apache.calcite.test.CsvTest.Fluent
- model(String) - Static method in class org.apache.calcite.test.CalciteAssert
-
Short-hand for
CalciteAssert.that().with(Config.EMPTY).withModel(model)
. - MODEL - Static variable in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
Connection factory based on the "mongo-zips" model.
- MODEL - Static variable in class org.apache.calcite.test.PigAdapterTest
- ModelTest - Class in org.apache.calcite.test
-
Unit test for data models.
- ModelTest() - Constructor for class org.apache.calcite.test.ModelTest
- modelWithLattice(String, String, String...) - Static method in class org.apache.calcite.test.LatticeTest
- modelWithLattices(String...) - Static method in class org.apache.calcite.test.LatticeTest
- modelWithView(String, Boolean) - Method in class org.apache.calcite.test.JdbcTest
- ModifiableTable(String) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- ModifiableTableWithCustomColumnResolving(String) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTableWithCustomColumnResolving
- ModifiableView() - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableView
- modifiableViewTable - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- modifiableViewTable(CalcitePrepare.AnalyzeViewResult, String, List<String>, List<String>, CalciteSchema) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable.MockViewTableMacro
- ModifiableViewWithCustomColumnResolving() - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableViewWithCustomColumnResolving
- MongoAdapterIT - Class in org.apache.calcite.test
-
Used to trigger integration tests from maven (thus class name is suffixed with
IT
). - MongoAdapterIT() - Constructor for class org.apache.calcite.test.MongoAdapterIT
- MongoAdapterTest - Class in org.apache.calcite.adapter.mongodb
-
Testing mongo adapter functionality.
- MongoAdapterTest() - Constructor for class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- MongoAssertions - Class in org.apache.calcite.test
-
Util class which needs to be in the same package as
CalciteAssert
due to package-private visibility. - MongoAssertions() - Constructor for class org.apache.calcite.test.MongoAssertions
- mongoChecker(String...) - Static method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
Returns a function that checks that a particular MongoDB pipeline is generated to implement a query.
- MongoDatabasePolicy - Class in org.apache.calcite.adapter.mongodb
-
Instantiates a new connection to Fongo (or Mongo) database depending on the current profile (unit or integration tests).
- MongoDatabasePolicy(MongoClient) - Constructor for class org.apache.calcite.adapter.mongodb.MongoDatabasePolicy
- monotonic(SqlMonotonicity) - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- monotonicColumnSet - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- MOON - Static variable in class org.apache.calcite.rex.RexBuilderTest
- MOON_DAY - Static variable in class org.apache.calcite.rex.RexBuilderTest
- MOON_TIME - Static variable in class org.apache.calcite.rex.RexBuilderTest
- msg - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.EchoCommand
- mul(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- MultiJdbcSchemaJoinTest - Class in org.apache.calcite.test
-
Test case for joining tables from two different JDBC databases.
- MultiJdbcSchemaJoinTest() - Constructor for class org.apache.calcite.test.MultiJdbcSchemaJoinTest
- MultiJdbcSchemaJoinTest.TempDb - Class in org.apache.calcite.test
-
Pool of temporary databases.
- multiple() - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationTraitDef
- MultipleFunction() - Constructor for class org.apache.calcite.util.Smalls.MultipleFunction
- MULTIPLICATION_TABLE_METHOD - Static variable in class org.apache.calcite.util.Smalls
- multiplicationTable(int, int, Integer) - Static method in class org.apache.calcite.util.Smalls
-
A function that generates multiplication table of
ncol
columns xnrow
rows. - multiplyBy(double) - Method in class org.apache.calcite.test.MockRelOptCost
- multisetBigInt - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- multisetFloat - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- mutable(String, List<JdbcTest.Employee>) - Static method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- mutable(List<JdbcTest.Employee>) - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- MutableRelTest - Class in org.apache.calcite.test
-
Tests for
MutableRel
sub-classes. - MutableRelTest() - Constructor for class org.apache.calcite.test.MutableRelTest
- MyAbcdeFunction() - Constructor for class org.apache.calcite.util.Smalls.MyAbcdeFunction
- MyCountAggFunction() - Constructor for class org.apache.calcite.tools.PlannerTest.MyCountAggFunction
- MyDataContext(Planner) - Constructor for class org.apache.calcite.test.InterpreterTest.MyDataContext
- MyDeterministicPlusFunction() - Constructor for class org.apache.calcite.util.Smalls.MyDeterministicPlusFunction
- MyDoubleFunction() - Constructor for class org.apache.calcite.util.Smalls.MyDoubleFunction
- MyEnum() - Constructor for enum org.apache.calcite.linq4j.test.ExpressionTest.MyEnum
- myEnumerable(int[], int) - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- MyIncrement() - Constructor for class org.apache.calcite.util.Smalls.MyIncrement
- MyInvocationHandler() - Constructor for class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler.MyInvocationHandler
- mykey - Variable in class org.apache.calcite.test.JdbcTest.MyTable
- mykey - Variable in class org.apache.calcite.test.JdbcTest.MyTable2
- MyLeftFunction() - Constructor for class org.apache.calcite.util.Smalls.MyLeftFunction
- MyPlusFunction() - Constructor for class org.apache.calcite.util.Smalls.MyPlusFunction
- MyRel(RelOptCluster, RelTraitSet) - Constructor for class org.apache.calcite.plan.RelOptPlanReaderTest.MyRel
- MyRelMetadataQuery() - Constructor for class org.apache.calcite.test.RelMetadataTest.MyRelMetadataQuery
- MySchema() - Constructor for class org.apache.calcite.test.JdbcTest.MySchema
- MySchemaFactory() - Constructor for class org.apache.calcite.test.JdbcTest.MySchemaFactory
- MYSQL - org.apache.calcite.test.CalciteAssert.DatabaseInstance
- mySqlDialect(NullCollation) - Static method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- MyStaticSumFunction() - Constructor for class org.apache.calcite.util.Smalls.MyStaticSumFunction
- MySum3() - Constructor for class org.apache.calcite.util.Smalls.MySum3
- MySumFunction() - Constructor for class org.apache.calcite.util.Smalls.MySumFunction
- mytable - Variable in class org.apache.calcite.test.JdbcTest.MySchema
- MyTable() - Constructor for class org.apache.calcite.test.JdbcTest.MyTable
- mytable2 - Variable in class org.apache.calcite.test.JdbcTest.MySchema
- MyTable2() - Constructor for class org.apache.calcite.test.JdbcTest.MyTable2
- MyTableFunction() - Constructor for class org.apache.calcite.util.Smalls.MyTableFunction
- MyThreeParamsSumFunctionWithFilter1() - Constructor for class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- MyThreeParamsSumFunctionWithFilter2() - Constructor for class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- MyToStringFunction() - Constructor for class org.apache.calcite.util.Smalls.MyToStringFunction
- MyTwoParamsSumFunctionFilter1() - Constructor for class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- MyTwoParamsSumFunctionFilter2() - Constructor for class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- myvalue - Variable in class org.apache.calcite.test.JdbcTest.MyTable
- myvalue - Variable in class org.apache.calcite.test.JdbcTest.MyTable2
N
- n - Variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest.TopN
- n - Variable in class org.apache.calcite.util.Smalls.IntString
- n2u(String) - Static method in class org.apache.calcite.test.QuidemTest
- name - Variable in class com.example.Linq4jExample.Employee
- name - Variable in class org.apache.calcite.examples.foodmart.java.JdbcExample.Employee
- name - Variable in class org.apache.calcite.linq4j.test.Linq4jTest.Department
- name - Variable in class org.apache.calcite.linq4j.test.Linq4jTest.Employee
- name - Variable in class org.apache.calcite.plan.volcano.TraitConversionTest.SimpleDistribution
- name - Variable in class org.apache.calcite.runtime.EnumerablesTest.Dept
- name - Variable in class org.apache.calcite.runtime.EnumerablesTest.Emp
- name - Variable in class org.apache.calcite.test.BookstoreSchema.Author
- name - Variable in class org.apache.calcite.test.CalciteAssert.AddSchemaPostProcessor
- name - Variable in class org.apache.calcite.test.CalciteAssert.DefaultSchemaPostProcessor
- name - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- name - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FailedThread
- name - Variable in class org.apache.calcite.test.ExceptionMessageTest.Entry
- name - Variable in class org.apache.calcite.test.FoodMartQuerySet.FoodmartColumn
- name - Variable in class org.apache.calcite.test.JdbcTest.Department
- name - Variable in class org.apache.calcite.test.JdbcTest.Dependent
- name - Variable in class org.apache.calcite.test.JdbcTest.Employee
- name - Variable in class RootEmployee
- NAME - Static variable in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- NAME - Static variable in class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
- NAME - Static variable in class org.apache.calcite.adapter.elasticsearch.Projection2Test
- NAME - Static variable in class org.apache.calcite.adapter.elasticsearch.ProjectionTest
- NAME - Static variable in class org.apache.calcite.adapter.elasticsearch.ScrollingTest
- nameMap - Variable in class org.apache.calcite.test.catalog.CompoundNameColumnResolver
- nameMatcher() - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- names - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- names - Variable in class org.apache.calcite.test.MaterializationTest.TableNameVisitor
- names - Variable in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- ncols - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- ne(RexNode, RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- ne(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- negate(Number) - Method in class org.apache.calcite.util.ReflectVisitorTest.NumberNegater
-
Negates the given number.
- negateWithoutDispatcher(Number) - Method in class org.apache.calcite.util.ReflectVisitorTest.NumberNegater
-
Negates the given number without using a dispatcher object to cache applicable methods.
- nestedCalls(RexNode) - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- NestedCollectionTable() - Constructor for class org.apache.calcite.test.CollectionTypeTest.NestedCollectionTable
- NestedCollectionWithAnyTypeTable() - Constructor for class org.apache.calcite.test.CollectionTypeTest.NestedCollectionWithAnyTypeTable
- nestedRecordsEnumerator() - Static method in class org.apache.calcite.test.CollectionTypeTest
- NEW_TRAIT_DEF_INSTANCE - Static variable in class org.apache.calcite.plan.volcano.TraitConversionTest
- newAttributeInitializer(RelDataType, SqlFunction, int, List<RexNode>, InitializerContext) - Method in class org.apache.calcite.test.catalog.CountingFactory
- newCluster(VolcanoPlanner) - Static method in class org.apache.calcite.plan.volcano.PlannerTests
- newColumnDefaultValue(RelOptTable, int, InitializerContext) - Method in class org.apache.calcite.test.catalog.CountingFactory
- newColumnDefaultValue(RelOptTable, int, InitializerContext) - Method in class org.apache.calcite.test.catalog.EmpInitializerExpressionFactory
- newConnectionFactory() - Method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- newConnectionFactory() - Method in class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
- newConnectionFactory() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- newConnectionFactory() - Method in class org.apache.calcite.adapter.elasticsearch.Projection2Test
- newConnectionFactory() - Method in class org.apache.calcite.adapter.elasticsearch.ProjectionTest
- newConnectionFactory() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- newConnectionFactory() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- newConnectionFactory() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- newConnectionFactory(int) - Method in class org.apache.calcite.adapter.elasticsearch.ScrollingTest
- newlineList(Collection) - Static method in class org.apache.calcite.test.CalciteAssert
- newSchema(String, String, Table) - Method in class org.apache.calcite.test.ScannableTableTest
- next() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator.TimedIterator
- nextThreadId - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- NL - Static variable in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- NL - Static variable in class org.apache.calcite.test.SqlToRelTestBase
- NO_EXPAND_CONFIG - Static variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- node - Variable in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
- node - Variable in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
- node - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueType
- node - Variable in class org.apache.calcite.test.fuzzer.SimplifyTask
- node(String) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
-
Parses a query returns its graph.
- node(String) - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
-
Parses a query returns its graph.
- node(Matcher<SqlNode>) - Method in class org.apache.calcite.sql.parser.SqlParserTest.Sql
- NODE - Static variable in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- NODE - Static variable in class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
- NODE - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- NODE - Static variable in class org.apache.calcite.adapter.elasticsearch.Projection2Test
- NODE - Static variable in class org.apache.calcite.adapter.elasticsearch.ProjectionTest
- NODE - Static variable in class org.apache.calcite.adapter.elasticsearch.ScrollingTest
- nodeCount(RexNode) - Static method in class org.apache.calcite.test.RexProgramTest
-
Returns the number of nodes (including leaves) in a Rex tree.
- nodesBelowCount - Variable in class org.apache.calcite.plan.volcano.ComboRuleTest.IntermediateNode
- nodeToString(RexNode) - Static method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- NOLOCKSTEP - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- nonDeterministic(int) - Static method in class org.apache.calcite.linq4j.test.DeterministicTest.TestClass
- nonDeterministic(int) - Static method in class org.apache.calcite.linq4j.test.DeterministicTest.TestDeterministicClass
- NONDETERMINISTIC_OP - Static variable in class org.apache.calcite.test.RelMetadataTest
- NoneLeafRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.NoneLeafRel
- NoneLeafRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.PlannerTests.NoneLeafRel
- NoneLeafRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.NoneLeafRel
- NoneLeafRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.NoneLeafRel
- NoneSingleRel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.NoneSingleRel
- NoneSingleRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.NoneSingleRel
- NoneSingleRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.PlannerTests.NoneSingleRel
- NoneSingleRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.NoneSingleRel
- NoneSingleRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.NoneSingleRel
- nonNullableBool - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- nonNullableInt - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- nonNullableVarchar - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- nonStatic(int) - Method in class org.apache.calcite.util.Smalls.MultipleFunction
- NopAssertQuery(String) - Constructor for class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- not(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- not(RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- NOT_STRONG_EXPR - Static variable in class org.apache.calcite.test.RelOptRulesTest
- notDistinct() - Method in class org.apache.calcite.test.RexProgramTest
- notEquals(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- notExpression() - Method in class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
-
Tests negations (
NOT
operator). - notNull(RexNode) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- notOperator() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
-
Testing
NOT
operator - nth - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrintCommand
- nth - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- NULL - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- null_(RelDataType) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates null literal with given type.
- NULL_INTEGER - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- Null4Function() - Constructor for class org.apache.calcite.util.Smalls.Null4Function
- Null8Function() - Constructor for class org.apache.calcite.util.Smalls.Null8Function
- nullable(RelDataType) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- nullableBool - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- nullableInt - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- nullableIntType - Variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- nullables - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- nullableVarchar - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- nullBool - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- nullIf(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- nullInt - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- nullVarchar - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- number(String) - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest
- NumberNegater() - Constructor for class org.apache.calcite.util.ReflectVisitorTest.NumberNegater
- NUMERIC_TO_NUMERIC - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- NUMERIC_TYPE_NAMES - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- numericFields() - Static method in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- numThreads - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor.Sync
- numWaiting - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor.Sync
O
- o - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- of(String) - Static method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
-
Returns an implementation of
CalciteAssert.AssertQuery
that does nothing. - offer(E) - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest.TopN
- ok() - Method in class org.apache.calcite.adapter.file.SqlTest.Fluent
-
Runs the test.
- ok() - Method in class org.apache.calcite.test.CsvTest.Fluent
-
Runs the test.
- ok() - Method in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- ok() - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- ok(String) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- ok(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.Sql
- ONE - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- ONE_SELECTOR - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- oneThreePlus(String) - Static method in class org.apache.calcite.util.Smalls
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.LeafTraitRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.CollationConversionTest.SingleNodeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.ComboRuleTest.AddIntermediateNodeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.ComboRuleTest.ComboRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.PlannerTests.GoodSingleRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.PlannerTests.PhysLeafRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.RandomSingleTraitRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.SingleLeafTraitRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysAggRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysProjRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysTableRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.GoodRemoveSingleRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.PhysProjectRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.ReformedRemoveSingleRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.ReformedSingleRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.SubsetRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSinglePhysMergeRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRule
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.IterSingleRule2
- onMatch(RelOptRuleCall) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysLeafRule
- onRegister(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockDynamicTable
- onRegister(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- onRegister(RelDataTypeFactory) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- op - Variable in class org.apache.calcite.sql.parser.SqlParserTest.Checker
- OP_METHODS - Static variable in class org.apache.calcite.test.fuzzer.RexToTestCodeShuttle
- openTestLog() - Method in class org.apache.calcite.test.DiffTestCase
-
Initializes a diff-based test.
- openTestLogOutputStream(File) - Method in class org.apache.calcite.test.DiffTestCase
-
Initializes a diff-based test, overriding the default log file naming scheme altogether.
- operatorTable - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- opTab - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- optimize(Expression) - Static method in class org.apache.calcite.linq4j.test.BlockBuilderBase
- optimize(Statement) - Static method in class org.apache.calcite.linq4j.test.BlockBuilderBase
- optimize(RuleSet, RelOptPlanner) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- optimizeExpression(Expression) - Static method in class org.apache.calcite.linq4j.test.BlockBuilderBase
- OptimizerTest - Class in org.apache.calcite.linq4j.test
-
Unit test for
BlockBuilder
optimization capabilities. - OptimizerTest() - Constructor for class org.apache.calcite.linq4j.test.OptimizerTest
- optimizeStatement(Statement) - Static method in class org.apache.calcite.linq4j.test.BlockBuilderBase
- optimizeWithVolcano(RelNode) - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- options - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- or(Iterable<? extends RexNode>) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- or(RexNode...) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- or(RexNode...) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- or(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- ORACLE - org.apache.calcite.test.CalciteAssert.DatabaseInstance
- oracleTester() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- oracleTester(SqlConformance) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- order - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- ORDER_KEYWORDS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- ORDERING - Static variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- OrdersHistoryTable(ImmutableList<Object[]>) - Constructor for class org.apache.calcite.test.StreamTest.OrdersHistoryTable
- OrdersStreamTableFactory() - Constructor for class org.apache.calcite.test.StreamTest.OrdersStreamTableFactory
- OrdersTable(ImmutableList<Object[]>) - Constructor for class org.apache.calcite.test.StreamTest.OrdersTable
- ordinal - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- org.apache.calcite.adapter.clone - package org.apache.calcite.adapter.clone
- org.apache.calcite.adapter.druid - package org.apache.calcite.adapter.druid
- org.apache.calcite.adapter.elasticsearch - package org.apache.calcite.adapter.elasticsearch
- org.apache.calcite.adapter.file - package org.apache.calcite.adapter.file
-
Query provider that reads from files and web pages in various formats.
- org.apache.calcite.adapter.generate - package org.apache.calcite.adapter.generate
- org.apache.calcite.adapter.geode.rel - package org.apache.calcite.adapter.geode.rel
- org.apache.calcite.adapter.geode.simple - package org.apache.calcite.adapter.geode.simple
- org.apache.calcite.adapter.mongodb - package org.apache.calcite.adapter.mongodb
- org.apache.calcite.adapter.os - package org.apache.calcite.adapter.os
- org.apache.calcite.adapter.tpcds - package org.apache.calcite.adapter.tpcds
- org.apache.calcite.adapter.tpch - package org.apache.calcite.adapter.tpch
- org.apache.calcite.chinook - package org.apache.calcite.chinook
- org.apache.calcite.examples - package org.apache.calcite.examples
- org.apache.calcite.examples.foodmart.java - package org.apache.calcite.examples.foodmart.java
- org.apache.calcite.jdbc - package org.apache.calcite.jdbc
- org.apache.calcite.linq4j.function - package org.apache.calcite.linq4j.function
-
Tests for functions.
- org.apache.calcite.linq4j.test - package org.apache.calcite.linq4j.test
-
Core linq4j tests.
- org.apache.calcite.linq4j.tree - package org.apache.calcite.linq4j.tree
-
Tests for expressions.
- org.apache.calcite.materialize - package org.apache.calcite.materialize
- org.apache.calcite.plan - package org.apache.calcite.plan
- org.apache.calcite.plan.volcano - package org.apache.calcite.plan.volcano
- org.apache.calcite.prepare - package org.apache.calcite.prepare
- org.apache.calcite.profile - package org.apache.calcite.profile
- org.apache.calcite.rel - package org.apache.calcite.rel
- org.apache.calcite.rel.rel2sql - package org.apache.calcite.rel.rel2sql
- org.apache.calcite.rel.rules - package org.apache.calcite.rel.rules
- org.apache.calcite.rex - package org.apache.calcite.rex
- org.apache.calcite.runtime - package org.apache.calcite.runtime
- org.apache.calcite.sql - package org.apache.calcite.sql
- org.apache.calcite.sql.parser - package org.apache.calcite.sql.parser
- org.apache.calcite.sql.test - package org.apache.calcite.sql.test
-
Regression tests for the SQL model.
- org.apache.calcite.sql.type - package org.apache.calcite.sql.type
- org.apache.calcite.sql.validate - package org.apache.calcite.sql.validate
- org.apache.calcite.test - package org.apache.calcite.test
-
Tests for Calcite.
- org.apache.calcite.test.catalog - package org.apache.calcite.test.catalog
- org.apache.calcite.test.concurrent - package org.apache.calcite.test.concurrent
-
A framework for concurrent JDBC unit tests.
- org.apache.calcite.test.enumerable - package org.apache.calcite.test.enumerable
-
Tests for Enumerable convention runtime.
- org.apache.calcite.test.fuzzer - package org.apache.calcite.test.fuzzer
- org.apache.calcite.tools - package org.apache.calcite.tools
- org.apache.calcite.util - package org.apache.calcite.util
- org.apache.calcite.util.graph - package org.apache.calcite.util.graph
- org.apache.calcite.util.mapping - package org.apache.calcite.util.mapping
- ORINOCO - org.apache.calcite.test.CalciteAssert.SchemaSpec
- OsAdapterTest - Class in org.apache.calcite.adapter.os
-
Unit tests for the OS (operating system) adapter.
- OsAdapterTest() - Constructor for class org.apache.calcite.adapter.os.OsAdapterTest
- out - Variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- out - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- OUT_OF_RANGE_MESSAGE - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- output(ResultSet) - Method in class org.apache.calcite.test.CsvTest
- output(ResultSet, PrintStream) - Method in class org.apache.calcite.test.CsvTest
- OverlapChecker(String...) - Constructor for class org.apache.calcite.sql.test.SqlOperatorBaseTest.OverlapChecker
P
- p(int) - Static method in class org.apache.calcite.tools.TpchSchema
- pad(String) - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- Page(int, String) - Constructor for class org.apache.calcite.test.BookstoreSchema.Page
- pageNo - Variable in class org.apache.calcite.test.BookstoreSchema.Page
- pages - Variable in class org.apache.calcite.test.BookstoreSchema.Book
- PAIR_SELECTOR - Static variable in class org.apache.calcite.linq4j.test.Linq4jTest
- parent - Variable in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- parse(String) - Method in class org.apache.calcite.sql.SqlSetOptionOperatorTest
- PARSE - org.apache.calcite.sql.test.SqlTests.Stage
- parseAndValidate(SqlValidator, String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- parseAndValidate(SqlValidator, String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
- parseCommand(String[]) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- parseCommand(List<String>, List<String>, String) - Method in class org.apache.calcite.test.BabelQuidemTest.BabelCommandHandler
- parseContains(String) - Method in class org.apache.calcite.test.Fluent
- parseExpected(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
-
Parses expected values.
- parseExpressionAndHandleEx(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- parseProgram(String) - Method in class org.apache.calcite.test.Fluent
- parseQuery(String) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- parseQuery(String) - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
-
Parses a SQL query.
- parseQuery(String) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
- parseQuery(String) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- parseQuery(String) - Method in interface org.apache.calcite.test.SqlValidatorTestCase.Tester
- parserConfig - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- parserImplFactory() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Implementors of custom parsing logic who want to reuse this test should override this method with the factory for their extension parser.
- parserImplFactory() - Method in class org.apache.calcite.test.BabelParserTest
- parserImplFactory() - Method in class org.apache.calcite.test.ServerParserTest
- parseStmtAndHandleEx(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- part - Variable in class org.apache.calcite.tools.TpchSchema
- Part(int) - Constructor for class org.apache.calcite.tools.TpchSchema.Part
- PartialColTypeImpl() - Constructor for class org.apache.calcite.test.RelMetadataTest.PartialColTypeImpl
- PartiallyOrderedSetTest - Class in org.apache.calcite.util
-
Unit test for
PartiallyOrderedSet
. - PartiallyOrderedSetTest() - Constructor for class org.apache.calcite.util.PartiallyOrderedSetTest
- partsupp - Variable in class org.apache.calcite.tools.TpchSchema
- PartSupp(int, int) - Constructor for class org.apache.calcite.tools.TpchSchema.PartSupp
- password - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- password - Variable in class org.apache.calcite.test.ConnectionSpec
- path - Variable in class org.apache.calcite.test.QuidemTest
- paths(DirectedGraph<V, DefaultEdge>, V, V) - Method in class org.apache.calcite.util.graph.DirectedGraphTest
- pattern - Variable in class org.apache.calcite.sql.test.SqlTests.PatternResultChecker
- PatternResultChecker(Pattern) - Constructor for class org.apache.calcite.sql.test.SqlTests.PatternResultChecker
- patterns - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ExceptionResultChecker
- patterns - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueOrExceptionResultChecker
- period - Variable in class org.apache.calcite.sql.parser.SqlParserTest.Checker
- PermutationTestCase - Class in org.apache.calcite.util
-
Unit test for
Permutation
. - PermutationTestCase() - Constructor for class org.apache.calcite.util.PermutationTestCase
- PHYS_CALLING_CONVENTION - Static variable in class org.apache.calcite.plan.volcano.PlannerTests
-
Private calling convention representing a physical implementation.
- PHYS_CALLING_CONVENTION - Static variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
-
Private calling convention representing a generic "physical" calling convention.
- PhysAgg(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysAgg
- PhysAggRule() - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysAggRule
- PHYSICAL - Static variable in class org.apache.calcite.plan.volcano.TraitPropagationTest
- PhysicalSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.PhysicalSort
- PhysLeafRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.PlannerTests.PhysLeafRel
- PhysLeafRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysLeafRel
- PhysLeafRule() - Constructor for class org.apache.calcite.plan.volcano.PlannerTests.PhysLeafRule
- PhysLeafRule() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysLeafRule
- PhysProj(RelOptCluster, RelTraitSet, RelNode, List<RexNode>, RelDataType) - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysProj
- PhysProjectRule() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTest.PhysProjectRule
- PhysProjRule(boolean) - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysProjRule
- PhysSingleRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.PlannerTests.PhysSingleRel
- PhysSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysSort
- PhysSortRule() - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysSortRule
- PhysTable(RelOptCluster) - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysTable
- PhysTableRule() - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysTableRule
- PhysToIteratorConverter(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTest.PhysToIteratorConverter
- PhysToIteratorConverter(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysToIteratorConverter
- PhysToIteratorConverterRule() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.PhysToIteratorConverterRule
- pig - Variable in class org.apache.calcite.test.Fluent
- pig(String) - Static method in class org.apache.calcite.test.PigletTest
- PigAdapterTest - Class in org.apache.calcite.test
-
Tests for the
org.apache.calcite.adapter.pig
package. - PigAdapterTest() - Constructor for class org.apache.calcite.test.PigAdapterTest
- PigletTest - Class in org.apache.calcite.test
-
Unit tests for Piglet.
- PigletTest() - Constructor for class org.apache.calcite.test.PigletTest
- PigRelBuilderStyleTest - Class in org.apache.calcite.test
-
Tests for the
org.apache.calcite.adapter.pig
package that tests the building ofPigRel
relational expressions usingRelBuilder
and associated factories inPigRelFactories
. - PigRelBuilderStyleTest() - Constructor for class org.apache.calcite.test.PigRelBuilderStyleTest
- PigRelBuilderTest - Class in org.apache.calcite.test
-
Unit test for
PigRelBuilder
. - PigRelBuilderTest() - Constructor for class org.apache.calcite.test.PigRelBuilderTest
- pigScriptChecker(String...) - Static method in class org.apache.calcite.test.PigAdapterTest
-
Returns a function that checks that a particular Pig Latin scriptis generated to implement a query.
- Place(BookstoreSchema.Coordinate, String, String) - Constructor for class org.apache.calcite.test.BookstoreSchema.Place
- plan - Variable in class org.apache.calcite.test.CalciteAssert.AssertQuery
- planContains(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- planContains(String) - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- planHasSql(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- planHasSql(String) - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- planner - Variable in class org.apache.calcite.test.InterpreterTest.MyDataContext
- planner - Variable in class org.apache.calcite.test.InterpreterTest
- planner - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- PlannerTest - Class in org.apache.calcite.tools
-
Unit tests for
Planner
. - PlannerTest() - Constructor for class org.apache.calcite.tools.PlannerTest
- PlannerTest.MockJdbcProjectRule - Class in org.apache.calcite.tools
-
Rule to convert a
EnumerableProject
to anJdbcRules.JdbcProject
. - PlannerTest.MockJdbcTableRule - Class in org.apache.calcite.tools
-
Rule to convert a
EnumerableTableScan
to anPlannerTest.MockJdbcTableScan
. - PlannerTest.MockJdbcTableScan - Class in org.apache.calcite.tools
-
Relational expression representing a "mock" scan of a table in a JDBC data source.
- PlannerTest.MyCountAggFunction - Class in org.apache.calcite.tools
-
User-defined aggregate function.
- PlannerTests - Class in org.apache.calcite.plan.volcano
-
Common classes and utility methods for Volcano planner tests.
- PlannerTests() - Constructor for class org.apache.calcite.plan.volcano.PlannerTests
- PlannerTests.GoodSingleRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that matches a
PlannerTests.NoneSingleRel
and succeeds. - PlannerTests.NoneLeafRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with zero inputs and convention NONE.
- PlannerTests.NoneSingleRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with one input and convention NONE.
- PlannerTests.PhysLeafRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with zero inputs and convention PHYS.
- PlannerTests.PhysLeafRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that converts
PlannerTests.NoneLeafRel
to PHYS convention. - PlannerTests.PhysSingleRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with one input and convention PHYS.
- PlannerTests.TestLeafRel - Class in org.apache.calcite.plan.volcano
-
Leaf relational expression.
- PlannerTests.TestSingleRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with one input.
- planUpdateHasSql(String, int) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- planUpdateHasSql(String, int) - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- plugin(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- PLUGIN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- PLUGIN_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- pluginCommand - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PluginCommand
- PluginCommand(String, String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PluginCommand
- pluginForCommand - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- plugins - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- plus(List<T>...) - Static method in class org.apache.calcite.sql.test.SqlAdvisorTest
-
Concatenates several lists of the same type into a single list.
- plus(RelOptCost) - Method in class org.apache.calcite.test.MockRelOptCost
- plus(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- plus(RexNode, RexNode) - Method in class org.apache.calcite.test.RexTransformerTest
- PLUS_RANDOM - Static variable in class org.apache.calcite.rex.RexExecutorTest
- PlusSuite - Class in org.apache.calcite.test
-
Suite consisting of all tests in the
calcite-plus
module. - PlusSuite() - Constructor for class org.apache.calcite.test.PlusSuite
- policy - Variable in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy.RefCountPolicy
- POLICY - Static variable in class org.apache.calcite.adapter.geode.rel.AbstractGeodeTest
- POLICY - Static variable in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- pooled() - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Returns a version that uses a single connection, as opposed to creating a new one each time a test method is invoked.
- PoolingConnectionFactory(CalciteAssert.ConnectionFactory) - Constructor for class org.apache.calcite.test.CalciteAssert.PoolingConnectionFactory
- populate(MongoCollection<Document>, URL) - Static method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- POST - org.apache.calcite.test.CalciteAssert.SchemaSpec
- POST_CLEANUP_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- POST_SETUP_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- POST_THREAD_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- postExecute(ConcurrentTestCommandExecutor[]) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- POSTGRESQL - org.apache.calcite.test.CalciteAssert.DatabaseInstance
- postProcessors - Variable in class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- pPartkey - Variable in class org.apache.calcite.tools.TpchSchema.Part
- PRE_SETUP_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- prec(SqlOperator) - Static method in class org.apache.calcite.test.SqlValidatorTest
- PrecedenceClimbingParserTest - Class in org.apache.calcite.util
-
Unit test for
PrecedenceClimbingParser
. - PrecedenceClimbingParserTest() - Constructor for class org.apache.calcite.util.PrecedenceClimbingParserTest
- predicate - Variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- predicate(String) - Method in class org.apache.calcite.test.JdbcTest
- PREDICATE_KEYWORDS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- PREFIX - Static variable in class org.apache.calcite.test.catalog.MockCatalogReader
- prefixEmps - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- prepare(String, List<String>) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Gets ready to execute: loads script FILENAME applying external variable BINDINGS
- PREPARE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- PREPARE_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- prepareBuilder() - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest
- prepareBuilder() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- PrepareCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.PrepareCommand
- PrepareCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrepareCommand
- prepareFormat(ResultSet) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- preProgram - Variable in class org.apache.calcite.test.RelOptTestBase.Sql
- preSetupFor(String, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestPlugin
-
Do pre-setup action for given command and parameters.
- preSetupPluginForCommand - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- primes - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- primesBoxed - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- primesCustomBoxed - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.CatchallSchema
- primitiveBoolean - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- primitiveByte - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- primitiveChar - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- primitiveDouble - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- primitiveFloat - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- primitiveInt - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- primitiveLong - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- primitiveShort - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- PrimitiveTest - Class in org.apache.calcite.linq4j.test
-
Unit test for
Primitive
. - PrimitiveTest() - Constructor for class org.apache.calcite.linq4j.test.PrimitiveTest
- PRINT - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- PRINT_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- PrintCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrintCommand
- printCommands(PrintStream, Integer) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Prints a description of the commands to be executed for a given thread.
- printCommands(PrintStream, Integer) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator
-
Outputs command sequence and notes how long the sequence will be repeated.
- printHeaders() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- printLimit(PrintWriter, String, RelDataType, boolean, SqlTypeName.Limit, boolean) - Method in class org.apache.calcite.test.SqlLimitsTest
- printResults(PrintWriter) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- printRow(String[]) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
-
Prints an output table row.
- printRowCount(int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- printSeparator() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
-
Prints an output table separator.
- printThreadResults(PrintWriter, String[]) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- printTimestamp(long) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- printValidate(PartiallyOrderedSet<E>) - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- PROCESS_CURSOR_METHOD - Static variable in class org.apache.calcite.util.Smalls
- PROCESS_CURSORS_METHOD - Static variable in class org.apache.calcite.util.Smalls
- processCursor(int, Enumerable<Object[]>) - Static method in class org.apache.calcite.util.Smalls
-
A function that adds a number to the first column of input cursor
- processCursors(int, Enumerable<Object[]>, Enumerable<Smalls.IntString>) - Static method in class org.apache.calcite.util.Smalls
-
A function that sums the second column of first input cursor, second column of first input and the given int.
- prod - Variable in class org.apache.calcite.util.Smalls.WideSaleSchema
- prod_id - Variable in class org.apache.calcite.examples.foodmart.java.JdbcExample.SalesFact
- prod_id - Variable in class org.apache.calcite.test.JdbcTest.SalesFact
- prodId - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- productSet - Variable in class org.apache.calcite.test.BabelQuidemTest.ExplainValidatedCommand
- ProductsTable(ImmutableList<Object[]>) - Constructor for class org.apache.calcite.test.StreamTest.ProductsTable
- ProductsTableFactory() - Constructor for class org.apache.calcite.test.StreamTest.ProductsTableFactory
- PROFILER_FACTORY - Static variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- ProfilerTest - Class in org.apache.calcite.profile
-
Unit tests for
Profiler
. - ProfilerTest() - Constructor for class org.apache.calcite.profile.ProfilerTest
- ProfilerTest.Fluid - Class in org.apache.calcite.profile
-
Fluid interface for writing profiler test cases.
- ProfilerTest.Fluid.StatisticToJson - Class in org.apache.calcite.profile
-
Returns a function that converts a statistic to a JSON string.
- project(List<String>) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- projection() - Method in class org.apache.calcite.adapter.elasticsearch.Projection2Test
- projection() - Method in class org.apache.calcite.adapter.elasticsearch.ProjectionTest
- projection2() - Method in class org.apache.calcite.adapter.elasticsearch.Projection2Test
- Projection2Test - Class in org.apache.calcite.adapter.elasticsearch
-
Checks renaming of fields (also upper, lower cases) during projections
- Projection2Test() - Constructor for class org.apache.calcite.adapter.elasticsearch.Projection2Test
- ProjectionTest - Class in org.apache.calcite.adapter.elasticsearch
-
Checks renaming of fields (also upper, lower cases) during projections
- ProjectionTest() - Constructor for class org.apache.calcite.adapter.elasticsearch.ProjectionTest
- PropAction() - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest.PropAction
- propBuilder() - Static method in class org.apache.calcite.test.CalciteAssert
-
Returns a
CalciteAssert.PropBuilder
. - PropBuilder() - Constructor for class org.apache.calcite.test.CalciteAssert.PropBuilder
- properties - Variable in class org.apache.calcite.test.CalciteAssert.PropBuilder
- protoRowType - Variable in class org.apache.calcite.test.StreamTest.BaseOrderStreamTable
- protoRowType - Variable in class org.apache.calcite.test.StreamTest.ProductsTable
- ps(int, int) - Static method in class org.apache.calcite.tools.TpchSchema
- psPartkey - Variable in class org.apache.calcite.tools.TpchSchema.PartSupp
- psSupplyCost - Variable in class org.apache.calcite.tools.TpchSchema.PartSupp
- publishYear - Variable in class org.apache.calcite.test.BookstoreSchema.Book
- pushBindParameters() - Method in class org.apache.calcite.test.JdbcAdapterTest
- pv(StringBuilder, String, String) - Method in class org.apache.calcite.test.JdbcTest
- pw - Variable in class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler
Q
- q(String) - Static method in class org.apache.calcite.test.JdbcTest
- QUANTIFIERS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- queries - Variable in class org.apache.calcite.test.FoodMartQuerySet.FoodmartRoot
- queries - Variable in class org.apache.calcite.test.FoodMartQuerySet
- QUERIES - Static variable in class org.apache.calcite.adapter.tpch.TpchTest
- QUERIES - Static variable in class org.apache.calcite.test.JdbcTest
- querify(String[]) - Static method in class org.apache.calcite.test.JdbcTest
-
Returns a list of (query, expected) pairs.
- query - Variable in class org.apache.calcite.test.FoodmartTest
- query(int, Boolean) - Method in class org.apache.calcite.adapter.tpch.TpchTest
-
Runs with query #i.
- query(String) - Static method in class org.apache.calcite.adapter.geode.rel.GeodeAssertions
- query(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- QueryBuildersTest - Class in org.apache.calcite.adapter.elasticsearch
-
Check that internal queries are correctly converted to ES search query (as JSON)
- QueryBuildersTest() - Constructor for class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
- queryContains(Function<List, Void>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Deprecated.
- queryContains(Consumer<List>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Runs the query and applies a checker to the generated third-party queries.
- queryContains(Consumer<List>) - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- queue - Variable in class org.apache.calcite.test.CsvTest.Worker
-
Queue of commands.
- QuidemConnectionFactory() - Constructor for class org.apache.calcite.test.QuidemTest.QuidemConnectionFactory
- QuidemTest - Class in org.apache.calcite.test
-
Test that runs every Quidem file as a test.
- QuidemTest(String) - Constructor for class org.apache.calcite.test.QuidemTest
-
Creates a QuidemTest.
- QuidemTest.QuidemConnectionFactory - Class in org.apache.calcite.test
-
Quidem connection factory for Calcite's built-in test schemas.
- quiet - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- quiet - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- quotedCasing - Variable in class org.apache.calcite.sql.parser.SqlParserTest
- quoteForJava(String) - Static method in class org.apache.calcite.util.TestUtil
-
Converts a string (which may contain quotes and newlines) into a java literal.
- quotePattern(String) - Static method in class org.apache.calcite.util.TestUtil
-
Quotes a pattern.
- quoting - Variable in class org.apache.calcite.sql.parser.SqlParserTest
R
- RampFunction() - Constructor for class org.apache.calcite.test.MockSqlOperatorTable.RampFunction
- random - Variable in class org.apache.calcite.util.PartiallyOrderedSetTest
- random(Random, int, int) - Static method in class org.apache.calcite.util.PartiallyOrderedSetTest
- RandomSingleRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.RandomSingleRel
- RandomSingleTraitRule() - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.RandomSingleTraitRule
- range() - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
- range(int, int) - Method in class org.apache.calcite.test.CsvTest
- range(int, int) - Static method in class org.apache.calcite.util.PartiallyOrderedSetTest
- RangeTable - Class in org.apache.calcite.adapter.generate
-
Table that returns a range of integers.
- RangeTable(Class<?>, String, int, int) - Constructor for class org.apache.calcite.adapter.generate.RangeTable
- RangeTable.Factory - Class in org.apache.calcite.adapter.generate
-
Implementation of
TableFactory
that allows aRangeTable
to be included as a custom table in a Calcite model file. - rcs0 - Variable in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- read(ResultSet, long) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- readLine(String, BufferedReader) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
-
Returns an input line, possible extended by the continuation character (\).
- readSql(String, BufferedReader) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
-
Returns a block of SQL, starting with the given String.
- recordEvent(RelOptListener.RelEvent) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- rectilinearCoordType - Variable in class org.apache.calcite.test.catalog.Fixture
- rectilinearPeekCoordType - Variable in class org.apache.calcite.test.catalog.Fixture
- rectilinearPeekNoExpandCoordType - Variable in class org.apache.calcite.test.catalog.Fixture
- ref - Static variable in class org.apache.calcite.test.FoodMartQuerySet
- ref(int, RelDataType) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- ref(String, List<Pair<String, Element>>) - Method in class org.apache.calcite.test.DiffRepository
- refCount - Variable in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy.RefCountPolicy
- RefCountPolicy(GeodeEmbeddedPolicy) - Constructor for class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy.RefCountPolicy
- referentialConstraints - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- refFile - Variable in class org.apache.calcite.test.DiffTestCase
-
Name of current .ref file.
- REFLECTIVE_FOODMART - org.apache.calcite.test.CalciteAssert.SchemaSpec
- ReflectiveSchemaTest - Class in org.apache.calcite.test
-
Unit tests for
ReflectiveSchema
. - ReflectiveSchemaTest() - Constructor for class org.apache.calcite.test.ReflectiveSchemaTest
- ReflectiveSchemaTest.AllPrivate - Class in org.apache.calcite.test
-
All field are private, therefore the resulting record has no fields.
- ReflectiveSchemaTest.BadType - Class in org.apache.calcite.test
-
Table that has a field that cannot be recognized as a SQL type.
- ReflectiveSchemaTest.CatchallSchema - Class in org.apache.calcite.test
-
Object whose fields are relations.
- ReflectiveSchemaTest.DateColumnSchema - Class in org.apache.calcite.test
-
Schema that contains a table with a date column.
- ReflectiveSchemaTest.EmployeeWithHireDate - Class in org.apache.calcite.test
-
Extension to
JdbcTest.Employee
with ahireDate
column. - ReflectiveSchemaTest.EveryType - Class in org.apache.calcite.test
-
Record that has a field of every interesting type.
- ReflectiveSchemaTest.IntAndString - Class in org.apache.calcite.test
-
Table that has integer and string fields
- ReflectiveSchemaTest.IntHolder - Class in org.apache.calcite.test
-
Custom java class that holds just a single field.
- ReflectVisitorTest - Class in org.apache.calcite.util
-
ReflectVisitorTest tests
ReflectUtil.invokeVisitor(org.apache.calcite.util.ReflectiveVisitor, java.lang.Object, java.lang.Class, java.lang.String)
andReflectiveVisitor
and provides a contrived example of how to use them. - ReflectVisitorTest() - Constructor for class org.apache.calcite.util.ReflectVisitorTest
- ReflectVisitorTest.AmbiguousNumber - Class in org.apache.calcite.util
-
A class inheriting two interfaces, leading to ambiguity.
- ReflectVisitorTest.CarefulNumberNegater - Class in org.apache.calcite.util
-
CarefulNumberNegater implements NumberNegater in a careful fashion by providing overloads for each known subclass of Number and returning the same subclass for the result.
- ReflectVisitorTest.CarelessNumberNegater - Class in org.apache.calcite.util
-
CarelessNumberNegater implements NumberNegater in a careless fashion by converting its input to a double and then negating that.
- ReflectVisitorTest.CluelessNumberNegater - Class in org.apache.calcite.util
-
CluelessNumberNegater implements NumberNegater in a very broken fashion; does the right thing for Shorts, but attempts to override visit(Object).
- ReflectVisitorTest.CrunchableNumber - Interface in org.apache.calcite.util
-
An interface for introducing ambiguity into the class hierarchy.
- ReflectVisitorTest.DiceyNumber - Interface in org.apache.calcite.util
-
Sub-interface of
ReflectVisitorTest.FudgeableNumber
. - ReflectVisitorTest.FudgeableNumber - Interface in org.apache.calcite.util
-
An interface for introducing ambiguity into the class hierarchy.
- ReflectVisitorTest.IndecisiveNumberNegater - Class in org.apache.calcite.util
-
IndecisiveNumberNegater implements NumberNegater in such a way that it doesn't know what to do when presented with an AmbiguousNumber.
- ReflectVisitorTest.NumberNegater - Class in org.apache.calcite.util
-
NumberNegater defines the abstract base for a computation object capable of negating an arbitrary number.
- ReflectVisitorTest.SomewhatAmbiguousNumber - Class in org.apache.calcite.util
-
A class inheriting a root interface (FudgeableNumber) two different ways, which should not lead to ambiguity in some cases.
- ReflectVisitorTest.SomewhatIndecisiveNumberNegater - Class in org.apache.calcite.util
-
SomewhatIndecisiveNumberNegater implements NumberNegater in such a way that it knows what to do when presented with a SomewhatAmbiguousNumber.
- ReformedRemoveSingleRule() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTest.ReformedRemoveSingleRule
- ReformedSingleRule() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTest.ReformedSingleRule
- RefSetResultChecker(Set<String>) - Constructor for class org.apache.calcite.sql.test.SqlTests.RefSetResultChecker
- region - Variable in class org.apache.calcite.adapter.geode.rel.JsonLoader
- register(RelOptPlanner) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.SimpleDistribution
- register(RelOptPlanner) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- register(RelOptPlanner) - Method in class org.apache.calcite.tools.PlannerTest.MockJdbcTableScan
- register(RelNode, RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- registerConverterRule(RelOptPlanner, ConverterRule) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitDef
- registerNestedSchema(MockCatalogReader.MockSchema, MockCatalogReader.MockSchema) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- registerRolledUpColumn(String) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- registerRules(RelOptPlanner) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- registerSchema(MockCatalogReader.MockSchema) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- registerTable(List<String>, Table) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- registerTable(MockCatalogReader.MockTable) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- registerTablesWithRollUp(MockCatalogReader.MockSchema, Fixture) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- registerType(List<String>, RelProtoDataType) - Method in class org.apache.calcite.test.catalog.MockCatalogReader
- REGULAR - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that creates a connection with two in-memory data sets:
JdbcTest.HrSchema
andJdbcTest.FoodmartSchema
. - REGULAR_PLUS_METADATA - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that includes the metadata schema.
- REL_BUILDER - Static variable in class org.apache.calcite.plan.RelOptUtilTest
- RelationalJdbcExample - Class in org.apache.calcite.adapter.geode.rel
-
Example of using Geode via JDBC.
- RelationalJdbcExample() - Constructor for class org.apache.calcite.adapter.geode.rel.RelationalJdbcExample
- relBuilder() - Static method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
Creates a RelBuilder.
- RelBuilderExample - Class in org.apache.calcite.examples
-
Example that uses
RelBuilder
to create various relational expressions. - RelBuilderExample(boolean) - Constructor for class org.apache.calcite.examples.RelBuilderExample
- RelBuilderTest - Class in org.apache.calcite.test
-
Unit test for
RelBuilder
. - RelBuilderTest() - Constructor for class org.apache.calcite.test.RelBuilderTest
- relChosen(RelOptListener.RelChosenEvent) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- relChosen(RelOptListener.RelChosenEvent) - Method in class org.apache.calcite.test.HepPlannerTest.HepTestListener
- RelCollationTest - Class in org.apache.calcite.rel
-
Tests for
RelCollation
andRelFieldCollation
. - RelCollationTest() - Constructor for class org.apache.calcite.rel.RelCollationTest
- relDiscarded(RelOptListener.RelDiscardedEvent) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- relDiscarded(RelOptListener.RelDiscardedEvent) - Method in class org.apache.calcite.test.HepPlannerTest.HepTestListener
- RelDistributionTest - Class in org.apache.calcite.rel
-
Tests for
RelDistribution
. - RelDistributionTest() - Constructor for class org.apache.calcite.rel.RelDistributionTest
- relEquivalenceFound(RelOptListener.RelEquivalenceEvent) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- relEquivalenceFound(RelOptListener.RelEquivalenceEvent) - Method in class org.apache.calcite.test.HepPlannerTest.HepTestListener
- RelMdColumnOriginsTest - Class in org.apache.calcite.test
-
Test case for CALCITE-542.
- RelMdColumnOriginsTest() - Constructor for class org.apache.calcite.test.RelMdColumnOriginsTest
- RelMetadataTest - Class in org.apache.calcite.test
-
Unit test for
DefaultRelMetadataProvider
. - RelMetadataTest() - Constructor for class org.apache.calcite.test.RelMetadataTest
- RelMetadataTest.BrokenColTypeImpl - Class in org.apache.calcite.test
-
Implementation of
RelMetadataTest.ColType
that has no fall-back forRelNode
. - RelMetadataTest.ColType - Interface in org.apache.calcite.test
-
Custom metadata interface.
- RelMetadataTest.ColType.Handler - Interface in org.apache.calcite.test
-
Handler API.
- RelMetadataTest.ColTypeImpl - Class in org.apache.calcite.test
-
A provider for
RelMetadataTest.ColType
via reflection. - RelMetadataTest.DummyRelNode - Class in org.apache.calcite.test
-
Dummy rel node used for testing.
- RelMetadataTest.MyRelMetadataQuery - Class in org.apache.calcite.test
-
Extension to
RelMetadataQuery
to supportRelMetadataTest.ColType
. - RelMetadataTest.PartialColTypeImpl - Class in org.apache.calcite.test
-
A provider for
RelMetadataTest.ColType
via reflection. - RelOptPlanReaderTest - Class in org.apache.calcite.plan
-
Unit test for
RelJson
. - RelOptPlanReaderTest() - Constructor for class org.apache.calcite.plan.RelOptPlanReaderTest
- RelOptPlanReaderTest.MyRel - Class in org.apache.calcite.plan
-
Dummy relational expression.
- RelOptRulesTest - Class in org.apache.calcite.test
-
Unit test for rules in
org.apache.calcite.rel
and subpackages. - RelOptRulesTest() - Constructor for class org.apache.calcite.test.RelOptRulesTest
- RelOptTestBase - Class in org.apache.calcite.test
-
RelOptTestBase is an abstract base for tests which exercise a planner and/or rules via
DiffRepository
. - RelOptTestBase() - Constructor for class org.apache.calcite.test.RelOptTestBase
- RelOptTestBase.Sql - Class in org.apache.calcite.test
-
Allows fluent testing.
- RelOptUtilTest - Class in org.apache.calcite.plan
-
Unit test for
RelOptUtil
and other classes in this package. - RelOptUtilTest() - Constructor for class org.apache.calcite.plan.RelOptUtilTest
- RelToSqlConverterStructsTest - Class in org.apache.calcite.rel.rel2sql
-
Tests for
RelToSqlConverter
on a schema that has nested structures of multiple levels. - RelToSqlConverterStructsTest() - Constructor for class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- RelToSqlConverterTest - Class in org.apache.calcite.rel.rel2sql
-
Tests for
RelToSqlConverter
. - RelToSqlConverterTest() - Constructor for class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- RelToSqlConverterTest.Sql - Class in org.apache.calcite.rel.rel2sql
-
Fluid interface to run tests.
- RelTraitTest - Class in org.apache.calcite.plan
-
Test to verify
RelCompositeTrait
. - RelTraitTest() - Constructor for class org.apache.calcite.plan.RelTraitTest
- RelValidityChecker() - Constructor for class org.apache.calcite.test.SqlToRelConverterTest.RelValidityChecker
- RelWriterTest - Class in org.apache.calcite.plan
-
Unit test for
RelJson
. - RelWriterTest() - Constructor for class org.apache.calcite.plan.RelWriterTest
- rememberVariableRebindings(List<String>) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- REMOTE_CONNECTION_FACTORY - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- RemotePreparedStatementParametersTest - Class in org.apache.calcite.chinook
-
Tests against parameters in prepared statement when using underlying jdbc subschema
- RemotePreparedStatementParametersTest() - Constructor for class org.apache.calcite.chinook.RemotePreparedStatementParametersTest
- remove() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator.TimedIterator
- removeAllChildren(Element) - Static method in class org.apache.calcite.test.DiffRepository
- removeRedundantCast() - Method in class org.apache.calcite.test.RexProgramTest
- removeRule(RelOptRule) - Method in class org.apache.calcite.test.MockRelOptPlanner
- removeTrivialProject(boolean) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
- rep(int) - Static method in class org.apache.calcite.sql.test.SqlTests
- REPEAT - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- REPEAT_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- REPEAT_READ_AHEAD_LIMIT - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- REPEAT_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- repeatCount - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- replaceQuotes(SqlParser.Config, String) - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- reportError(String, String, int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- requiresCustomErrorHandling() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Indicates whether commands generated by this generator require special handling.
- requiresCustomErrorHandling() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Causes errors to be send here for custom handling.
- requireStatus(AbstractLauncher.Status) - Method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy
- RESERVED_KEYWORDS - Static variable in class org.apache.calcite.sql.parser.SqlParserTest
-
List of reserved keywords.
- resolveColumn(RelDataType, RelDataTypeFactory, List<String>) - Method in class org.apache.calcite.test.catalog.CompoundNameColumnResolver
- resolveColumn(RelDataType, RelDataTypeFactory, List<String>) - Method in interface org.apache.calcite.test.catalog.MockCatalogReader.ColumnResolver
- resolveColumn(RelDataType, RelDataTypeFactory, List<String>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTableWithCustomColumnResolving
- resolveColumn(RelDataType, RelDataTypeFactory, List<String>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableViewWithCustomColumnResolving
- resolver - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- RESOURCE_NAME_ATTR - Static variable in class org.apache.calcite.test.DiffRepository
- RESOURCE_TAG - Static variable in class org.apache.calcite.test.DiffRepository
- resourcePath(String) - Static method in class org.apache.calcite.adapter.file.FileReaderTest
- resourcePath(String) - Method in class org.apache.calcite.test.CsvTest
- restClient() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchPolicy
-
Low-level http rest client connected to current embedded elastic search instance.
- result - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- result - Variable in class org.apache.calcite.test.fuzzer.SimplifyTask
- result - Variable in class org.apache.calcite.util.ReflectVisitorTest.NumberNegater
- result(int) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter1
- result(long) - Static method in class org.apache.calcite.util.Smalls.MyStaticSumFunction
- result(long) - Method in class org.apache.calcite.util.Smalls.MySumFunction
- result(long) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter1
- result(long) - Static method in class org.apache.calcite.util.Smalls.MyThreeParamsSumFunctionWithFilter2
- result(long) - Method in class org.apache.calcite.util.Smalls.MyTwoParamsSumFunctionFilter2
- result(A) - Method in interface org.apache.calcite.util.Smalls.MyGenericAggFunction
- result(Integer) - Method in class org.apache.calcite.util.Smalls.MySum3
- results - Variable in class org.apache.calcite.test.JdbcTest.AutoTempDriver
- resultSet(ResultSet) - Method in class org.apache.calcite.test.CalciteAssert.ResultSetFormatter
- ResultSetFormatter() - Constructor for class org.apache.calcite.test.CalciteAssert.ResultSetFormatter
- ResultsReader(BufferedWriter) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- ResultsReader(BufferedWriter, int, boolean, boolean, boolean) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- returns(Function<ResultSet, Void>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Deprecated.
- returns(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertMetaData
- returns(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returns(String) - Method in class org.apache.calcite.test.Fluent
- returns(String...) - Method in class org.apache.calcite.adapter.file.SqlTest.Fluent
-
Sets the rows that are expected to be returned from the SQL query.
- returns(String...) - Method in class org.apache.calcite.test.CsvTest.Fluent
-
Sets the rows that are expected to be returned from the SQL query.
- returns(String, Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returns(String, Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- returns(Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertMetaData
- returns(Consumer<ResultSet>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returns(Function<String, Void>) - Method in class org.apache.calcite.test.Fluent
- returns2(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Similar to
CalciteAssert.AssertQuery.returns(java.lang.String)
, but trims a few values before comparing. - returnsCount(int) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnsOrdered(String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnsStartingWith(String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnsUnordered(String...) - Method in class org.apache.calcite.adapter.file.SqlTest.Fluent
-
Sets the rows that are expected to be returned from the SQL query, in no particular order.
- returnsUnordered(String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- returnsUnordered(String...) - Method in class org.apache.calcite.test.CsvTest.Fluent
-
Sets the rows that are expected to be returned from the SQL query, in no particular order.
- returnsUnordered(String...) - Method in class org.apache.calcite.test.Fluent
- returnsUnordered(String...) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches if the examined result set returns the given collection of rows in some order.
- returnsValue(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- rexBuilder - Variable in class org.apache.calcite.adapter.druid.DruidQueryFilterTest.Fixture
- rexBuilder - Variable in class org.apache.calcite.test.MaterializationTest
- rexBuilder - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- rexBuilder - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- rexBuilder - Variable in class org.apache.calcite.test.RexTransformerTest
- rexBuilder - Variable in class org.apache.calcite.test.SqlOperatorBindingTest
- RexBuilderTest - Class in org.apache.calcite.rex
-
Test for
RexBuilder
. - RexBuilderTest() - Constructor for class org.apache.calcite.rex.RexBuilderTest
- RexExecutorTest - Class in org.apache.calcite.rex
-
Unit test for
RexExecutorImpl
. - RexExecutorTest() - Constructor for class org.apache.calcite.rex.RexExecutorTest
- RexExecutorTest.Action - Interface in org.apache.calcite.rex
- RexExecutorTest.TestDataContext - Class in org.apache.calcite.rex
-
ArrayList-based DataContext to check Rex execution.
- RexFuzzer - Class in org.apache.calcite.test.fuzzer
-
Generates random
RexNode
instances for tests. - RexFuzzer(RexBuilder, JavaTypeFactory) - Constructor for class org.apache.calcite.test.fuzzer.RexFuzzer
-
Generates randomized
RexNode
. - RexImplicationCheckerTest - Class in org.apache.calcite.test
-
Unit tests for
RexImplicationChecker
. - RexImplicationCheckerTest() - Constructor for class org.apache.calcite.test.RexImplicationCheckerTest
- RexImplicationCheckerTest.Fixture - Class in org.apache.calcite.test
-
Contains all the nourishment a test case could possibly need.
- RexProgramBuilderBase - Class in org.apache.calcite.test
-
This class provides helper methods to build rex expressions.
- RexProgramBuilderBase() - Constructor for class org.apache.calcite.test.RexProgramBuilderBase
- RexProgramBuilderBase.DummyTestDataContext - Class in org.apache.calcite.test
-
Dummy data context for test.
- RexProgramFuzzyTest - Class in org.apache.calcite.test.fuzzer
-
Validates that
RexSimplify
is able to deal with randomizedRexNode
. - RexProgramFuzzyTest() - Constructor for class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- RexProgramFuzzyTest.TopN<E extends java.lang.Comparable<E>> - Class in org.apache.calcite.test.fuzzer
-
A bounded variation of
PriorityQueue
- RexProgramTest - Class in org.apache.calcite.test
-
Unit tests for
RexProgram
andRexProgramBuilder
. - RexProgramTest() - Constructor for class org.apache.calcite.test.RexProgramTest
-
Creates a RexProgramTest.
- RexToTestCodeShuttle - Class in org.apache.calcite.test.fuzzer
-
Converts
RexNode
into a string form usable for inclusion intoRexProgramFuzzyTest
. - RexToTestCodeShuttle() - Constructor for class org.apache.calcite.test.fuzzer.RexToTestCodeShuttle
- RexTransformerTest - Class in org.apache.calcite.test
-
Tests transformations on rex nodes.
- RexTransformerTest() - Constructor for class org.apache.calcite.test.RexTransformerTest
- RIGHT_BRACKET - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- RollbackCommand() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.RollbackCommand
- rolledUpColumns - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.WrapperTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionWithAnyTypeTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.StreamTest.BaseOrderStreamTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.StreamTest.OrdersTable
- rolledUpColumnValidInsideAgg(String, SqlCall, SqlNode, CalciteConnectionConfig) - Method in class org.apache.calcite.test.StreamTest.ProductsTable
- rollup(ImmutableBitSet...) - Method in class org.apache.calcite.test.SqlValidatorTest
- root - Variable in class org.apache.calcite.test.DiffRepository
- root - Variable in class org.apache.calcite.test.MockRelOptPlanner
- ROOT_COLLATION - Static variable in class org.apache.calcite.plan.volcano.CollationConversionTest
- ROOT_PACKATE - Static variable in class org.apache.calcite.adapter.geode.rel.JsonLoader
- ROOT_PREFIX - Static variable in class org.apache.calcite.util.SourceTest
- ROOT_SCHEMA - Static variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- ROOT_TAG - Static variable in class org.apache.calcite.test.DiffRepository
- RootEmployee - Class in <Unnamed>
-
Equivalent to
JdbcExample.Employee
, but belongs to the unnamed (root) package. - RootEmployee(int, String) - Constructor for class RootEmployee
-
Creates a RootEmployee.
- RootHr - Class in <Unnamed>
-
Equivalent to
JdbcExample.Hr
, but belongs to the unnamed (root) package. - RootHr() - Constructor for class RootHr
- rootPackage - Variable in class org.apache.calcite.adapter.geode.rel.JsonLoader
- rootSchema - Variable in class org.apache.calcite.test.InterpreterTest
- RootSingleRel(RelOptCluster, RelNode) - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.RootSingleRel
- ROW_RANGE_NOT_ALLOWED_WITH_RANK - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- ROW_RANGE_NOT_ALLOWED_WITH_RANK - Static variable in class org.apache.calcite.test.SqlValidatorTest
- rowCount - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- rowCount - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- rowLimit - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandWithTimeoutAndRowLimit
- ROWLIMIT - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- ROWLIMIT_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- rows - Variable in class org.apache.calcite.test.FoodMartQuerySet.FoodmartQuery
- rows - Variable in class org.apache.calcite.test.StreamTest.OrdersHistoryTable
- rows - Variable in class org.apache.calcite.test.StreamTest.OrdersTable
- rows - Variable in class org.apache.calcite.test.StreamTest.ProductsTable
- rows - Variable in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- ROWS - Static variable in class org.apache.calcite.test.CountriesTableFunction
- rowToString(ResultSet, ResultSetMetaData) - Method in class org.apache.calcite.test.CalciteAssert.ResultSetFormatter
-
Converts one row to a string.
- rowType - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- rowType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- rowType - Variable in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- rule - Variable in class org.apache.calcite.test.MockRelOptPlanner
- RULE - Static variable in class org.apache.calcite.test.CassandraAdapterTest
- ruleAttempted(RelOptListener.RuleAttemptedEvent) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- ruleAttempted(RelOptListener.RuleAttemptedEvent) - Method in class org.apache.calcite.test.HepPlannerTest.HepTestListener
- ruleProductionSucceeded(RelOptListener.RuleProductionEvent) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- ruleProductionSucceeded(RelOptListener.RuleProductionEvent) - Method in class org.apache.calcite.test.HepPlannerTest.HepTestListener
- RULES - Static variable in class org.apache.calcite.plan.volcano.TraitPropagationTest
- run() - Method in class org.apache.calcite.examples.foodmart.java.JdbcExample
- run() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Executes the configured commands.
- run() - Method in class org.apache.calcite.test.CsvTest.Worker
- run(String[]) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- run(String...) - Static method in class org.apache.calcite.test.SqlLineTest
-
Execute a script with "sqlline -f".
- run(TraitPropagationTest.PropAction, RuleSet) - Static method in class org.apache.calcite.plan.volcano.TraitPropagationTest
- run(RelNode) - Method in class org.apache.calcite.test.MaterializationTest.TableNameVisitor
- runAllExamples() - Method in class org.apache.calcite.examples.RelBuilderExample
- runAppProcess(ProcessBuilder, Logger, Reader, Writer) - Static method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Runs an external application process.
- runDuplicateSortCheck(String, String) - Method in class org.apache.calcite.tools.PlannerTest
- runJdbc() - Static method in class org.apache.calcite.test.LatticeTest
- runProjectQueryWithLex(Lex, String) - Static method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- runQuery(String) - Method in class org.apache.calcite.test.ExceptionMessageTest
- runQuery(Connection, String) - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest
- runRexFuzzer(long, Duration, int, long, int) - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- runs() - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- runs() - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- runScript(File, boolean) - Static method in class org.apache.calcite.test.SqlLineTest
- RUNTIME - org.apache.calcite.sql.test.SqlTests.Stage
- runTimeSeconds - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator
S
- s - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- s - Variable in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- s - Variable in class org.apache.calcite.util.Smalls.IntString
- salary - Variable in class org.apache.calcite.test.JdbcTest.Employee
- sale0 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale1 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale10 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale100 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale101 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale102 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale103 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale104 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale105 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale106 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale107 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale108 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale109 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale11 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale110 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale111 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale112 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale113 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale114 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale115 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale116 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale117 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale118 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale119 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale12 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale120 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale121 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale122 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale123 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale124 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale125 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale126 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale127 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale128 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale129 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale13 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale130 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale131 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale132 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale133 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale134 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale135 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale136 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale137 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale138 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale139 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale14 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale140 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale141 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale142 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale143 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale144 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale145 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale146 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale147 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale148 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale149 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale15 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale150 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale151 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale152 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale153 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale154 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale155 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale156 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale157 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale158 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale159 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale16 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale160 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale161 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale162 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale163 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale164 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale165 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale166 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale167 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale168 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale169 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale17 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale170 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale171 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale172 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale173 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale174 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale175 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale176 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale177 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale178 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale179 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale18 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale180 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale181 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale182 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale183 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale184 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale185 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale186 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale187 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale188 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale189 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale19 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale190 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale191 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale192 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale193 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale194 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale195 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale196 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale197 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale198 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale199 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale2 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale20 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale21 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale22 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale23 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale24 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale25 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale26 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale27 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale28 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale29 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale3 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale30 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale31 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale32 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale33 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale34 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale35 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale36 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale37 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale38 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale39 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale4 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale40 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale41 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale42 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale43 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale44 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale45 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale46 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale47 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale48 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale49 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale5 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale50 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale51 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale52 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale53 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale54 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale55 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale56 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale57 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale58 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale59 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale6 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale60 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale61 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale62 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale63 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale64 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale65 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale66 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale67 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale68 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale69 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale7 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale70 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale71 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale72 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale73 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale74 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale75 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale76 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale77 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale78 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale79 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale8 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale80 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale81 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale82 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale83 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale84 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale85 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale86 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale87 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale88 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale89 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale9 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale90 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale91 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale92 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale93 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale94 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale95 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale96 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale97 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale98 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sale99 - Variable in class org.apache.calcite.util.Smalls.WideProductSale
- sales_fact_1997 - Variable in class org.apache.calcite.examples.foodmart.java.JdbcExample.Foodmart
- sales_fact_1997 - Variable in class org.apache.calcite.test.JdbcTest.FoodmartSchema
- SALES_LATTICE - Static variable in class org.apache.calcite.test.LatticeTest
- SALES_TABLES - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- SalesFact(int, int) - Constructor for class org.apache.calcite.examples.foodmart.java.JdbcExample.SalesFact
- SalesFact(int, int) - Constructor for class org.apache.calcite.test.JdbcTest.SalesFact
- sameResultWithMaterializationsDisabled() - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- SAMPLE_VALUES - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
A bunch of sample values of various types.
- SamplePlugin - Class in org.apache.calcite.test.concurrent
-
Sample mtsql plugin.
- SamplePlugin() - Constructor for class org.apache.calcite.test.concurrent.SamplePlugin
- SamplePlugin.DescribeResultSet - Class in org.apache.calcite.test.concurrent
-
Command that describes a result set.
- sansCarets() - Method in class org.apache.calcite.sql.parser.SqlParserTest.Sql
-
Removes the carets from the SQL string.
- sansCarets() - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
-
Removes the carets from the SQL string.
- satisfies(RelTrait) - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.SimpleDistribution
- satisfies(RelTrait) - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- SCALE - Static variable in class org.apache.calcite.util.PartiallyOrderedSetTest
- scan(DataContext) - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionTable
- scan(DataContext) - Method in class org.apache.calcite.test.CollectionTypeTest.NestedCollectionWithAnyTypeTable
- scan(DataContext) - Method in class org.apache.calcite.test.ScannableTableTest.BeatlesTable
- scan(DataContext) - Method in class org.apache.calcite.test.ScannableTableTest.SimpleTable
- scan(DataContext) - Method in class org.apache.calcite.test.StreamTest.InfiniteOrdersTable
- scan(DataContext) - Method in class org.apache.calcite.test.StreamTest.OrdersHistoryTable
- scan(DataContext) - Method in class org.apache.calcite.test.StreamTest.OrdersTable
- scan(DataContext) - Method in class org.apache.calcite.test.StreamTest.ProductsTable
- scan(DataContext) - Method in class org.apache.calcite.util.Smalls.MazeTable
- scan(DataContext, List<RexNode>) - Method in class org.apache.calcite.test.ScannableTableTest.BeatlesFilterableTable
- scan(DataContext, List<RexNode>, int[]) - Method in class org.apache.calcite.test.ScannableTableTest.BeatlesProjectableFilterableTable
- scan(DataContext, List<RexNode>, int[]) - Method in class org.apache.calcite.tools.FrameworksTest.TableImpl
- ScannableTableTest - Class in org.apache.calcite.test
-
Unit test for
ScannableTable
. - ScannableTableTest() - Constructor for class org.apache.calcite.test.ScannableTableTest
- ScannableTableTest.BeatlesFilterableTable - Class in org.apache.calcite.test
-
Table that returns two columns via the
FilterableTable
interface. - ScannableTableTest.BeatlesProjectableFilterableTable - Class in org.apache.calcite.test
-
Table that returns two columns via the
FilterableTable
interface. - ScannableTableTest.BeatlesTable - Class in org.apache.calcite.test
-
Table that returns two columns via the ScannableTable interface.
- ScannableTableTest.SimpleTable - Class in org.apache.calcite.test
-
Table that returns one column via the
ScannableTable
interface. - schema - Static variable in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- schema - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- schema - Variable in class org.apache.calcite.test.CalciteAssert.AddSchemaPostProcessor
- schema - Variable in class org.apache.calcite.test.ConnectionSpec
- schema(String, String) - Static method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- schema(String, String) - Static method in class org.apache.calcite.adapter.tpch.TpchTest
- schema(CalciteAssert.SchemaSpec) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- schema(CalciteAssert.SchemaSpec) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- SCHEMA - Static variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- schemaFor(String, Class<? extends TableFactory>) - Static method in class org.apache.calcite.test.StreamTest
- schemaFrom(CalciteAssert.SchemaSpec) - Static method in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- schemaName - Variable in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
-
The name of the schema that is usually created from this specification.
- SCHEMAS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- schemaSpec - Variable in class org.apache.calcite.test.CalciteAssert.AddSchemaSpecPostProcessor
- SchemaSpec(String) - Constructor for enum org.apache.calcite.test.CalciteAssert.SchemaSpec
- scott - Variable in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
- scott() - Method in class org.apache.calcite.profile.ProfilerTest
- SCOTT - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that loads the "scott/tiger" database.
- SCOTT - org.apache.calcite.test.CalciteAssert.SchemaSpec
- SCOTT - Static variable in class org.apache.calcite.test.JdbcTest
- SCOTT_MODEL - Static variable in class org.apache.calcite.test.JdbcTest
- SCOTT_SCHEMA - Static variable in class org.apache.calcite.test.JdbcTest
- scriptDirectory - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- scriptHasVars - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- scriptStartTime - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- scrolling() - Method in class org.apache.calcite.adapter.elasticsearch.ScrollingTest
- ScrollingTest - Class in org.apache.calcite.adapter.elasticsearch
-
Tests usage of scrolling API like correct results and resource cleanup (delete scroll after scan).
- ScrollingTest() - Constructor for class org.apache.calcite.adapter.elasticsearch.ScrollingTest
- search(int, int, int, Integer...) - Method in class org.apache.calcite.runtime.BinarySearchTest
- second - Variable in class org.apache.calcite.test.catalog.CompoundNameColumn
- seed - Variable in class org.apache.calcite.test.fuzzer.SimplifyTask
- seed - Variable in class org.apache.calcite.util.PartiallyOrderedSetTest
- SEED - Static variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- SELECT_BOTH - Static variable in class org.apache.calcite.linq4j.test.CorrelateJoinTest
- SELECT_KEYWORDS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- SelectCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SelectCommand
- SelectCommand(String, boolean) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SelectCommand
- SelectCommand(String, long) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SelectCommand
- SelectCommand(String, long, int) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SelectCommand
- server - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- ServerParserTest - Class in org.apache.calcite.test
-
Tests SQL parser extensions for DDL.
- ServerParserTest() - Constructor for class org.apache.calcite.test.ServerParserTest
- ServerQuidemTest - Class in org.apache.calcite.test
-
Unit tests for server and DDL.
- ServerQuidemTest(String) - Constructor for class org.apache.calcite.test.ServerQuidemTest
-
Creates a ServerQuidemTest.
- ServerTest - Class in org.apache.calcite.test
-
Unit tests for server and DDL.
- ServerTest() - Constructor for class org.apache.calcite.test.ServerTest
- ServerUnParserTest - Class in org.apache.calcite.test
-
Extension to
ServerParserTest
that ensures that every expression can un-parse successfully. - ServerUnParserTest() - Constructor for class org.apache.calcite.test.ServerUnParserTest
- set(String, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- set(String, String) - Method in class org.apache.calcite.test.DiffRepository
-
Sets the value of a given resource of the current test case.
- set(TimeUnitRange...) - Static method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- set(CalciteConnectionProperty, String) - Method in class org.apache.calcite.test.CalciteAssert.PropBuilder
- setCallRewrite(boolean) - Method in class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler.MyInvocationHandler
- setColumnReferenceExpansion(boolean) - Method in class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler.MyInvocationHandler
- setDataSource(String, Properties) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Sets the jdbc data source for executing the command threads.
- setDebug(boolean) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- setDebug(boolean, PrintStream) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
- setFor(SqlOperator, SqlTester.VmName...) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- setFor(SqlOperator, SqlTester.VmName...) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Declares that this test is for a given operator.
- setIdentifierExpansion(boolean) - Method in class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler.MyInvocationHandler
- setKind(StructKind) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- SETOPS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- setQuiet(boolean) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- setRefFileDiffMasks() - Method in class org.apache.calcite.test.DiffTestCase
-
Sets the diff masks that are common to .REF files
- setRelMetadataTimestamp(long) - Method in class org.apache.calcite.test.MockRelOptPlanner
-
Allow tests to tweak the timestamp.
- setRoot(RelNode) - Method in class org.apache.calcite.test.MockRelOptPlanner
- setRowLimit(Statement) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandWithTimeoutAndRowLimit
- setStatement(Statement) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Sets the thread's current JDBC statement.
- setThreadName(int, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Configures a human-readable name for a given thread identifier.
- setTimeout(Statement) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.CommandWithTimeout
- setTimeout(Statement) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandWithTimeout
- setup() - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest
- setUp() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchJsonTest
- setUp() - Static method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- setUp() - Static method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- setUp() - Static method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- setUp() - Static method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- setUp() - Method in class org.apache.calcite.linq4j.test.LookupImplTest
- setUp() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- setUp() - Static method in class org.apache.calcite.test.CassandraAdapterTest
- setUp() - Method in class org.apache.calcite.test.DiffTestCase
- setUp() - Method in class org.apache.calcite.test.ExceptionMessageTest
- setUp() - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- setUp() - Method in class org.apache.calcite.test.InterpreterTest
- setUp() - Method in class org.apache.calcite.test.RexProgramBuilderBase
- setUp() - Method in class org.apache.calcite.test.RexProgramTest
- setUp() - Method in class org.apache.calcite.test.RexTransformerTest
- setUp() - Method in class org.apache.calcite.test.SqlOperatorBindingTest
- SETUP - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SETUP_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SETUP_THREAD_ID - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- setupCommands - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- setupConnectionWithNestedAnyTypeTable() - Method in class org.apache.calcite.test.CollectionTypeTest
- setupConnectionWithNestedTable() - Method in class org.apache.calcite.test.CollectionTypeTest
- setupDataFilesForPigServer() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- setupInstance() - Static method in class org.apache.calcite.adapter.elasticsearch.AggregationTest
- setupInstance() - Static method in class org.apache.calcite.adapter.elasticsearch.BooleanLogicTest
-
Used to create
zips
index and insert some data - setupInstance() - Static method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
-
Used to create
zips
index and insert zip data in bulk. - setupInstance() - Static method in class org.apache.calcite.adapter.elasticsearch.Projection2Test
- setupInstance() - Static method in class org.apache.calcite.adapter.elasticsearch.ProjectionTest
- setupInstance() - Static method in class org.apache.calcite.adapter.elasticsearch.ScrollingTest
- setupNestedRecords() - Static method in class org.apache.calcite.test.CollectionTypeTest
- setUSLocale() - Static method in class org.apache.calcite.test.SqlLimitsTest
- setUSLocale() - Static method in class org.apache.calcite.test.SqlValidatorDynamicTest
- setUSLocale() - Static method in class org.apache.calcite.test.SqlValidatorTest
- setUSLocale() - Static method in class org.apache.calcite.util.UtilTest
- setVerbose(boolean) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- setVerbose(boolean) - Method in class org.apache.calcite.test.DiffTestCase
-
Sets whether to give verbose message if diff fails.
- sh - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- share() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy.RefCountPolicy
- share() - Method in class org.apache.calcite.adapter.geode.rel.GeodeEmbeddedPolicy
-
Allows this instance to be shared by multiple test classes (in parallel).
- SHELL - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SHELL_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- ShellCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ShellCommand
- shellWildcardPattern - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- shortDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- shortestPath(DirectedGraph<V, DefaultEdge>, V, V) - Method in class org.apache.calcite.util.graph.DirectedGraphTest
- shortLiteral(short) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- shouldExpandIdentifiers() - Method in class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler.MyInvocationHandler
- shouldExpandIdentifiers() - Method in class org.apache.calcite.test.SqlToRelTestBase.FarragoTestValidator
- shouldFail - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.AbstractCommand
- ShouldHaveFailedException(String) - Constructor for exception org.apache.calcite.test.concurrent.ConcurrentTestCommand.ShouldHaveFailedException
- shutdownPigServer() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- SIMPLE_DISTRIBUTION_ANY - Static variable in class org.apache.calcite.plan.volcano.TraitConversionTest
- SIMPLE_DISTRIBUTION_RANDOM - Static variable in class org.apache.calcite.plan.volcano.TraitConversionTest
- SIMPLE_DISTRIBUTION_SINGLETON - Static variable in class org.apache.calcite.plan.volcano.TraitConversionTest
- SIMPLE_FACTORY - Static variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- simpleCorrelate() - Method in class org.apache.calcite.test.enumerable.EnumerableCorrelateTest
- simpleCorrelateDecorrelated() - Method in class org.apache.calcite.test.enumerable.EnumerableCorrelateTest
- simpleCorrelateWithConditionIncludingBoxedPrimitive() - Method in class org.apache.calcite.test.enumerable.EnumerableCorrelateTest
- SimpleDistribution(String) - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.SimpleDistribution
- SimpleJdbcExample - Class in org.apache.calcite.adapter.geode.simple
-
Example of using Geode via JDBC.
- SimpleJdbcExample() - Constructor for class org.apache.calcite.adapter.geode.simple.SimpleJdbcExample
- SimpleTable() - Constructor for class org.apache.calcite.test.ScannableTableTest.SimpleTable
- SimpleTable() - Constructor for class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- SimpleTableFunction() - Constructor for class org.apache.calcite.util.Smalls.SimpleTableFunction
- simplify - Variable in class org.apache.calcite.test.MaterializationTest
- simplify - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- simplify - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- simplify(RexNode) - Method in class org.apache.calcite.test.RexProgramTest
- simplifyNull() - Method in class org.apache.calcite.test.RexProgramTest
- simplifyStrong() - Method in class org.apache.calcite.test.RexProgramTest
- SimplifyTask - Class in org.apache.calcite.test.fuzzer
-
Tracks rex nodes used in
RexProgramFuzzyTest
to identify the ones which take most time to simplify. - SimplifyTask(RexNode, long, RexNode, long) - Constructor for class org.apache.calcite.test.fuzzer.SimplifyTask
- singleFuzzyTest() - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- SingleLeafTraitRule() - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.SingleLeafTraitRule
- SingleNodeRule() - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.SingleNodeRule
- SingletonLeafRel(RelOptCluster, String) - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest.SingletonLeafRel
- SIZE - Static variable in class org.apache.calcite.adapter.elasticsearch.ScrollingTest
- skillRecordType - Variable in class org.apache.calcite.test.catalog.Fixture
- skipFirstWord(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
-
Returns everything but the first word of the given line, assuming the line is trimmed.
- skipItem - Variable in class org.apache.calcite.test.RelOptRulesTest
- sleep(long) - Method in class org.apache.calcite.test.CsvTest
-
Creates a command that sleeps.
- SLEEP - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SLEEP_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SleepCommand(long) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.SleepCommand
- slowestTasks - Variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- Smalls - Class in org.apache.calcite.util
-
Holder for various classes and functions used in tests as user-defined functions and so forth.
- Smalls() - Constructor for class org.apache.calcite.util.Smalls
- Smalls.AllTypesFunction - Class in org.apache.calcite.util
-
UDF class that provides user-defined functions for each data type.
- Smalls.AwkwardFunction - Class in org.apache.calcite.util
-
Example of a UDF class that needs to be instantiated but cannot be.
- Smalls.CountArgs0Function - Class in org.apache.calcite.util
-
Example of a UDF that has overloaded UDFs (same name, different args).
- Smalls.CountArgs1Function - Class in org.apache.calcite.util
- Smalls.CountArgs1NullableFunction - Class in org.apache.calcite.util
- Smalls.CountArgs2Function - Class in org.apache.calcite.util
- Smalls.IntString - Class in org.apache.calcite.util
-
Class with int and String fields.
- Smalls.MazeTable - Class in org.apache.calcite.util
-
The real MazeTable may be found in example/function.
- Smalls.MultipleFunction - Class in org.apache.calcite.util
-
UDF class that has multiple methods, some overloaded.
- Smalls.MyAbcdeFunction - Class in org.apache.calcite.util
-
Example of a UDF with named parameters, some of them optional.
- Smalls.MyDeterministicPlusFunction - Class in org.apache.calcite.util
-
As
Smalls.MyPlusFunction
but declared to be deterministic. - Smalls.MyDoubleFunction - Class in org.apache.calcite.util
-
Example of a UDF with a static
eval
method. - Smalls.MyGenericAggFunction<A,V,R> - Interface in org.apache.calcite.util
-
A generic interface for defining user defined aggregate functions
- Smalls.MyIncrement - Class in org.apache.calcite.util
-
User-defined function with two arguments.
- Smalls.MyLeftFunction - Class in org.apache.calcite.util
-
Example of a UDF with named parameters.
- Smalls.MyPlusFunction - Class in org.apache.calcite.util
-
Example of a UDF with a non-static
eval
method, and named parameters. - Smalls.MyStaticSumFunction - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF), whose methods are static.
- Smalls.MySum3 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function that implements a generic interface.
- Smalls.MySumFunction - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF).
- Smalls.MyTableFunction - Class in org.apache.calcite.util
-
A table function that returns a
QueryableTable
. - Smalls.MyThreeParamsSumFunctionWithFilter1 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF), whose methods are static.
- Smalls.MyThreeParamsSumFunctionWithFilter2 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF), whose methods are static.
- Smalls.MyToStringFunction - Class in org.apache.calcite.util
-
Example of a non-strict UDF.
- Smalls.MyTwoParamsSumFunctionFilter1 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF).
- Smalls.MyTwoParamsSumFunctionFilter2 - Class in org.apache.calcite.util
-
Example of a user-defined aggregate function (UDAF).
- Smalls.Null4Function - Class in org.apache.calcite.util
-
Example of a semi-strict UDF.
- Smalls.Null8Function - Class in org.apache.calcite.util
-
Example of a picky, semi-strict UDF.
- Smalls.SimpleTableFunction - Class in org.apache.calcite.util
-
A table function that returns a
QueryableTable
. - Smalls.StaticTableMacroFunction - Class in org.apache.calcite.util
-
User-defined table-macro function whose eval method is static.
- Smalls.SumFunctionBadIAdd - Class in org.apache.calcite.util
-
User-defined function.
- Smalls.TableMacroFunction - Class in org.apache.calcite.util
-
User-defined table-macro function.
- Smalls.TableMacroFunctionWithNamedParameters - Class in org.apache.calcite.util
-
User-defined table-macro function with named and optional parameters.
- Smalls.TestStaticTableFunction - Class in org.apache.calcite.util
-
A table function that returns a
QueryableTable
via a static method. - Smalls.WideProductSale - Class in org.apache.calcite.util
-
Table with a lot of columns.
- Smalls.WideSaleSchema - Class in org.apache.calcite.util
-
Schema containing a
prod
table with a lot of columns. - SOLVE_METHOD - Static variable in class org.apache.calcite.test.ExampleFunctionTest
- SomewhatAmbiguousNumber() - Constructor for class org.apache.calcite.util.ReflectVisitorTest.SomewhatAmbiguousNumber
- SomewhatIndecisiveNumberNegater() - Constructor for class org.apache.calcite.util.ReflectVisitorTest.SomewhatIndecisiveNumberNegater
- sort(Ordering<Profiler.Statistic>) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- sort(E...) - Static method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
- sort(List<E>) - Static method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
- sortAscDesc() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
-
Sort by multiple fields (in different direction: asc/desc)
- sortsAs(String) - Static method in class org.apache.calcite.test.RelMetadataTest
-
Matcher that succeeds for any collection that, when converted to strings and sorted on those strings, matches the given reference string.
- SOURCE - Static variable in class org.apache.calcite.test.RelMetadataTest.BrokenColTypeImpl
- SOURCE - Static variable in class org.apache.calcite.test.RelMetadataTest.ColTypeImpl
- SourceTest - Class in org.apache.calcite.util
-
Tests for
Source
. - SourceTest() - Constructor for class org.apache.calcite.util.SourceTest
- SPACES - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SPARK - org.apache.calcite.test.CalciteAssert.Config
-
Configuration that loads Spark.
- SparkAdapterTest - Class in org.apache.calcite.test
-
Tests for using Calcite with Spark as an internal engine, as implemented by the
org.apache.calcite.adapter.spark
package. - SparkAdapterTest() - Constructor for class org.apache.calcite.test.SparkAdapterTest
- splitBinding - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- splitJoinConditionHelper(RexNode, List<Integer>, List<Integer>, List<Boolean>, RexNode) - Static method in class org.apache.calcite.plan.RelOptUtilTest
- splitWords - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- SPLUNK_PASSWORD - Static variable in class org.apache.calcite.test.SplunkAdapterTest
- SPLUNK_URL - Static variable in class org.apache.calcite.test.SplunkAdapterTest
- SPLUNK_USER - Static variable in class org.apache.calcite.test.SplunkAdapterTest
- SplunkAdapterTest - Class in org.apache.calcite.test
-
Unit test of the Calcite adapter for Splunk.
- SplunkAdapterTest() - Constructor for class org.apache.calcite.test.SplunkAdapterTest
- SPOOLER_VALIDATOR - Static variable in class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler
- sql - Variable in class org.apache.calcite.adapter.file.SqlTest.Fluent
- sql - Variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- sql - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- sql - Variable in class org.apache.calcite.sql.parser.SqlParserTest.Sql
- sql - Variable in class org.apache.calcite.test.CalciteAssert.AssertQuery
- sql - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.DdlCommand
- sql - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.ExplainCommand
- sql - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.InsertCommand
- sql - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.PrepareCommand
- sql - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrepareCommand
- sql - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SelectCommand
- sql - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SqlCommand
- sql - Variable in class org.apache.calcite.test.CsvTest.Fluent
- sql - Variable in class org.apache.calcite.test.FoodMartQuerySet.FoodmartQuery
- sql - Variable in class org.apache.calcite.test.RelOptTestBase.Sql
- sql - Variable in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- sql - Variable in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- sql(String) - Static method in class org.apache.calcite.adapter.os.OsAdapterTest
- sql(String) - Static method in class org.apache.calcite.profile.ProfilerTest
- sql(String) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- sql(String) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
Initiates a test case with a given SQL query.
- sql(String) - Method in class org.apache.calcite.sql.parser.SqlParserTest
- sql(String) - Method in class org.apache.calcite.test.DruidAdapterIT
-
Creates a query against the
DruidAdapterIT.FOODMART
data set. - sql(String) - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Creates a query against the
DruidAdapterIT2.FOODMART
data set. - sql(String) - Method in class org.apache.calcite.test.RelOptTestBase
-
Sets the SQL statement for a test.
- sql(String) - Method in class org.apache.calcite.test.SparkAdapterTest
- sql(String) - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Sets the SQL statement for a test.
- sql(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- sql(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- sql(String, String) - Method in class org.apache.calcite.adapter.file.SqlTest
- sql(String, String) - Method in class org.apache.calcite.test.CsvTest
- sql(String, URL) - Method in class org.apache.calcite.test.DruidAdapterIT
-
Creates a query against a data set given by a map.
- sql(String, URL) - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Creates a query against a data set given by a map.
- Sql(String) - Constructor for class org.apache.calcite.sql.parser.SqlParserTest.Sql
- Sql(String, boolean) - Constructor for class org.apache.calcite.sql.parser.SqlParserTest.Sql
- Sql(String, boolean, boolean, SqlToRelTestBase.Tester, boolean, SqlToRelConverter.Config, SqlConformance) - Constructor for class org.apache.calcite.test.SqlToRelConverterTest.Sql
- Sql(String, HepProgram, HepPlanner, ImmutableMap<Hook, Consumer>, ImmutableList<Function<SqlToRelTestBase.Tester, SqlToRelTestBase.Tester>>) - Constructor for class org.apache.calcite.test.RelOptTestBase.Sql
- Sql(SchemaPlus, String, SqlDialect, SqlToRelConverter.Config, List<Function<RelNode, RelNode>>) - Constructor for class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- Sql(SqlTester, String, boolean) - Constructor for class org.apache.calcite.test.SqlValidatorTestCase.Sql
-
Creates a Sql.
- Sql(CalciteAssert.SchemaSpec, String, SqlDialect, SqlToRelConverter.Config, List<Function<RelNode, RelNode>>) - Constructor for class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- SQL - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SQL_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SQL_STRINGS - Static variable in class org.apache.calcite.test.SplunkAdapterTest
- SqlAdvisorJdbcTest - Class in org.apache.calcite.test
-
Tests for
SqlAdvisor
. - SqlAdvisorJdbcTest() - Constructor for class org.apache.calcite.test.SqlAdvisorJdbcTest
- SqlAdvisorTest - Class in org.apache.calcite.sql.test
-
Concrete child class of
SqlValidatorTestCase
, containing unit tests for SqlAdvisor. - SqlAdvisorTest() - Constructor for class org.apache.calcite.sql.test.SqlAdvisorTest
- sqlAny - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- sqlBigInt - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- sqlBigIntNullable - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- sqlBoolean - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- sqlChar - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- SqlCommand(String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SqlCommand
- SqlCommand(String, boolean) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SqlCommand
- SqlCommand(String, long) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.SqlCommand
- sqlDate - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- sqlDate - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- sqlFloat - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- SqlFunctionsTest - Class in org.apache.calcite.test
-
Unit test for the methods in
SqlFunctions
that implement SQL functions. - SqlFunctionsTest() - Constructor for class org.apache.calcite.test.SqlFunctionsTest
- sqlInt - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- SqlJsonFunctionsTest - Class in org.apache.calcite.test
-
Unit test for the methods in
SqlFunctions
that implement JSON processing functions. - SqlJsonFunctionsTest() - Constructor for class org.apache.calcite.test.SqlJsonFunctionsTest
- SqlLimitsTest - Class in org.apache.calcite.test
-
Unit test for SQL limits.
- SqlLimitsTest() - Constructor for class org.apache.calcite.test.SqlLimitsTest
- SqlLineTest - Class in org.apache.calcite.test
-
Tests that we can invoke SqlLine on a Calcite connection.
- SqlLineTest() - Constructor for class org.apache.calcite.test.SqlLineTest
- sqlNull - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- SqlOperatorBaseTest - Class in org.apache.calcite.sql.test
-
Contains unit tests for all operators.
- SqlOperatorBaseTest(boolean, SqlTester) - Constructor for class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Creates a SqlOperatorBaseTest.
- SqlOperatorBaseTest.Builder - Class in org.apache.calcite.sql.test
-
Builds lists of types and sample values.
- SqlOperatorBaseTest.ExceptionResultChecker - Class in org.apache.calcite.sql.test
-
Result checker that considers a test to have succeeded if it throws an exception that matches one of a list of patterns.
- SqlOperatorBaseTest.OverlapChecker - Class in org.apache.calcite.sql.test
-
Runs an OVERLAPS test with a given set of literal values.
- SqlOperatorBaseTest.TesterImpl - Class in org.apache.calcite.sql.test
-
Implementation of
SqlTester
based on a JDBC connection. - SqlOperatorBaseTest.ValueOrExceptionResultChecker - Class in org.apache.calcite.sql.test
-
Result checker that considers a test to have succeeded if it returns a particular value or throws an exception that matches one of a list of patterns.
- SqlOperatorBaseTest.ValueType - Class in org.apache.calcite.sql.test
-
A type, a value, and its
SqlNode
representation. - SqlOperatorBindingTest - Class in org.apache.calcite.test
-
Unit tests for
RexProgram
andRexProgramBuilder
. - SqlOperatorBindingTest() - Constructor for class org.apache.calcite.test.SqlOperatorBindingTest
-
Creates a SqlOperatorBindingTest.
- SqlOperatorTest - Class in org.apache.calcite.sql.test
-
Concrete subclass of
SqlOperatorBaseTest
which checks against aSqlValidator
. - SqlOperatorTest() - Constructor for class org.apache.calcite.sql.test.SqlOperatorTest
-
Creates a SqlOperatorTest.
- SqlParserTest - Class in org.apache.calcite.sql.parser
-
A
SqlParserTest
is a unit-test forthe SQL parser
. - SqlParserTest() - Constructor for class org.apache.calcite.sql.parser.SqlParserTest
- SqlParserTest.Checker - Class in org.apache.calcite.sql.parser
-
Runs tests on period operators such as OVERLAPS, IMMEDIATELY PRECEDES.
- SqlParserTest.Sql - Class in org.apache.calcite.sql.parser
-
Helper class for building fluent code such as
sql("values 1").ok();
. - SqlParserTest.Tester - Interface in org.apache.calcite.sql.parser
-
Callback to control how test actions are performed.
- SqlParserTest.TesterImpl - Class in org.apache.calcite.sql.parser
-
Default implementation of
SqlParserTest.Tester
. - SqlParserTest.UnparsingTesterImpl - Class in org.apache.calcite.sql.parser
-
Implementation of
SqlParserTest.Tester
which makes sure that the results of unparsing a query are consistent with the original query. - SqlPrettyWriterTest - Class in org.apache.calcite.sql.test
-
Unit test for
SqlPrettyWriter
. - SqlPrettyWriterTest() - Constructor for class org.apache.calcite.sql.test.SqlPrettyWriterTest
- SqlRuntimeTester - Class in org.apache.calcite.sql.test
-
Tester of
SqlValidator
and runtime execution of the input SQL. - SqlRuntimeTester(SqlTestFactory) - Constructor for class org.apache.calcite.sql.test.SqlRuntimeTester
- SqlSetOptionOperatorTest - Class in org.apache.calcite.sql
-
Test for
SqlSetOption
. - SqlSetOptionOperatorTest() - Constructor for class org.apache.calcite.sql.SqlSetOptionOperatorTest
- SqlTest - Class in org.apache.calcite.adapter.file
-
System test of the Calcite file adapter, which can also read and parse HTML tables over HTTP.
- SqlTest() - Constructor for class org.apache.calcite.adapter.file.SqlTest
- SqlTest.Fluent - Class in org.apache.calcite.adapter.file
-
Fluent API to perform test actions.
- SqlTester - Interface in org.apache.calcite.sql.test
-
SqlTester defines a callback for testing SQL queries and expressions.
- SqlTester.ParameterChecker - Interface in org.apache.calcite.sql.test
-
Parameter checker.
- SqlTester.ResultChecker - Interface in org.apache.calcite.sql.test
-
Result checker.
- SqlTester.TypeChecker - Interface in org.apache.calcite.sql.test
-
Type checker.
- SqlTester.VmName - Enum in org.apache.calcite.sql.test
-
Name of a virtual machine that can potentially implement an operator.
- SqlTestFactory - Class in org.apache.calcite.sql.test
-
Default implementation of
SqlTestFactory
. - SqlTestFactory() - Constructor for class org.apache.calcite.sql.test.SqlTestFactory
- SqlTestFactory(ImmutableMap<String, Object>, SqlTestFactory.MockCatalogReaderFactory, SqlTestFactory.ValidatorFactory) - Constructor for class org.apache.calcite.sql.test.SqlTestFactory
- SqlTestFactory.MockCatalogReaderFactory - Interface in org.apache.calcite.sql.test
-
Creates
MockCatalogReader
for tests. - SqlTestFactory.ValidatorFactory - Interface in org.apache.calcite.sql.test
-
Creates
SqlValidator
for tests. - SqlTestGen - Class in org.apache.calcite.test
-
Utility to generate a SQL script from validator test.
- SqlTestGen() - Constructor for class org.apache.calcite.test.SqlTestGen
- SqlTestGen.SqlValidatorSpooler - Class in org.apache.calcite.test
-
Subversive subclass, which spools results to a writer rather than running tests.
- SqlTestGen.SqlValidatorSpooler.MyInvocationHandler - Class in org.apache.calcite.test
-
Handles the methods in
SqlValidator
that are called from validator tests. - SqlTests - Class in org.apache.calcite.sql.test
-
Utility methods.
- SqlTests() - Constructor for class org.apache.calcite.sql.test.SqlTests
- SqlTests.ApproximateResultChecker - Class in org.apache.calcite.sql.test
-
Result checker that checks a result against an expected value.
- SqlTests.PatternResultChecker - Class in org.apache.calcite.sql.test
-
Result checker that checks a result against a regular expression.
- SqlTests.RefSetResultChecker - Class in org.apache.calcite.sql.test
-
Result checker that checks a result against a list of expected strings.
- SqlTests.SqlTypeChecker - Class in org.apache.calcite.sql.test
-
Checks that a type matches a given SQL type.
- SqlTests.Stage - Enum in org.apache.calcite.sql.test
-
Stage of query processing
- SqlTests.StringTypeChecker - Class in org.apache.calcite.sql.test
-
Type checker which compares types to a specified string.
- sqlTime - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- sqlTimestamp - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- SqlToRelConverterExtendedTest - Class in org.apache.calcite.test
-
Runs
SqlToRelConverterTest
with extensions. - SqlToRelConverterExtendedTest() - Constructor for class org.apache.calcite.test.SqlToRelConverterExtendedTest
- SqlToRelConverterTest - Class in org.apache.calcite.test
-
Unit test for
SqlToRelConverter
. - SqlToRelConverterTest() - Constructor for class org.apache.calcite.test.SqlToRelConverterTest
- SqlToRelConverterTest.RelValidityChecker - Class in org.apache.calcite.test
-
Visitor that checks that every
RelNode
in a tree is valid. - SqlToRelConverterTest.Sql - Class in org.apache.calcite.test
-
Allows fluent testing.
- SqlToRelTestBase - Class in org.apache.calcite.test
-
SqlToRelTestBase is an abstract base for tests which involve conversion from SQL to relational algebra.
- SqlToRelTestBase() - Constructor for class org.apache.calcite.test.SqlToRelTestBase
- SqlToRelTestBase.DelegatingRelOptTable - Class in org.apache.calcite.test
-
Table that delegates to a given table.
- SqlToRelTestBase.FarragoTestValidator - Class in org.apache.calcite.test
-
Validator for testing.
- SqlToRelTestBase.MockRelOptSchema - Class in org.apache.calcite.test
-
Mock implementation of
RelOptSchema
. - SqlToRelTestBase.MockRelOptSchema.MockColumnSet - Class in org.apache.calcite.test
-
Mock column set.
- SqlToRelTestBase.Tester - Interface in org.apache.calcite.test
-
Helper class which contains default implementations of methods used for running sql-to-rel conversion tests.
- SqlToRelTestBase.TesterImpl - Class in org.apache.calcite.test
-
Default implementation of
SqlToRelTestBase.Tester
, using mock classesSqlToRelTestBase.MockRelOptSchema
andMockRelOptPlanner
. - SqlTypeChecker(SqlTypeName) - Constructor for class org.apache.calcite.sql.test.SqlTests.SqlTypeChecker
- SqlTypeFactoryTest - Class in org.apache.calcite.sql.type
-
Test for
SqlTypeFactoryImpl
. - SqlTypeFactoryTest() - Constructor for class org.apache.calcite.sql.type.SqlTypeFactoryTest
- SqlTypeFixture - Class in org.apache.calcite.sql.type
-
Reusable
RelDataType
fixtures for tests. - SqlTypeFixture() - Constructor for class org.apache.calcite.sql.type.SqlTypeFixture
- SqlTypeNameTest - Class in org.apache.calcite.sql.test
-
Tests types supported by
SqlTypeName
. - SqlTypeNameTest() - Constructor for class org.apache.calcite.sql.test.SqlTypeNameTest
- SqlTypeUtilTest - Class in org.apache.calcite.sql.type
-
Test of
SqlTypeUtil
. - SqlTypeUtilTest() - Constructor for class org.apache.calcite.sql.type.SqlTypeUtilTest
- SqlUnParserTest - Class in org.apache.calcite.sql.parser
-
Extension to
SqlParserTest
which ensures that every expression can un-parse successfully. - SqlUnParserTest() - Constructor for class org.apache.calcite.sql.parser.SqlUnParserTest
- SqlValidatorDynamicTest - Class in org.apache.calcite.test
-
Concrete child class of
SqlValidatorTestCase
, containing lots of unit tests. - SqlValidatorDynamicTest() - Constructor for class org.apache.calcite.test.SqlValidatorDynamicTest
- SqlValidatorFeatureTest - Class in org.apache.calcite.test
-
SqlValidatorFeatureTest verifies that features can be independently enabled or disabled.
- SqlValidatorFeatureTest() - Constructor for class org.apache.calcite.test.SqlValidatorFeatureTest
- SqlValidatorFeatureTest.FeatureValidator - Class in org.apache.calcite.test
-
Extension to
SqlValidatorImpl
that validates features. - SqlValidatorMatchTest - Class in org.apache.calcite.test
-
Validation tests for the
MATCH_RECOGNIZE
clause. - SqlValidatorMatchTest() - Constructor for class org.apache.calcite.test.SqlValidatorMatchTest
- SqlValidatorSpooler(PrintWriter) - Constructor for class org.apache.calcite.test.SqlTestGen.SqlValidatorSpooler
- SqlValidatorTest - Class in org.apache.calcite.test
-
Concrete child class of
SqlValidatorTestCase
, containing lots of unit tests. - SqlValidatorTest() - Constructor for class org.apache.calcite.test.SqlValidatorTest
- SqlValidatorTestCase - Class in org.apache.calcite.test
-
An abstract base class for implementing tests against
SqlValidator
. - SqlValidatorTestCase() - Constructor for class org.apache.calcite.test.SqlValidatorTestCase
-
Creates a test case.
- SqlValidatorTestCase.Sql - Class in org.apache.calcite.test
-
Fluent testing API.
- SqlValidatorTestCase.Tester - Interface in org.apache.calcite.test
-
Encapsulates differences between test environments, for example, which SQL parser or validator to use.
- SqlValidatorTestCase.TesterConfigurationRule - Class in org.apache.calcite.test
-
Enables to configure
SqlValidatorTestCase.tester
behavior on a per-test basis. - SqlValidatorTester - Class in org.apache.calcite.sql.test
-
Tester of
SqlValidator
. - SqlValidatorTester(SqlTestFactory) - Constructor for class org.apache.calcite.sql.test.SqlValidatorTester
- SqlValidatorUtilTest - Class in org.apache.calcite.sql.validate
-
Tests for
SqlValidatorUtil
. - SqlValidatorUtilTest() - Constructor for class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- sqlVarchar - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- sqlVarcharNullable - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- stack - Variable in class org.apache.calcite.test.SqlToRelConverterTest.RelValidityChecker
- Stage(String) - Constructor for enum org.apache.calcite.sql.test.SqlTests.Stage
- STAR_KEYWORD - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- start - Variable in class org.apache.calcite.adapter.generate.RangeTable
- start - Static variable in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- start() - Method in class org.apache.calcite.adapter.elasticsearch.EmbeddedElasticsearchNode
-
Starts current node
- START_OF_GROUP_DATA - Static variable in class org.apache.calcite.test.JdbcTest
- startOfGroupStep1(String) - Method in class org.apache.calcite.test.JdbcTest
- startOfGroupStep2(String) - Method in class org.apache.calcite.test.JdbcTest
- startOfGroupStep3(String) - Method in class org.apache.calcite.test.JdbcTest
- startsWith(String...) - Method in class org.apache.calcite.test.StreamTest
- state - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- state - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.StateAction
- STATE_OTHER_VALUE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- STATE_ROW_START - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- STATE_STRING_VALUE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- STATE_TABLE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- STATE_VALUE_END - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- STATE_VALUE_START - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- StateAction(String, ConcurrentTestCommandScript.StateDatum[]) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.StateAction
- stateData - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.StateAction
- StateDatum(String, String) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.StateDatum
- statement - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Current JDBC Statement.
- STATES_SOURCE - Static variable in class org.apache.calcite.adapter.file.FileReaderTest
- StaticTableMacroFunction() - Constructor for class org.apache.calcite.util.Smalls.StaticTableMacroFunction
- STATISTIC_PREDICATE - Static variable in class org.apache.calcite.profile.ProfilerTest.Fluid
- StatisticToJson() - Constructor for class org.apache.calcite.profile.ProfilerTest.Fluid.StatisticToJson
- STATS - Static variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- storeMessage(Integer, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Saves a message to be printed with the thread's output.
- storeMessage(String) - Method in interface org.apache.calcite.test.concurrent.ConcurrentTestPluginCommand.TestContext
-
Store a message as output for mtsql script.
- storeResults(Integer, ResultSet, long) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- storeSql(Integer, String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
-
Saves a SQL command to be printed with the thread's output.
- str - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- str - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- str(Object[]) - Static method in class org.apache.calcite.test.CalciteAssert
- str(Object, Object) - Static method in class org.apache.calcite.util.Smalls
- str(RelNode) - Method in class org.apache.calcite.test.PigRelBuilderTest
-
Converts a relational expression to a sting with linux line-endings.
- STR_AGG_REQUIRES_MONO - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- STR_AGG_REQUIRES_MONO - Static variable in class org.apache.calcite.test.SqlValidatorTest
- STR_METHOD - Static variable in class org.apache.calcite.util.Smalls
- STR_ORDER_REQUIRES_MONO - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- STR_ORDER_REQUIRES_MONO - Static variable in class org.apache.calcite.test.SqlValidatorTest
- STR_SET_OP_INCONSISTENT - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
- STR_SET_OP_INCONSISTENT - Static variable in class org.apache.calcite.test.SqlValidatorTest
- stream - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- stream() - Method in class org.apache.calcite.test.catalog.MockCatalogReader.StreamableWrapperTable
- stream() - Method in class org.apache.calcite.test.StreamTest.InfiniteOrdersTable
- stream() - Method in class org.apache.calcite.test.StreamTest.OrdersTable
- STREAM_JOINS_MODEL - Static variable in class org.apache.calcite.test.StreamTest
- STREAM_JOINS_SCHEMA_NAME - Static variable in class org.apache.calcite.test.StreamTest
- STREAM_MODEL - Static variable in class org.apache.calcite.test.StreamTest
- STREAM_SCHEMA_NAME - Static variable in class org.apache.calcite.test.StreamTest
- StreamableWrapperTable(MockCatalogReader.MockTable) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.StreamableWrapperTable
- StreamTest - Class in org.apache.calcite.test
-
Tests for streaming queries.
- StreamTest() - Constructor for class org.apache.calcite.test.StreamTest
- StreamTest.BaseOrderStreamTable - Class in org.apache.calcite.test
-
Base table for the Orders table.
- StreamTest.InfiniteOrdersStreamTableFactory - Class in org.apache.calcite.test
-
Mock table that returns a stream of orders from a fixed array.
- StreamTest.InfiniteOrdersTable - Class in org.apache.calcite.test
-
Table representing an infinitely larger ORDERS stream.
- StreamTest.OrdersHistoryTable - Class in org.apache.calcite.test
-
Table representing the history of the ORDERS stream.
- StreamTest.OrdersStreamTableFactory - Class in org.apache.calcite.test
-
Mock table that returns a stream of orders from a fixed array.
- StreamTest.OrdersTable - Class in org.apache.calcite.test
-
Table representing the ORDERS stream.
- StreamTest.ProductsTable - Class in org.apache.calcite.test
-
Table representing the PRODUCTS relation.
- StreamTest.ProductsTableFactory - Class in org.apache.calcite.test
-
Mocks a simple relation to use for stream joining test.
- string - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- string() - Method in class org.apache.calcite.test.CalciteAssert.ResultSetFormatter
-
Flushes the buffer and returns its previous contents.
- STRING_SUBSET_ORDERING - Static variable in class org.apache.calcite.util.PartiallyOrderedSetTest
- STRING_TRUNC_MESSAGE - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- STRING_UNION_METHOD - Static variable in class org.apache.calcite.util.Smalls
- stringDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- stringJoin(String, Iterable<String>) - Static method in class org.apache.calcite.linq4j.test.Linq4jTest
-
Equivalent to
String
.join, but that method is only in JDK 1.8 and higher. - StringTypeChecker(String) - Constructor for class org.apache.calcite.sql.test.SqlTests.StringTypeChecker
- stringUnion(Queryable<T>, Queryable<T>) - Static method in class org.apache.calcite.util.Smalls
- STRONG - Static variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- STRONG_EXPR - Static variable in class org.apache.calcite.test.RelOptRulesTest
- struct(RelDataType...) - Method in class org.apache.calcite.sql.type.SqlTypeUtilTest
- structKind - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.DelegateStructType
- strView(String) - Static method in class org.apache.calcite.util.Smalls
- sub(String) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.OverlapChecker
- sub(RexNode, RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- subsetHack - Variable in class org.apache.calcite.plan.volcano.TraitPropagationTest.PhysProjRule
- SubsetRule(List<String>) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTest.SubsetRule
- substitutionMatches(Function<RelNode, Void>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- substitutionMatches(Function<RelNode, Void>) - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- subTestIntervalDayFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalDayNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalDayPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalDayPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToHourFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToHourNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToHourPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToHourPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
- subTestIntervalDayToMinuteFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToMinuteNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToMinutePositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToMinutePositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToSecondFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToSecondNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToSecondPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalDayToSecondPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalHourFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalHourNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalHourPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalHourPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToMinuteFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToMinuteNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToMinutePositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToMinutePositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToSecondFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToSecondNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToSecondPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalHourToSecondPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalMinutePositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalMinutePositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteToSecondFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteToSecondNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteToSecondPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalMinuteToSecondPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalMonthFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalMonthNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalMonthPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalMonthPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalSecondFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalSecondNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalSecondPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalSecondPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalYearFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalYearNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalYearPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalYearPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalYearToMonthFailsValidation() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalYearToMonthNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- subTestIntervalYearToMonthPositive() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for INTERVAL...
- subTestIntervalYearToMonthPositive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Runs tests for INTERVAL...
- suggester - Variable in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- SumFunctionBadIAdd() - Constructor for class org.apache.calcite.util.Smalls.SumFunctionBadIAdd
- sums(int, boolean) - Static method in class org.apache.calcite.test.JdbcTest
- supportsModality(SqlModality) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- symbolPattern - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- Sync(int) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor.Sync
- SYNC - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- SynchronizationCommand() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.SynchronizationCommand
- synchronizeCommandSets() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Insures that the number of commands is the same for each thread, fills missing order value with null commands, and interleaves a synchronization command before each actual command.
- synchronizer - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Used to synchronize command execution.
T
- t - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- TAB_PATTERN - Static variable in class org.apache.calcite.util.TestUtil
- table - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- table - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.WrapperTable
- TABLE - Static variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- TableFunctionTest - Class in org.apache.calcite.test
-
Tests for user-defined table functions.
- TableFunctionTest() - Constructor for class org.apache.calcite.test.TableFunctionTest
- TableImpl() - Constructor for class org.apache.calcite.tools.FrameworksTest.TableImpl
- TableInRootSchemaTest - Class in org.apache.calcite.test
-
Test case for issue 85.
- TableInRootSchemaTest() - Constructor for class org.apache.calcite.test.TableInRootSchemaTest
- TableInRootSchemaTest.SimpleTable - Class in org.apache.calcite.test
-
Table with columns (A, B).
- TableMacroFunction() - Constructor for class org.apache.calcite.util.Smalls.TableMacroFunction
- TableMacroFunctionWithNamedParameters() - Constructor for class org.apache.calcite.util.Smalls.TableMacroFunctionWithNamedParameters
- tableNames - Variable in class org.apache.calcite.test.catalog.MockCatalogReader.MockSchema
- TableNameVisitor() - Constructor for class org.apache.calcite.test.MaterializationTest.TableNameVisitor
- tBoolean() - Method in class org.apache.calcite.test.RexProgramBuilderBase
- tBoolean(boolean) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- tearDown() - Method in class org.apache.calcite.test.DiffTestCase
- tearDown() - Method in class org.apache.calcite.test.InterpreterTest
- TempDb() - Constructor for class org.apache.calcite.test.MultiJdbcSchemaJoinTest.TempDb
- tens() - Static method in class org.apache.calcite.test.ScannableTableTest
- term() - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
-
Test for simple scalar terms (boolean, int etc.)
- terms() - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
- test() - Method in class org.apache.calcite.prepare.LookupOperatorOverloadsTest
- test() - Method in class org.apache.calcite.test.BabelQuidemTest
- test() - Method in class org.apache.calcite.test.FoodmartTest
- test() - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest
- test() - Method in class org.apache.calcite.test.QuidemTest
- test() - Method in class org.apache.calcite.test.ServerQuidemTest
- test(double, double, int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- test(float, float, int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- test(int, int, int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- test(long, long, int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- test(Object, Object, int, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
- TEST_CASE_NAME_ATTR - Static variable in class org.apache.calcite.test.DiffRepository
- TEST_CASE_OVERRIDES_ATTR - Static variable in class org.apache.calcite.test.DiffRepository
- TEST_CASE_TAG - Static variable in class org.apache.calcite.test.DiffRepository
- TEST_DURATION - Static variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- TEST_HOST - Static variable in class org.apache.calcite.adapter.file.FileSuite
- TEST_ITERATIONS - Static variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- test2() - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest
-
Makes sure that
MultiJdbcSchemaJoinTest.test()
is re-entrant. - testAbsFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAbsFuncIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAbstractConformance() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAccessNestedMap() - Method in class org.apache.calcite.test.CollectionTypeTest
- testAccessNestedMapWithAnyType() - Method in class org.apache.calcite.test.CollectionTypeTest
- testAccessNestedMapWithAnyTypeWithoutCast() - Method in class org.apache.calcite.test.CollectionTypeTest
- testAccessNonExistKeyFromMap() - Method in class org.apache.calcite.test.CollectionTypeTest
- testAccessNonExistKeyFromMapWithAnyType() - Method in class org.apache.calcite.test.CollectionTypeTest
- testAccessNonExistKeyFromNestedMap() - Method in class org.apache.calcite.test.CollectionTypeTest
- testAccessNonExistKeyFromNestedMapWithAnyType() - Method in class org.apache.calcite.test.CollectionTypeTest
- testAcosFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAddCarets() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testAddingTableInRootSchema() - Method in class org.apache.calcite.test.TableInRootSchemaTest
- testAddMissingGroupByColumnToProjectedFields() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
-
OQL Error: Query contains group by columns not present in projected fields Solution: Automatically expand the projections to include all missing GROUP By columns.
- testAddMonths() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testAddRedundantSemiJoinRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAdviceEmptyFrom() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testAdviceExpression() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testAdviceKeywordsJava() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testAdviceMixedCase() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testAggCaseInSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test aggregate function on a CASE expression involving IN with a sub-query.
- testAggCaseSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test aggregate function on a CASE expression involving a non-query IN
- testAggDistinct() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAggFilter() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAggFilterWithIn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAggFuncNoGroupBy() - Method in class org.apache.calcite.test.SparkAdapterTest
- testAggMultipleMeasures() - Method in class org.apache.calcite.test.JdbcTest
- testAggNoDuplicateColumnNames() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAggOnArithmeticProject() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAggOnArithmeticProject() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testAggOnArithmeticProject2() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAggOnArithmeticProject2() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testAggOnArithmeticProject3() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAggOnArithmeticProject3() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testAggOnTimeExtractColumn() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAggOnTimeExtractColumn2() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAggOnTimeExtractColumn2() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testAggOverStringToLong() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAggOverStringToLong() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testAggregate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testAggregate() - Method in class org.apache.calcite.test.MaterializationTest
-
Aggregation query at same level of aggregation as aggregation materialization.
- testAggregate() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregate2() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
-
Tests the version of
ExtendedEnumerable.aggregate(org.apache.calcite.linq4j.function.Function2<TSource, TSource, TSource>)
that has a result selector. - testAggregate2() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregate3() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregate4() - Method in class org.apache.calcite.test.RelBuilderTest
-
As
RelBuilderTest.testAggregate3()
but with Filter. - testAggregateAndScalarSubQueryInHaving() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-716] Scalar sub-query and aggregate function in SELECT or HAVING clause gives AssertionError; variant involving HAVING clause.
- testAggregateAndScalarSubQueryInSelect() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-716] Scalar sub-query and aggregate function in SELECT or HAVING clause gives AssertionError; variant involving SELECT clause.
- testAggregateConstantKeyRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAggregateConstantKeyRule2() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests
AggregateProjectPullUpConstantsRule
where reduction is not possible because "deptno" is the only key. - testAggregateConstantKeyRule3() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests
AggregateProjectPullUpConstantsRule
where both keys are constants but only one can be removed. - testAggregateCount() - Method in class org.apache.calcite.test.InterpreterTest
- testAggregateEmpty() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that SUM and AVG over empty set return null.
- testAggregateExpression() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testAggregateExtractProjectRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAggregateExtractProjectRuleWithFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAggregateExtractProjectRuleWithGroupingSets() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAggregateExtractProjectRuleWithGroupingSets2() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test with column used in both grouping set and argument to aggregate function.
- testAggregateFilter() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testAggregateFilter() - Method in class org.apache.calcite.test.JdbcTest
- testAggregateFilter() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateFilter() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateFilterContainsAggregate() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateFilterFails() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateFilterInHaving() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateFilterNotBoolean() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateFilterNullable() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateFunctionInOver() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateFunctions() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests columns based on types such as java.sql.Date and java.util.Date.
- testAggregateGroup() - Method in class org.apache.calcite.test.InterpreterTest
- testAggregateGroupFilter() - Method in class org.apache.calcite.test.InterpreterTest
- testAggregateGrouping() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateGroupingKeyOutOfRangeFails() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateGroupingSetDuplicateIgnored() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateGroupingSetNotSubsetFails() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateGroupingSetsProjectMerge() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAggregateGroupingWithDistinctFails() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateGroupingWithFilterFails() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateInGroupByFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateInNonGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateInOrderByFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateInsideOverClause() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateInsideOverClause2() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAggregateMaterializationAggregateFuncs1() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs10() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs11() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs12() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs13() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs14() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs15() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs16() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs17() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs18() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs19() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs2() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs3() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs4() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs5() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs6() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs7() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs8() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationAggregateFuncs9() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs1() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs2() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs3() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs4() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs5() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs6() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs7() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs8() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationNoAggregateFuncs9() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationOnCountDistinctQuery1() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationOnCountDistinctQuery2() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationOnCountDistinctQuery3() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMaterializationOnCountDistinctQuery4() - Method in class org.apache.calcite.test.MaterializationTest
- testAggregateMax() - Method in class org.apache.calcite.test.InterpreterTest
- testAggregateMin() - Method in class org.apache.calcite.test.InterpreterTest
- testAggregateNoGroup() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAggregateProject() - Method in class org.apache.calcite.test.MaterializationTest
-
Aggregation materialization with a project.
- testAggregateProjectMerge() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAggregateProjectPullUpConstants() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAggregateProjectPullUpConstants2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAggregateProjectWithAliases() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateProjectWithExpression() - Method in class org.apache.calcite.test.RelBuilderTest
- testAggregateRollUp() - Method in class org.apache.calcite.test.MaterializationTest
-
Aggregation query at coarser level of aggregation than aggregation materialization.
- testAggregationsWithComplexColumns() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests the use of other aggregations with complex columns
- testAggSameColumnMultipleTimes() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAggSameColumnMultipleTimes() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testAggScalarSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAggUnnestColumn() - Method in class org.apache.calcite.test.JdbcTest
- testAlias() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView13()
but using alias and condition of query is stronger. - testAlias() - Method in class org.apache.calcite.test.RelBuilderTest
- testAlias2() - Method in class org.apache.calcite.test.RelBuilderTest
- testAliasAggregate() - Method in class org.apache.calcite.test.RelBuilderTest
- testAliasedStar() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testAliasFilter() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests that table aliases are propagated and are available to a filter, even when there is a project on top of a project.
- testAliasInGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests validation of the aliases in GROUP BY.
- testAliasInHaving() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAliasInHaving() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests validation of the aliases in HAVING.
- testAliasLimit() - Method in class org.apache.calcite.test.RelBuilderTest
- testAliasList() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAliasList2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAliasPastTop() - Method in class org.apache.calcite.test.RelBuilderTest
-
Test case for [CALCITE-1523] Add RelBuilder field() method to reference aliased relations not on top of stack, accessing tables aliased that are not accessible in the top RelNode.
- testAliasPastTop2() - Method in class org.apache.calcite.test.RelBuilderTest
- testAliasProject() - Method in class org.apache.calcite.test.RelBuilderTest
-
Test case for [CALCITE-1551] RelBuilder's project() doesn't preserve alias.
- testAliasProjectProject() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests that table aliases are propagated even when there is a project on top of a project.
- testAliasSort() - Method in class org.apache.calcite.test.RelBuilderTest
- testAll() - Method in class org.apache.calcite.linq4j.function.FunctionTest
-
Unit test for
Functions.all(java.util.List<? extends E>, org.apache.calcite.linq4j.function.Predicate1<E>)
. - testAll() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testAll() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAllFoodmartQueries() - Method in class org.apache.calcite.test.LatticeTest
-
Runs all queries against the Foodmart schema, using a lattice.
- testAllList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testAllNull() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testAllPredicate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testAllPredicates() - Method in class org.apache.calcite.test.RelMetadataTest
- testAllPredicatesAggregate1() - Method in class org.apache.calcite.test.RelMetadataTest
- testAllPredicatesAggregate2() - Method in class org.apache.calcite.test.RelMetadataTest
- testAllPredicatesAggregate3() - Method in class org.apache.calcite.test.RelMetadataTest
- testAllPredicatesAndTablesJoin() - Method in class org.apache.calcite.test.RelMetadataTest
- testAllPredicatesAndTableUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testAllPredicatesCrossJoinMultiTable() - Method in class org.apache.calcite.test.RelMetadataTest
- testAllPredicatesUnionMultiTable() - Method in class org.apache.calcite.test.RelMetadataTest
- testAllTheSame() - Method in class org.apache.calcite.runtime.BinarySearchTest
- testAllValueList() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAlmostBushy() - Method in class org.apache.calcite.test.JdbcTest
-
Just short of bushy.
- testAlmostBushy() - Method in class org.apache.calcite.tools.PlannerTest
-
Plans a 3-table join query on the FoodMart schema.
- testAlreadyFalseEliminatesFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testAmbiguity() - Method in class org.apache.calcite.util.ReflectVisitorTest
-
Tests for ambiguity detection in method lookup.
- testAmbiguousColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAmbiguousColumnInIn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAmbiguousDynamicStar() - Method in class org.apache.calcite.test.SqlValidatorDynamicTest
-
Test case for [CALCITE-1150] Dynamic Table / Dynamic Star support.
- testAmbiguousDynamicStar2() - Method in class org.apache.calcite.test.SqlValidatorDynamicTest
- testAmbiguousDynamicStar3() - Method in class org.apache.calcite.test.SqlValidatorDynamicTest
- testAmbiguousDynamicStar4() - Method in class org.apache.calcite.test.SqlValidatorDynamicTest
- testAnd3() - Method in class org.apache.calcite.test.JdbcTest
-
Tests 3-way AND.
- testAndAlsoBoolTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testAndAlsoFalseBool() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testAndAlsoNullBool() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testAndAlsoTrueBool() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testAndAlsoXX() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testAndAlsoXY() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testAndCombinationOfComplexExpAndSimpleFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAndCombinationOfComplexExpAndSimpleFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testAndCombinationOfExpAndSimpleFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testAndCombinationOfExpAndSimpleFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testAndOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAndOperator2() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAndOperatorLazy() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAndOrIllegalTypesFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAnti() - Method in class org.apache.calcite.linq4j.test.CorrelateJoinTest
- testAny() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testAnyList() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAnyPredicate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testAnyValueAggregateFunctionGroupBy() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testAnyValueAggregateFunctionNoGroupBy() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-2366] Add support for ANY_VALUE aggregate function.
- testAnyValueFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAnyValueFunction() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAppendHttp() - Method in class org.apache.calcite.util.SourceTest
- testAppendWithSpaces() - Method in class org.apache.calcite.util.SourceTest
- testApply() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests CROSS APPLY, which is equivalent to CROSS JOIN and LEFT JOIN but only supported in some conformance levels (e.g.
- testApproxConstant() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
-
We use BigDecimal to represent literals of float and double using BigDecimal, because we want an exact representation.
- testApproxCountDistinctFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testArgumentBounds() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Test that calls all operators with all possible argument types, and for each type, with a set of tricky values.
- testArithmeticDiv() - Method in class org.apache.calcite.test.SparkAdapterTest
- testArithmeticMinus() - Method in class org.apache.calcite.test.SparkAdapterTest
- testArithmeticMul() - Method in class org.apache.calcite.test.SparkAdapterTest
- testArithmeticOperators() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testArithmeticOperators() - Method in class org.apache.calcite.test.SqlValidatorTest
- testArithmeticOperatorsFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testArithmeticPlus() - Method in class org.apache.calcite.test.SparkAdapterTest
- testArithmeticToAnyTypeWithoutCast() - Method in class org.apache.calcite.test.CollectionTypeTest
- testArray() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testArray() - Method in class org.apache.calcite.test.JdbcTest
-
Tests accessing a column in a JDBC source whose type is ARRAY.
- testArray2() - Method in class org.apache.calcite.test.JdbcTest
-
Tests the
CARDINALITY
function applied to an array column. - testArrayAssignment() - Method in class org.apache.calcite.test.SqlValidatorTest
- testArrayConstructor() - Method in class org.apache.calcite.test.JdbcTest
- testArrayConstructor() - Method in class org.apache.calcite.test.SqlValidatorTest
- testArrayElement() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testArrayElement() - Method in class org.apache.calcite.test.JdbcTest
- testArrayElementWithDot() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testArrayIndexing() - Method in class org.apache.calcite.test.JdbcTest
-
Tests array index.
- testArrayOfBoxedPrimitives() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Table with single field as Integer[]
- testArrayOfPrimitives() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Table with single field as int[]
- testArrayOfRecord() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testArrayOfRecordType() - Method in class org.apache.calcite.test.SqlValidatorTest
- testArrayPrecedenceList() - Method in class org.apache.calcite.sql.type.SqlTypeFactoryTest
-
Unit test for
ArraySqlType.getPrecedenceList()
. - testArraySort() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
-
Test for
Primitive.sortArray(Object)
. - testArrayToString() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
-
Test for
Primitive.arrayToString(Object)
. - testArrayUserDefinedFunction() - Method in class org.apache.calcite.test.UdfTest
-
Test case for [CALCITE-1834] User-defined function for Arrays.
- testArrayValueConstructor() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testArrayValueConstructor() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAs() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testAs() - Method in class org.apache.calcite.test.BabelParserTest
-
In Babel, AS is not reserved.
- testAsAliases() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testAsColumnList() - Method in class org.apache.calcite.test.SqlValidatorTest
- testAsIndexView() - Method in class org.apache.calcite.util.UtilTest
- testAsinFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAsList() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the methods
ImmutableBitSet.toList()
, andImmutableBitSet.asList()
andImmutableBitSet.asSet()
. - testAsQueryable() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testAssign() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testAssign2() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testAssignInConditionMultipleUsage() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testAssignInConditionMultipleUsageNonOptimized() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testAssignInConditionNotOptimizedWithoutFinal() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testAssignInConditionOptimizedOut() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testAtan2Func() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAtanFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAtom() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testAttributed() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
- testAutomaticTemporaryTable() - Method in class org.apache.calcite.test.JdbcTest
-
Tests saving query results into temporary tables, per
Handler.ResultSink
. - testAvaticaConnectionException() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testAvaticaStatementException() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testAvaticaStatementGetMoreResults() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testAverageRowSize() - Method in class org.apache.calcite.test.RelMetadataTest
-
Unit test for
RelMetadataQuery.getAverageColumnSizes(org.apache.calcite.rel.RelNode)
,RelMetadataQuery.getAverageRowSize(org.apache.calcite.rel.RelNode)
. - testAverageSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testAvgFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testAvgInt() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testBackTickIdentifier() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testBackTickQuery() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testBadDirectory() - Method in class org.apache.calcite.test.CsvTest
-
Tests an inline schema with a non-existent directory.
- testBadFieldName() - Method in class org.apache.calcite.test.RelBuilderTest
- testBadFieldOrdinal() - Method in class org.apache.calcite.test.RelBuilderTest
- testBadType() - Method in class org.apache.calcite.test.RelBuilderTest
- testBadUnionArgsErrorMessage() - Method in class org.apache.calcite.test.RelBuilderTest
- testBangEqualIsBad() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testBasic() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testBetween() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testBetween() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testBetween() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testBetween() - Method in class org.apache.calcite.test.SqlValidatorTest
- testBetweenAnd() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Test case that does not reproduce but is related to [CALCITE-2637] Prefix '-' operator failed between BETWEEN and AND.
- testBetweenAnd2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testBetweenFilterStringCase() - Method in class org.apache.calcite.adapter.druid.DruidQueryFilterTest
- testBetweenFilterWithCastOverNumeric() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test case for https://issues.apache.org/jira/browse/CALCITE-2123
- testBetweenFilterWithCastOverNumeric() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test case for https://issues.apache.org/jira/browse/CALCITE-2123
- testBigDecimalAndLong() - Method in class org.apache.calcite.test.UdfTest
- testBigDecimalLiteral() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
RexBuilder.makeExactLiteral(java.math.BigDecimal)
. - testBigint() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testBigIntegerValueOf() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testBijection() - Method in class org.apache.calcite.util.mapping.MappingTest
-
Unit test for
Mappings.bijection(List)
. - testBinary() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testBinaryString() - Method in class org.apache.calcite.test.SqlValidatorTest
- testBinaryStringFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testBinarySubstring() - Method in class org.apache.calcite.rex.RexExecutorTest
- testBind() - Method in class org.apache.calcite.test.SqlValidatorTest
- testBindBetween() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-1310] Infer type of arguments to BETWEEN operator.
- testBit() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testBitSetOf() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.of(int...)
. - testBitSetOfImmutableIntList() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.of(ImmutableIntList)
. - testBitSetOfImmutableIntList() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
ImmutableBitSet.of(org.apache.calcite.util.ImmutableIntList)
. - testBitSetsContains() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.contains(java.util.BitSet, java.util.BitSet)
. - testBitSetsContains() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
ImmutableBitSet.contains(org.apache.calcite.util.ImmutableBitSet)
. - testBitSetsRange() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.range(int, int)
. - testBitSetsToArray() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.toArray(java.util.BitSet)
. - testBitSetsUnion() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.union(java.util.BitSet, java.util.BitSet...)
. - testBitString() - Method in class org.apache.calcite.util.UtilTest
-
Unit-test for
BitString
. - testBitStringNotImplemented() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testBlob() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testBlockBuilder() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testBlockBuilder2() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testBlockBuilder3() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testBoolean() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testBoolean() - Method in class org.apache.calcite.test.CsvTest
- testBooleanFilterExpressions() - Method in class org.apache.calcite.test.DruidAdapterIT
- testBooleanFilterExpressions() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testBooleanPrecedenceAndAssociativity() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testBooleans() - Method in class org.apache.calcite.test.SqlValidatorTest
- testBooleanValueOfFalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testBox() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
- testBox() - Method in class org.apache.calcite.test.FilteratorTest
- testBracketIdentifier() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testBrackets() - Method in class org.apache.calcite.test.SqlValidatorTest
- testBreadthFirstIterator() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
-
Unit test for
BreadthFirstIterator
. - testBrokenCustomProvider() - Method in class org.apache.calcite.test.RelMetadataTest
- testBuilder() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testBuilderUseOriginal() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Unit test for
ImmutableBitSet.Builder.build(ImmutableBitSet)
. - testBuildProgram() - Method in class org.apache.calcite.test.RexProgramTest
-
Tests construction of a RexProgram.
- testBushy() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a query whose best plan is a bushy join.
- testBushy() - Method in class org.apache.calcite.tools.PlannerTest
-
Plans a 4-table join query on the FoodMart schema.
- testBushy5() - Method in class org.apache.calcite.tools.PlannerTest
-
Plans a 5-table join query on the FoodMart schema.
- testBushyCrossJoin() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests the bushy join algorithm where one table does not join to anything.
- testBushyCrossJoin2() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests the bushy join algorithm against a query where not all tables have a join condition to the others.
- testByteString() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testCalciteCaseJava() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseJavaException() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseJoinJava() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseJoinMySql() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseJoinMySqlAnsi() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseJoinOracle() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseJoinSqlServer() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseMySql() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseMySqlAnsi() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseMySqlAnsiNoException() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseMySqlNoException() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseOracle() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseOracleException() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseSqlServer() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCalciteCaseSqlServerNoException() - Method in class org.apache.calcite.sql.validate.LexCaseSensitiveTest
- testCallCenter() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testCamelToUpper() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
AvaticaUtils.camelToUpper(String)
. - testCannotPushProject() - Method in class org.apache.calcite.test.ScannableTableTest
- testCardinality() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCardinalityFunc() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCardinalityFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCarefulNegater() - Method in class org.apache.calcite.util.ReflectVisitorTest
-
Tests CarefulNumberNegater.
- testCarelessNegater() - Method in class org.apache.calcite.util.ReflectVisitorTest
-
Tests CarelessNumberNegater.
- testCartesianJoin() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a cartesian product aka cross join.
- testCartesianJoinWithoutKeyPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testCartesianProductEnumerator() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testCartesianProductWithCommaSyntax() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testCartesianProductWithInnerJoinSyntax() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testCase() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCase() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testCase() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testCase() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackTest
- testCase() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test one of the custom conversions which is recognized by the class of the operator (in this case,
SqlCaseOperator
). - testCase2() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testCaseExpression() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCaseExpression() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCaseExpressionFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCaseExpressionFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCaseExpressionTypes() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCaseInsensitive() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests using case-insensitive matching of identifiers.
- testCaseInsensitiveInsert() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests that it is an error to insert into the same column twice, even using case-insensitive matching.
- testCaseInsensitiveSubQuery() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests referencing columns from a sub-query that has duplicate column names.
- testCaseInsensitiveTableAlias() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCaseInsensitiveTableAliasInGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-1305] Case-insensitive table aliases and GROUP BY.
- testCaseInsensitiveTables() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests using case-insensitive matching of table names.
- testCaseName - Variable in class org.apache.calcite.test.DiffTestCase
- testCaseNull() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCasePushIsAlwaysWorking() - Method in class org.apache.calcite.test.RelOptRulesTest
- testCaseSensitiveSubQueryOracle() - Method in class org.apache.calcite.test.JdbcTest
- testCaseType() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCast() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testCast() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCast() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testCast() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testCastApproxNumericLimits() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastBinaryLiteral() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCastConcatOverPostAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCastConcatOverPostAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCastDateTime() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastDecimalToDoubleToInteger() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastExactNumericLimits() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCastFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCastFromString() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testCastInAggregateExpandDistinctAggregatesRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testCastInAggregateReduceFunctions() - Method in class org.apache.calcite.test.RelOptRulesTest
- testCastingList() - Method in class org.apache.calcite.util.UtilTest
-
Tests
CastingList
andUtil.cast(java.util.List<? super E>, java.lang.Class<E>)
. - testCastIntervalToInterval() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastIntervalToNumeric() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastIntToInt() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testCastIntToLong() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testCastIntToShort() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testCastInvalid() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Test case for [CALCITE-1439] Handling errors during constant reduction.
- testCastLiteral() - Method in class org.apache.calcite.test.RexProgramTest
- testCastLiteralToTimestamp() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCastLiteralToTimestamp() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCastLongVarchar1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testCastLongVarchar2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testCastNull() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastOverPostAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCastOverPostAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCastPlusMathOps() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCastPlusMathOps() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCastRegisteredType() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCastStringToDateTime() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastStringToDecimal() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastTimestamp() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCastToApproxNumeric() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastToBoolean() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastToExactNumeric() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastToInterval() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCastToInterval() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastToInterval() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCastToString() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastToVarchar() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCastTruncates() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCastTypeToType() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCastWithRoundingToScalar() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCatalogSchemaTableStar() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCatalogsLocal() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testCeil() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCeil() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testCeilEqRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testCeilFilterExpression() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCeilFilterExpression() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCeilFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCeilFuncDateTime() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCeilFuncInterval() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCeilGeRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testCeilGtRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testCeilLeRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testCeilLtRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testChar() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testCharacterLengthFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCharLength() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCharLength() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testCharLength() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Tests one of the custom conversions which is recognized by the identity of the operator (in this case,
SqlStdOperatorTable.CHARACTER_LENGTH
). - testCharLength() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCharLengthFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCharsetMismatch() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCheckingDuplicatesWithCompoundIdentifiers() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- testChunkList() - Method in class org.apache.calcite.util.ChunkListTest
-
Unit test for
ChunkList
. - TestClass() - Constructor for class org.apache.calcite.linq4j.test.DeterministicTest.TestClass
- testClassDecl() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testClassNames() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testClausesNotOnNewLine() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testClear() - Method in class org.apache.calcite.util.ChunkListTest
-
Clears lists of various sizes.
- testClear() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testClob() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testCloneGroupBy() - Method in class org.apache.calcite.test.JdbcTest
- testCloneGroupBy2() - Method in class org.apache.calcite.test.JdbcTest
- testCloneGroupBy2Plan() - Method in class org.apache.calcite.test.JdbcTest
-
Tests plan for a query with 4 tables, 3 joins.
- testCloneQueries() - Method in class org.apache.calcite.test.JdbcTest
-
A selection of queries generated by Mondrian.
- testCloneSchema() - Method in class org.apache.calcite.test.JdbcTest
- testClosure() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.closure(java.util.SortedMap)
- testClosure() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
BitSets.closure(java.util.SortedMap)
. - testCluelessNegater() - Method in class org.apache.calcite.util.ReflectVisitorTest
-
Tests CluelessNumberNegater.
- testCnf() - Method in class org.apache.calcite.test.RexProgramTest
-
Unit test for
RexUtil.toCnf(org.apache.calcite.rex.RexBuilder, org.apache.calcite.rex.RexNode)
. - testCnf2() - Method in class org.apache.calcite.test.RexProgramTest
- testCnfExponential() - Method in class org.apache.calcite.test.RexProgramTest
-
Tests formulas of various sizes whose size is exponential when converted to CNF.
- testCoalesce() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCoalesce() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCoalesceFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCoalesceFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCoalesceWithoutRewrite() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCoalesceWithRewrite() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCogroup() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testCollation() - Method in class org.apache.calcite.test.RelMetadataTest
-
Unit test for
RelMdCollation.project(org.apache.calcite.rel.metadata.RelMetadataQuery, org.apache.calcite.rel.RelNode, java.util.List<? extends org.apache.calcite.rex.RexNode>)
and other helper functions for deducing collations. - testCollationCompare() - Method in class org.apache.calcite.rel.RelCollationTest
-
Unit test for
RelCollationImpl.compareTo(org.apache.calcite.plan.RelMultipleTrait)
. - testCollationContains() - Method in class org.apache.calcite.rel.RelCollationTest
-
Unit test for
RelCollations.contains(org.apache.calcite.rel.RelCollation, java.lang.Iterable<java.lang.Integer>)
. - testCollationConversion() - Method in class org.apache.calcite.plan.volcano.CollationConversionTest
- testCollect() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCollectFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCollectionTable() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCollectionTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCollectionTable() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCollectionTableWithColumnListParam() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCollectionTableWithCursorParam() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCollectionTableWithCursorParam() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCollectionTableWithCursorParam() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCollectionTableWithLateral() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCollectionTableWithLateral() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCollectionTableWithLateral() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-1309] Support LATERAL TABLE.
- testCollectionTableWithLateral2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCollectionTableWithLateral2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCollectionTableWithLateral2() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCollectionTableWithLateral3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCollectionTableWithLateral3() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testColumnAEqColumnB() - Method in class org.apache.calcite.test.DruidAdapterIT
- testColumnAEqColumnB() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testColumnAliasWithAs() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testColumnAliasWithoutAs() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testColumnANotEqColumnB() - Method in class org.apache.calcite.test.DruidAdapterIT
- testColumnANotEqColumnB() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testColumnCount() - Method in class org.apache.calcite.test.LatticeTest
-
Unit test for
Lattice.getRowCount(double, List)
. - testColumnNotFound() - Method in class org.apache.calcite.test.SqlValidatorTest
- testColumnNotFound2() - Method in class org.apache.calcite.test.SqlValidatorTest
- testColumnNotFound3() - Method in class org.apache.calcite.test.SqlValidatorTest
- testColumnNotFoundDidYouMean() - Method in class org.apache.calcite.test.SqlValidatorTest
- testColumnNullability() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testColumnOriginsAggCountNullable() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsAggCountStar() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsAggKey() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsAggReduced() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsConstant() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsDyadicExpression() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsExpression() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsJoinFullOuter() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsJoinLeft() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsJoinOuter() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsJoinRight() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsSelfUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsTableOnly() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumnOriginsValues() - Method in class org.apache.calcite.test.RelMetadataTest
- testColumns() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackTest
- testColumnTypes() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests columns based on types such as java.sql.Date and java.util.Date.
- testColumnUniquenessForValues() - Method in class org.apache.calcite.test.RelMetadataTest
-
Unit test for
RelMdColumnUniqueness.areColumnsUnique(org.apache.calcite.rel.core.TableScan, org.apache.calcite.rel.metadata.RelMetadataQuery, org.apache.calcite.util.ImmutableBitSet, boolean)
applied toValues
. - testCombinationOfValidAndNotValidAndInterval() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test case for [CALCITE-2122] DateRangeRules issues.
- testCombinationOfValidAndNotValidAndInterval() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test case for [CALCITE-2122] DateRangeRules issues.
- testCombinationOfValidAndNotValidFilters() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCombinationOfValidAndNotValidFilters() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCombo() - Method in class org.apache.calcite.plan.volcano.ComboRuleTest
- testCommaList() - Method in class org.apache.calcite.util.UtilTest
-
Tests
Util.commaList(java.util.List)
. - testCommonSubExpression() - Method in class org.apache.calcite.test.HepPlannerTest
-
Tests that if two relational expressions are equivalent, the planner notices, and only applies the rule once.
- testCompare() - Method in class org.apache.calcite.test.SqlFunctionsTest
-
Unit test for
Utilities.compare(java.util.List, java.util.List)
. - testCompare() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testCompare2() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testCompareJavaAndSqlTypes() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testCompareTimestampWithTimeZone() - Method in class org.apache.calcite.test.RexProgramTest
- testComparingIntAndString() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-980] different flavors of boolean logic.
- testCompile() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testComplexExpressionsIsNull() - Method in class org.apache.calcite.test.DruidAdapterIT
- testComplexExpressionsIsNull() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testComplexLiteral() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testComplexMetricAlsoDimension() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to make sure that if a complex metric is also a dimension, then
DruidTable
should allow it to be used like any other column. - testComplexMetricAlsoDimension() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to make sure that if a complex metric is also a dimension, then
DruidTable
should allow it to be used like any other column. - testComplexPushGroupBy() - Method in class org.apache.calcite.test.DruidAdapterIT
- testComplexPushGroupBy() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testComposeMatcher() - Method in class org.apache.calcite.util.UtilTest
- testCompositeGroupBy() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testCompositeInUncorrelatedSubQueryRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCompositeList() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
CompositeList
. - testCompositeMap() - Method in class org.apache.calcite.util.UtilTest
- testCompoundStar() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testConcat() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testConcat() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testConcat() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testConcat() - Method in class org.apache.calcite.test.SqlValidatorTest
- testConcatFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testConcatOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testConcatWithCharset() - Method in class org.apache.calcite.test.SqlValidatorTest
- testConditionalIfBoolFalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionalIfBoolFalseElse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionalIfBoolFalseTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionalIfBoolTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionalIfBoolTrueElse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionalIfFalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionalIfFalseElse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionalIfTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionalIfTrueElse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testConditionOffByOne() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-245] Off-by-one translation of ON clause of JOIN.
- testConditionOffByOneReversed() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testConnectionProperties() - Method in class org.apache.calcite.test.JdbcTest
-
Test for
UnregisteredDriver.getPropertyInfo(String, Properties)
. - testCons() - Method in class org.apache.calcite.util.UtilTest
- testConsPerformance() - Method in class org.apache.calcite.util.UtilTest
- testConstant() - Method in class org.apache.calcite.rex.RexExecutorTest
- testConstant2() - Method in class org.apache.calcite.rex.RexExecutorTest
-
Reduces several expressions to constants.
- testConstantExpression() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testConstantIsConstant() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testConstantMap() - Method in class org.apache.calcite.test.RexProgramTest
- testConstantPostAggregator() - Method in class org.apache.calcite.test.DruidAdapterIT
- testConstantPostAggregator() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testContains() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testContains() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testContains() - Method in class org.apache.calcite.test.SqlValidatorTest
- testContainsValue() - Method in class org.apache.calcite.linq4j.test.LookupImplTest
- testContainsWithEqualityComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testContinuedLiteral() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testConvert() - Method in class org.apache.calcite.test.RelBuilderTest
- testConvertAggregate() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertAndTranslate() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testConvertCalc() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertCollect() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertCorrelate() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertFilter() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testConvertIntersect() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertJoin() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertMinus() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertMultiJoinRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testConvertMultiJoinRuleOuterJoins() - Method in class org.apache.calcite.test.RelOptRulesTest
- testConvertMultiJoinRuleOuterJoins2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testConvertMultiJoinRuleOuterJoins3() - Method in class org.apache.calcite.test.RelOptRulesTest
- testConvertMultiJoinRuleOuterJoins4() - Method in class org.apache.calcite.test.RelOptRulesTest
- testConvertProject() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertRename() - Method in class org.apache.calcite.test.RelBuilderTest
- testConvertSample() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertSemiJoin() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertSort() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertTableFunctionScan() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertTableModify() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertUncollect() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertUnion() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertValues() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertWindow() - Method in class org.apache.calcite.test.MutableRelTest
- testConvertWithoutValidateFails() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests that planner throws an error if you pass to
Planner.rel(org.apache.calcite.sql.SqlNode)
aSqlNode
that has been parsed but not validated. - testCorrelatedScalarSubQuery() - Method in class org.apache.calcite.test.JdbcTest
- testCorrelatedSubQueryInAggregate() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCorrelatedSubQueryInJoin() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCorrelateUniqueKeys() - Method in class org.apache.calcite.test.RelMetadataTest
- testCorrelatingVariables() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCorrelationExistsAndFilter() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case (correlated EXISTS sub-query) for [CALCITE-714] When de-correlating, push join condition into sub-query.
- testCorrelationExistsAndFilterRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCorrelationExistsAndFilterThetaRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
A theta join condition, unlike the equi-join condition in
SqlToRelConverterTest.testCorrelationExistsAndFilterRex()
, requires a value generator. - testCorrelationFails() - Method in class org.apache.calcite.test.RelBuilderTest
- testCorrelationJoin() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCorrelationJoin() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCorrelationJoinRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCorrelationMultiScalarAggregate() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCorrelationNotExistsAndFilter() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case (correlated NOT EXISTS sub-query) for [CALCITE-714] When de-correlating, push join condition into sub-query.
- testCorrelationScalarAggAndFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testCorrelationScalarAggAndFilter() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case (correlated scalar aggregate sub-query) for [CALCITE-714] When de-correlating, push join condition into sub-query.
- testCorrelationScalarAggAndFilterRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCorrelationWithCondition() - Method in class org.apache.calcite.test.RelBuilderTest
- testCosFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCotFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCount() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testCount() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testCountColumn() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCountColumn2() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCountCompositeFunction() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCountDistinctOnComplexColumn() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests the use of count(distinct ...) on a complex metric column in SELECT
- testCountFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCountFunction() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCountGroupByEmpty() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testCountGroupByEmpty() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCountGroupByEmpty() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCountGroupByEmptyMultiplyBy2() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testCountInGroupBy() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testCountNoGroup() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCountOnMetric() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that a count on a metric does not get pushed into Druid
- testCountOnMetric() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that a count on a metric does not get pushed into Druid
- testCountOnMetricRenamed() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCountOnMetricRenamed() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCountOverVirtualColumn() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCountOverVirtualColumn() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCountPredicate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testCountStar() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testCountStar() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that count(*) is pushed into Druid
- testCountStar() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that count(*) is pushed into Druid
- testCountStar() - Method in class org.apache.calcite.test.JdbcTest
-
Query that reads no columns from either underlying table.
- testCountUnionAll() - Method in class org.apache.calcite.test.JdbcTest
-
Same result (and plan) as
JdbcTest.testSelectDistinct()
. - testCountViaInt() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
Test case for [CALCITE-665] ClassCastException in MongoDB adapter.
- testCountWithApproxDistinct(boolean, String, String) - Method in class org.apache.calcite.test.DruidAdapterIT
- testCountWithApproxDistinct(boolean, String, String) - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCountWithApproxDistinct(boolean, String, String, String) - Method in class org.apache.calcite.test.DruidAdapterIT
- testCountWithApproxDistinct(boolean, String, String, String) - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCountWithNonNull() - Method in class org.apache.calcite.test.DruidAdapterIT
- testCountWithNonNull() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testCovarPopFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCovarSampFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCreateForeignSchema() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateForeignSchema2() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateLongBuffer() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testCreateLongs() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testCreateMaterializedView() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateMaterializedView2() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateOrReplaceFunction() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateOrReplaceFunction2() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateOrReplaceMaterializedView() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateOrReplaceSchema() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateOrReplaceTypeWith() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateRootSchemaWithNoMetadataSchema() - Method in class org.apache.calcite.tools.FrameworksTest
-
Unit test to test create root schema which has no "metadata" schema.
- testCreateSchema() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateSchema() - Method in class org.apache.calcite.test.ServerTest
- testCreateTable() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateTable() - Method in class org.apache.calcite.test.ServerTest
- testCreateTableAsSelect() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateTableAsSelectColumnList() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateTableAsValues() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateTableCheck() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateTableIfNotExistsAsSelect() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateTableVirtualColumn() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateType() - Method in class org.apache.calcite.test.ServerTest
- testCreateTypeWithAttributeList() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateTypeWithBaseType() - Method in class org.apache.calcite.test.ServerParserTest
- testCreateView() - Method in class org.apache.calcite.test.ServerParserTest
- testCross() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testCrossApply() - Method in class org.apache.calcite.test.TableFunctionTest
- testCrossJoinOnFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCrossJoinUsingFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCrossJoinWithJoinKeyAndFilterPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testCrossJoinWithJoinKeyPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testCrossOuterApply() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testCsvFile() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests reading a CSV file via the file adapter.
- testCsvSalesDepts() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads the DEPTS table from the CSV schema.
- testCsvSalesEmps() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads the EMPS table from the CSV schema.
- testCsvSalesEmpty() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads the EMPTY table from the CSV schema.
- testCsvSalesHeaderOnly() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads the HEADER_ONLY table from the CSV schema.
- testCsvStream() - Method in class org.apache.calcite.test.CsvTest
- testCube() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testCube() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCubeBitSets() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Unit test for
SqlValidatorUtil.cube(java.util.List<org.apache.calcite.util.ImmutableBitSet>)
. - testCubeExpression() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-1781] Allow expression in CUBE and ROLLUP.
- testCubeGrouping() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCumeDistFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCurrentCatalogFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCurrentDateFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCurrentPathFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCurrentRoleFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCurrentTimeFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCurrentTimestamp() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that CURRENT_TIMESTAMP gives different values each time a statement is executed.
- testCurrentTimestampFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCurrentUserFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testCustomBoxedSalarCalc() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testCustomBoxedScalar() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testCustomColumnResolving() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCustomColumnResolving() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCustomColumnResolving2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCustomColumnResolving3() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCustomColumnResolving4() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCustomColumnResolving5() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCustomColumnResolvingInCorrelatedSubQuery() - Method in class org.apache.calcite.test.RelOptRulesTest
- testCustomColumnResolvingInCorrelatedSubQuery2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testCustomColumnResolvingInNonCorrelatedSubQuery() - Method in class org.apache.calcite.test.RelOptRulesTest
- testCustomColumnResolvingWithSelectFieldNameDotStar() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCustomColumnResolvingWithSelectStar() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testCustomColumnResolvingWithView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testCustomer() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testCustomer5() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
-
Tests the customer table with scale factor 5.
- testCustomer5() - Method in class org.apache.calcite.adapter.tpch.TpchTest
-
Tests the customer table with scale factor 5.
- testCustomProvider() - Method in class org.apache.calcite.test.RelMetadataTest
- testCustomSchema() - Method in class org.apache.calcite.test.ModelTest
-
Reads a custom schema.
- testCustomSchemaDirectConnection() - Method in class org.apache.calcite.test.JdbcTest
-
Connects to a custom schema without writing a model.
- testCustomSchemaInFileInPwd() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-1360] Custom schema in file in current directory.
- testCustomSchemaWithoutFactory() - Method in class org.apache.calcite.test.ModelTest
- testCustomTable() - Method in class org.apache.calcite.test.CsvTest
- testCycleDetection() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
-
Unit test for
CycleDetector
. - testDamiansSubQueryStyle() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- TestDataContext(Object[]) - Constructor for class org.apache.calcite.rex.RexExecutorTest.TestDataContext
- testDatalink() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testDate() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
Test case for [CALCITE-286] Error casting MongoDB date.
- testDate() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testDate() - Method in class org.apache.calcite.test.UdfTest
- testDateAndTimestamp() - Method in class org.apache.calcite.test.UdfTest
- testDateCanCompare() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testDateColumn() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests column based on java.sql.Date field.
- testDateCompare() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-613] Implicitly convert strings in comparisons.
- testDateLiteral() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
RexBuilder.makeDateLiteral(DateString)
. - testDateLiteral() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDateMinusDate() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDatePlusInterval() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDateStringDayError() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
DateString
day range. - testDateStringMonthError() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
DateString
month range. - testDateStringYearError() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
DateString
year range. - testDateTime() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDateTimeCast() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests for casting to/from date/time types.
- testDateTimeCast() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests casting to/from date/time types.
- testDatetimePlusNullInterval() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDateType() - Method in class org.apache.calcite.test.CsvTest
- testDateType2() - Method in class org.apache.calcite.test.CsvTest
- testDayOfMonth() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDayOfWeek() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDayOfYear() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDb2DialectCast() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectJoin() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectJoinStar() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectJoinWhere() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectSelectQueryComplex() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectSelectQueryWithGroup() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectSelectQueryWithGroupByHaving() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectSelfJoin() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectSelfJoinStar() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectSelfJoinWhere() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDb2DialectWhere() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testDecimal() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testDecimalLiteral() - Method in class org.apache.calcite.rex.RexBuilderTest
- testDecodeFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDecorrelateExists() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDecorrelateScalarAggregate() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testDecorrelateTwoExists() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDecorrelateTwoIn() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDecorrelateTwoScalar() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-1045] Decorrelate sub-queries in Project and Join, with the added complication that there are two sub-queries.
- testDecorrelateUncorrelatedInAndCorrelatedExists() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDefault() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDefault() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testDefaultIfEmpty() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testDefaultIfEmpty2() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testDefine() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testDegreesFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDejsonize() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testDelete() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDelete() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- testDelete() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDelete() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteBind() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDeleteBind() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteBindExtendedColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDeleteBindExtendedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteBindExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDeleteBindModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDeleteExtendedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteExtendedColumnCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteExtendedColumnFailCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteExtendedColumnFailDuplicate() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteExtendedColumnModifiableViewCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteExtendedColumnModifiableViewFailCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteExtendedColumnModifiableViewFailExtendedCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteModifiableView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDeleteWhere() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDeleteWhere() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDenseRankFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDepthFirst() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
-
Unit test for
DepthFirstIterator
. - testDerivedColumnList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDerivedColumnListInJoin() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDerivedColumnListNoAs() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDesc() - Method in class org.apache.calcite.test.BabelParserTest
-
In Babel, DESC is not reserved.
- testDescendingOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDescribeSchema() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDescribeStatement() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDescribeTable() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testDeterministic1() - Method in class org.apache.calcite.rex.RexExecutorTest
- testDeterministic2() - Method in class org.apache.calcite.rex.RexExecutorTest
- testDeterministic3() - Method in class org.apache.calcite.rex.RexExecutorTest
- TestDeterministicClass() - Constructor for class org.apache.calcite.linq4j.test.DeterministicTest.TestDeterministicClass
- testDeterministicClassDefaultMethod() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testDeterministicClassNonDeterministicMethod() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testDeterministicMethodCall() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testDialect() - Method in class org.apache.calcite.test.JdbcTest
-
Tests
SqlDialect
. - testDifferentColumnNames() - Method in class org.apache.calcite.test.MaterializationTest
- testDifferentType() - Method in class org.apache.calcite.test.MaterializationTest
- testDifferentTypesSameFields() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for bug where if two tables have different element classes but those classes have identical fields, Calcite would generate code to use the wrong element class; a
ClassCastException
would ensue. - testDiffLines() - Method in class org.apache.calcite.util.UtilTest
-
Tests the difference engine,
DiffTestCase.diff(java.io.File, java.io.File)
. - testDimensionIsInvalidColumn() - Method in class org.apache.calcite.test.LatticeTest
- testDistinct() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testDistinct() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testDistinct() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testDistinct() - Method in class org.apache.calcite.test.RelBuilderTest
- testDistinct() - Method in class org.apache.calcite.test.SqlValidatorFeatureTest
- testDistinct() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Util.isDistinct(java.util.List)
. - testDistinctAlready() - Method in class org.apache.calcite.test.RelBuilderTest
- testDistinctCount() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testDistinctCount() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests that distinct-count is pushed down to Druid and evaluated using "cardinality".
- testDistinctCount() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests that distinct-count is pushed down to Druid and evaluated using "cardinality".
- testDistinctCount() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testDistinctCount() - Method in class org.apache.calcite.test.JdbcTest
- testDistinctCount() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a distinct-count query.
- testDistinctCount1() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCount2() - Method in class org.apache.calcite.test.JdbcTest
- testDistinctCount2() - Method in class org.apache.calcite.test.LatticeTest
- testDistinctCount2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCount3() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCountComposite() - Method in class org.apache.calcite.test.JdbcTest
- testDistinctCountGroupingSets1() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCountGroupingSets2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCountMixed() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCountMixed2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCountMixedJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCountMultiple() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests implementing multiple distinct count the new way, using GROUPING SETS.
- testDistinctCountMultipleNoGroup() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctCountMultipleViaJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests implementing multiple distinct count the old way, using a join.
- testDistinctCountOnMetric() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDistinctCountOnMetric() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDistinctCountOnMetricRenamed() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDistinctCountOnMetricRenamed() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDistinctCountOrderBy() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testDistinctCountSimple() - Method in class org.apache.calcite.test.JdbcTest
- testDistinctCountWhenApproxResultsAccepted() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that count(distinct ...) gets pushed to Druid when approximate results are acceptable
- testDistinctCountWhenApproxResultsAccepted() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that count(distinct ...) gets pushed to Druid when approximate results are acceptable
- testDistinctCountWhenApproxResultsNotAccepted() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that count(distinct ...) doesn't get pushed to Druid when approximate results are not acceptable
- testDistinctCountWhenApproxResultsNotAccepted() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that count(distinct ...) doesn't get pushed to Druid when approximate results are not acceptable
- testDistinctCountWithoutGroupBy() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctEmpty() - Method in class org.apache.calcite.test.RelBuilderTest
- testDistinctExample() - Method in class org.apache.calcite.test.PigletTest
- testDistinctLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDistinctLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDistinctList() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Util.distinctList(List)
andUtil.distinctList(Iterable)
. - testDistinctNonDistinctAggregates() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctNonDistinctAggregatesWithGrouping1() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctNonDistinctAggregatesWithGrouping2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctNonDistinctTwoAggregatesWithGrouping() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctRowCountTable() - Method in class org.apache.calcite.test.RelMetadataTest
- testDistinctRowCountTableEmptyKey() - Method in class org.apache.calcite.test.RelMetadataTest
- testDistinctWithEqualityComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testDistinctWithGrouping() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctWithMultipleInputs() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistinctWithMultipleInputsAndGroupby() - Method in class org.apache.calcite.test.RelOptRulesTest
- testDistributionHash() - Method in class org.apache.calcite.test.RelMetadataTest
- testDistributionHashEmpty() - Method in class org.apache.calcite.test.RelMetadataTest
- testDistributionSimple() - Method in class org.apache.calcite.test.RelMetadataTest
- testDistributionSingleton() - Method in class org.apache.calcite.test.RelMetadataTest
- testDivideAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testDivideArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDivideArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDivideByZeroDoubleTypeInfinity() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDivideByZeroDoubleTypeInfinity() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDivideByZeroDoubleTypeNaN() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDivideByZeroDoubleTypeNaN() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDivideByZeroDoubleTypeNegInfinity() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDivideByZeroDoubleTypeNegInfinity() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDivideByZeroIntegerType() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDivideByZeroIntegerType() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDivideOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDivideOperatorIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testDivideWraperPrimitive() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testDivideWraperWrapper() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testDivideWraperWrapperMultipleTimes() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testDivisorInverseRandom() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testDivisorInverseRandomWithRemoval() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testDivisorInverseSeries() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testDivisorPoset() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testDivisorRandom() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testDivisorRandomWithRemoval() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testDivisorSeries() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testDotLiteralAfterNestedRow() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDotLiteralAfterRow() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDouble() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testDoubleConversion() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
- testDoubleNoAlias() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDown() - Method in class org.apache.calcite.test.RexTransformerTest
- testDropForeignSchema() - Method in class org.apache.calcite.test.ServerParserTest
- testDropFunction() - Method in class org.apache.calcite.test.ServerParserTest
- testDropFunctionIfExists() - Method in class org.apache.calcite.test.ServerParserTest
- testDropMaterializedView() - Method in class org.apache.calcite.test.ServerParserTest
- testDropMaterializedViewIfExists() - Method in class org.apache.calcite.test.ServerParserTest
- testDropSchema() - Method in class org.apache.calcite.test.ServerParserTest
- testDropSchemaIfExists() - Method in class org.apache.calcite.test.ServerParserTest
- testDropTable() - Method in class org.apache.calcite.test.ServerParserTest
- testDropTableComposite() - Method in class org.apache.calcite.test.ServerParserTest
- testDropTableIfExists() - Method in class org.apache.calcite.test.ServerParserTest
- testDropType() - Method in class org.apache.calcite.test.ServerParserTest
- testDropType() - Method in class org.apache.calcite.test.ServerTest
- testDropTypeIfExists() - Method in class org.apache.calcite.test.ServerParserTest
- testDropTypeTrailingIfExistsFails() - Method in class org.apache.calcite.test.ServerParserTest
- testDropView() - Method in class org.apache.calcite.test.ServerParserTest
- testDruidTimeFloorAndTimeParseExpressions() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDruidTimeFloorAndTimeParseExpressions() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDruidTimeFloorAndTimeParseExpressions2() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDruidTimeFloorAndTimeParseExpressions2() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDu() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testDuFilterSortLimit() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testDummy() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
For development.
- testDummy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDump() - Method in class org.apache.calcite.test.PigletTest
- testDumpValues() - Method in class org.apache.calcite.test.PigletTest
-
VALUES is an extension to Pig.
- testDuplicateAnd() - Method in class org.apache.calcite.test.RexProgramTest
-
Checks translation of AND(x, x).
- testDuplicateColumnAliasIsOK() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDuplicateColumnsInSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Tests referencing columns from a sub-query that has duplicate column names.
- testDuplicateGroupingSets() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
GROUP BY with duplicate (and heavily nested) GROUPING SETS.
- testDuplicateReferenceOnPostAggregation() - Method in class org.apache.calcite.test.DruidAdapterIT
- testDuplicateReferenceOnPostAggregation() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testDuplicateSortPlan() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that parses, validates, converts and plans for query using two duplicate order by.
- testDuplicateSortPlanWithExpr() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that parses, validates, converts and plans for query using two duplicate order by.
- testDuplicateSortPlanWithOver() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests that outer order by is not removed since window function might reorder the rows in-between
- testDuplicateSortPlanWORemoveSortRule() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that parses, validates, converts and plans for query using two duplicate order by.
- testDuplicateTableAliasFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testDynamicNestedColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDynamicSchemaUnnest() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testDynamicStar2() - Method in class org.apache.calcite.test.SqlValidatorDynamicTest
-
When resolve column reference, regular field has higher priority than dynamic star columns.
- testDynamicStarInJoinAndSubQ() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for Dynamic Table / Dynamic Star support [CALCITE-1150]
- testDynamicStarInTableJoin() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for Dynamic Table / Dynamic Star support [CALCITE-1150]
- testDynStarInExistSubQ() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for Dynamic Table / Dynamic Star support [CALCITE-1150]
- testElement() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testElement() - Method in class org.apache.calcite.test.SqlValidatorTest
- testElementAt() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testElementAtOrDefault() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testElementAtOrDefaultWithoutList() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testElementAtWithoutList() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testElementFunc() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testElementFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testElementInValues() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testElimDups() - Method in class org.apache.calcite.test.RexProgramTest
-
Tests construction and normalization of a RexProgram.
- testEmbeddedCall() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testEmbeddedDate() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testEmbeddedFunction() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testEmbeddedTime() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testEmbeddedTimestamp() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testEmpDept() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
-
Some basic query patterns on the Scott schema with "EMP" and "DEPT" tables.
- testEmpty() - Method in class org.apache.calcite.runtime.BinarySearchTest
- testEmpty() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackTest
-
Tests a JDBC method known to be not implemented (as it happens,
DatabaseMetaData.getPrimaryKeys(java.lang.String, java.lang.String, java.lang.String)
) that therefore uses empty result set. - testEmpty() - Method in class org.apache.calcite.test.RelBuilderTest
- testEmpty() - Method in class org.apache.calcite.util.PermutationTestCase
- testEmptyAggregate() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyAggregateEmptyKey() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyAggregateEmptyKeyWithAggregateValuesRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyAggregateTableOrigin() - Method in class org.apache.calcite.test.RelMetadataTest
-
Tests calling
RelMetadataQuery.getTableOrigin(org.apache.calcite.rel.RelNode)
for an aggregate with no columns. - testEmptyEnumerable() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testEmptyFilterProjectUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyIntersect() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyJoinLeft() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyJoinRight() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyListLiteral() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testEmptyMapLiteral() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testEmptyMinus() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyMinus2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyProject() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-1488] ValuesReduceRule should ignore empty Values.
- testEmptyProject2() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Same query as
RelOptRulesTest.testEmptyProject()
, andPruneEmptyRules
is able to do the job thatValuesReduceRule
cannot do. - testEmptySort() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptySortLimitZero() - Method in class org.apache.calcite.test.RelOptRulesTest
- testEmptyValues() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testEneElementListLiteral() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testEnsureTypeWithAny() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Test RexBuilder.ensureType()
- testEnsureTypeWithDifference() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Test RexBuilder.ensureType()
- testEnsureTypeWithItself() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Test RexBuilder.ensureType()
- testEnumConstants() - Method in class org.apache.calcite.util.UtilTest
-
Tests the methods
Util.enumConstants(Class)
andUtil.enumVal(Class, String)
. - testEnumerableWithJdbcJoin() - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest
- testEnumerableWithJdbcJoinWithWhereClause() - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest
- testEqualBoolFalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualBoolTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualDifferentConst() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualDifferentExpr() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualNotEqual() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testEqualNotEqual() - Method in class org.apache.calcite.test.SqlValidatorTest
- testEqualNotEqualFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testEqualObjectNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualPrecedence() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testEqualPrimitiveNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualSameConst() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualSameExpr() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualsOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testEqualsOperatorInterval() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testEqualStringNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualTypedNullUntypedNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEqualUnypedNullTypedNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testEquiJoinPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testEquiThetaJoin() - Method in class org.apache.calcite.test.JdbcTest
-
A join that has both equi and non-equi conditions.
- testEquivalenceSet() - Method in class org.apache.calcite.util.UtilTest
- testEqWithAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- tester - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- tester - Variable in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- tester - Variable in class org.apache.calcite.test.SqlToRelTestBase
- tester - Variable in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- tester - Variable in class org.apache.calcite.test.SqlValidatorTestCase
- tester() - Static method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- tester(boolean, Object) - Method in class org.apache.calcite.test.enumerable.EnumerableCorrelateTest
- tester(SqlTester) - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- Tester() - Constructor for class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- Tester() - Constructor for class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- Tester(FrameworkConfig) - Constructor for class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- Tester(FrameworkConfig) - Constructor for class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- TESTER_CONFIGURATION_RULE - Static variable in class org.apache.calcite.test.SqlValidatorTestCase
- TesterConfigurationRule() - Constructor for class org.apache.calcite.test.SqlValidatorTestCase.TesterConfigurationRule
- TesterImpl() - Constructor for class org.apache.calcite.sql.parser.SqlParserTest.TesterImpl
- TesterImpl(SqlTestFactory) - Constructor for class org.apache.calcite.sql.test.SqlOperatorBaseTest.TesterImpl
- TesterImpl(DiffRepository, boolean, boolean, boolean, boolean, SqlTestFactory.MockCatalogReaderFactory, Function<RelOptCluster, RelOptCluster>) - Constructor for class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
-
Creates a TesterImpl.
- TesterImpl(DiffRepository, boolean, boolean, boolean, boolean, SqlTestFactory.MockCatalogReaderFactory, Function<RelOptCluster, RelOptCluster>, SqlToRelConverter.Config, SqlConformance, Context) - Constructor for class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- testEscapeOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testEvolve() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testExactLiteral() - Method in class org.apache.calcite.test.RexTransformerTest
- testExample() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testExcept() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testExcept() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExcept() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Tests EXCEPT.
- testExcept() - Method in class org.apache.calcite.test.JdbcTest
- testExcept() - Method in class org.apache.calcite.test.RelBuilderTest
- testExcept() - Method in class org.apache.calcite.test.SqlValidatorFeatureTest
- testExceptionCleanup() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests that when there is an error, non-reserved keywords such as "A", "ABSOLUTE" (which naturally arise whenever a production uses "<IDENTIFIER>") are removed, but reserved words such as "AND" remain.
- testExceptOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExchange() - Method in class org.apache.calcite.test.RelBuilderTest
- testExists() - Method in class org.apache.calcite.linq4j.function.FunctionTest
-
Unit test for
Functions.exists(java.util.List<? extends E>, org.apache.calcite.linq4j.function.Predicate1<E>)
. - testExists() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExists() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExistsCorrelated() - Method in class org.apache.calcite.test.JdbcTest
- testExistsCorrelated() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExistsCorrelatedDecorrelate() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExistsCorrelatedDecorrelateRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExistsCorrelatedLimit() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExistsCorrelatedLimitDecorrelate() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExistsCorrelatedLimitDecorrelateRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExistsInWhere() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExistsOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExistsWithExpand() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testExpandFilterExists() - Method in class org.apache.calcite.test.RelOptRulesTest
-
An EXISTS filter that can be converted into true/false.
- testExpandFilterExistsSimple() - Method in class org.apache.calcite.test.RelOptRulesTest
-
An EXISTS filter that can be converted into a semi-join.
- testExpandFilterExistsSimpleAnd() - Method in class org.apache.calcite.test.RelOptRulesTest
-
An EXISTS filter that can be converted into a semi-join.
- testExpandFilterIn() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandFilterIn3Value() - Method in class org.apache.calcite.test.RelOptRulesTest
-
An IN filter that requires full 3-value logic (true, false, unknown).
- testExpandFilterInComposite() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandFilterScalar() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandJoinExists() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandJoinIn() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandJoinInComposite() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandJoinScalar() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandProjectExists() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandProjectIn() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandProjectInComposite() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandProjectInNullable() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpandProjectScalar() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests expanding a sub-query, specifically an uncorrelated scalar sub-query in a project (SELECT clause).
- testExpandStar() - Method in class org.apache.calcite.test.SqlValidatorTest
- testExpandTable() - Method in class org.apache.calcite.test.RelBuilderTest
- testExpandViewInRelBuilder() - Method in class org.apache.calcite.test.RelBuilderTest
-
Ensures that relational algebra (
RelBuilder
) works with SQL views. - testExpandViewWithLateralJoin() - Method in class org.apache.calcite.test.JdbcTest
-
Unit test for view expansion with lateral join.
- testExpandWhereComparisonCorrelated() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExplain() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplain() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testExplain() - Method in class org.apache.calcite.test.JdbcTest
- testExplainAsJson() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplainAsXml() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplainAsXml() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExplainInsert() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplainJoin() - Method in class org.apache.calcite.test.JdbcTest
-
Checks that a 3-way join is re-ordered so that join conditions can be applied.
- testExplainJoin2() - Method in class org.apache.calcite.test.JdbcTest
-
Checks that a 3-way join is re-ordered so that join conditions can be applied.
- testExplainJoin3() - Method in class org.apache.calcite.test.JdbcTest
-
One of the most expensive foodmart queries.
- testExplainJoin4() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for (not yet fixed) [CALCITE-99] Recognize semi-join that has high selectivity and push it down.
- testExplainJoinOrderingWithOr() - Method in class org.apache.calcite.test.JdbcTest
-
Condition involving OR makes this more complex than
JdbcTest.testExplainJoin()
. - testExplainUpsert() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplainWithImpl() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplainWithoutImpl() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplainWithType() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplicitImplicitSchemaSameName() - Method in class org.apache.calcite.test.JdbcTest
- testExplicitTable() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplicitTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testExplicitTable() - Method in class org.apache.calcite.test.SqlValidatorTest
- testExplicitTableInJoin() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExplicitTableOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExplicitTableOrdered() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExpression() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testExpressionFilterSimpleColumnAEqColumnB() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionFilterSimpleColumnAEqColumnB() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionInAggregate() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testExpressionInJoin() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testExpressionInWindowFunction() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExpressionLineageAggregateAggColumn() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageAggregateGroupColumn() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageCombineTwoColumns() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageInnerJoinLeft() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageInnerJoinRight() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageLeftJoinLeft() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageMultiUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageOuterJoin() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageRightJoinRight() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageSelfJoin() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageStar() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageTwoColumns() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageTwoColumnsSwapped() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionLineageValues() - Method in class org.apache.calcite.test.RelMetadataTest
- testExpressionsConcatFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsConcatFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsConcatFilterMultipleColumns() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsConcatFilterMultipleColumns() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsFilter2() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsFilter2() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsFilterWithCast() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsFilterWithCast() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsFilterWithCastTimeToDateToChar() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsFilterWithCastTimeToDateToChar() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsFilterWithExtract() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsFilterWithExtract() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsLikeFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsLikeFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsLowerFilterMatching() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsLowerFilterMatching() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsLowerFilterNotMatching() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsLowerFilterNotMatching() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsLowerUpperFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsLowerUpperFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsNotNull() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsNotNull() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsSTRLENFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsSTRLENFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsUpperFilterMatching() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsUpperFilterMatching() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsUpperFilterNotMatching() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsUpperFilterNotMatching() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExpressionsUpperLowerFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExpressionsUpperLowerFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExtract() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testExtract() - Method in class org.apache.calcite.test.JdbcTest
- testExtract() - Method in class org.apache.calcite.test.SqlValidatorTest
- testExtractDate() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExtractFilterWorkWithPostAggregations() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExtractFilterWorkWithPostAggregations() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExtractFilterWorkWithPostAggregationsWithConstant() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExtractFilterWorkWithPostAggregationsWithConstant() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExtractFromInterval() - Method in class org.apache.calcite.test.JdbcTest
- testExtractFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExtractFuncFromDateTime() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExtractHourFilterExpression() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExtractHourFilterExpressionWithCast() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExtractIntervalDayTime() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExtractIntervalYearMonth() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExtractJoinFilterRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExtractMonthFilterExpression() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExtractMonthFilterExpression() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExtractMonthFromTimestamp() - Method in class org.apache.calcite.test.JdbcTest
- testExtractOnNullDateField() - Method in class org.apache.calcite.test.JdbcTest
- testExtractPartialRewriteForInMonth() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
-
Test case #4 for [CALCITE-1658] DateRangeRules issues.
- testExtractPartialRewriteForNotEqualsYear() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
-
Test case #3 for [CALCITE-1658] DateRangeRules issues.
- testExtractQuarter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExtractQuarter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExtractQuarterPlusDim() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExtractQuarterPlusDim() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExtractRewriteForInvalidDayComparison() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractRewriteForInvalidMonthComparison() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractRewriteMultipleOperands() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractTimestamp() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testExtractWithOrCondition1() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
-
Test case #1 for [CALCITE-1658] DateRangeRules issues.
- testExtractWithOrCondition2() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
-
Test case #2 for [CALCITE-1658] DateRangeRules issues.
- testExtractYearAndDayFromDateColumn() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractYearAndDayFromDateColumn() - Method in class org.apache.calcite.test.DruidDateRangeRulesTest
- testExtractYearAndMonthFromDateColumn() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractYearAndMonthFromDateColumn() - Method in class org.apache.calcite.test.DruidDateRangeRulesTest
- testExtractYearAndMonthFromDateColumn2() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
-
Test case for [CALCITE-1601] DateRangeRules loses OR filters.
- testExtractYearFilterExpression() - Method in class org.apache.calcite.test.DruidAdapterIT
- testExtractYearFilterExpression() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testExtractYearFromDateColumn() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractYearFromTimestamp() - Method in class org.apache.calcite.test.JdbcTest
- testExtractYearFromTimestampColumn() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractYearMonthDayFromDateColumn() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractYearMonthDayFromDateColumn() - Method in class org.apache.calcite.test.DruidDateRangeRulesTest
- testExtractYearMonthDayFromTimestampColumn() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testExtractYearMonthDayFromTimestampColumn() - Method in class org.apache.calcite.test.DruidDateRangeRulesTest
- testExtractYearMonthToRange() - Method in class org.apache.calcite.test.RelOptRulesTest
- testExtractYearToRange() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-434] Converting predicates on date dimension columns into date ranges, specifically a rule that converts
EXTRACT(YEAR FROM ...) = constant
to a range. - testFactorOutBinaryAdd() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testFactorOutBinaryAddMul() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testFactorOutBinaryAddNameCollision() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testFactorOutBinaryAddSurvivesMultipleOptimizations() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testFactorOutNestedClasses() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testFakeStar() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testFalseFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFalseFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFalseFilterCaseConjectionWithTrue() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFalseFilterCaseConjectionWithTrue() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFetch() - Method in class org.apache.calcite.test.JdbcTest
-
Tests FETCH with no ORDER BY.
- testFetch() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testFetchStar() - Method in class org.apache.calcite.test.JdbcTest
- testFetchWithDynamicParameter() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testFieldNamesWithAggregateSubQuery() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFieldOrigin() - Method in class org.apache.calcite.test.SqlValidatorTest
- testFileReaderBadSelector() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests failed
FileReader
instantiation - bad selector. - testFileReaderBadUrl() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests failed
FileReader
instantiation - bad URL. - testFileReaderData() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Test
FileReader
with static file - data. - testFileReaderDataBadFile() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests
FileReader
with bad static file - data. - testFileReaderDataNoTh() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests
FileReader
with no headings static file - data. - testFileReaderHeadings() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Test
FileReader
with static file - headings. - testFileReaderHeadingsBadFile() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests
FileReader
with bad static file - headings. - testFileReaderIterator() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests
FileReader
iterator with static file, - testFileReaderMalUrl() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests failed
FileReader
instantiation - malformed URL. - testFileReaderUrlFetch() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests
FileReader
URL fetch. - testFileReaderUrlNoPath() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests
FileReader
URL instantiation - no path. - testFileReaderUrlWithPath() - Method in class org.apache.calcite.adapter.file.FileReaderTest
-
Tests
FileReader
URL instantiation - with path. - testFiles() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testFileSelect() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads from a local file and checks the result.
- testFilter() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testFilter() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testFilter() - Method in class org.apache.calcite.linq4j.function.FunctionTest
-
Unit test for
Functions.filter(java.util.List<E>, org.apache.calcite.linq4j.function.Predicate1<E>)
. - testFilter() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilter() - Method in class org.apache.calcite.test.MaterializationTest
- testFilter() - Method in class org.apache.calcite.test.PigletTest
- testFilter() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testFilter() - Method in class org.apache.calcite.util.UtilTest
-
Tests
Util.filter(Iterable, java.util.function.Predicate)
. - testFilterableSelect() - Method in class org.apache.calcite.test.CsvTest
- testFilterableSelectStar() - Method in class org.apache.calcite.test.CsvTest
- testFilterableTableCooperative() - Method in class org.apache.calcite.test.ScannableTableTest
-
A filter on a
FilterableTable
with two columns (cooperative). - testFilterableTableNonCooperative() - Method in class org.apache.calcite.test.ScannableTableTest
-
A filter on a
FilterableTable
with two columns (noncooperative). - testFilterableWhere() - Method in class org.apache.calcite.test.CsvTest
-
Filter that can be fully handled by CsvFilterableTable.
- testFilterableWhere2() - Method in class org.apache.calcite.test.CsvTest
-
Filter that can be partly handled by CsvFilterableTable.
- testFilterBetween() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterCastAny() - Method in class org.apache.calcite.test.RelBuilderTest
- testFilterCastNull() - Method in class org.apache.calcite.test.RelBuilderTest
- testFilterClauseAlwaysFalseNotPushed() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests that an aggregate with a filter clause that is always false does not get pushed in
- testFilterClauseAlwaysFalseNotPushed() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests that an aggregate with a filter clause that is always false does not get pushed in
- testFilterClauseAlwaysFalseNotPushedWithFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests that an aggregate with a filter clause that is always false does not get pushed when there is already an outer filter
- testFilterClauseAlwaysFalseNotPushedWithFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests that an aggregate with a filter clause that is always false does not get pushed when there is already an outer filter
- testFilterClauseAlwaysTrueGone() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests whether filter clauses with filters that are always true disappear or not
- testFilterClauseAlwaysTrueGone() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests whether filter clauses with filters that are always true disappear or not
- testFilterClauseAlwaysTrueWithAggGone1() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests whether filter clauses with filters that are always true disappear in the presence of another aggregate without a filter clause
- testFilterClauseAlwaysTrueWithAggGone1() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests whether filter clauses with filters that are always true disappear in the presence of another aggregate without a filter clause
- testFilterClauseAlwaysTrueWithAggGone2() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests whether filter clauses with filters that are always true disappear in the presence of another aggregate with a filter clause
- testFilterClauseAlwaysTrueWithAggGone2() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests whether filter clauses with filters that are always true disappear in the presence of another aggregate with a filter clause
- testFilterClauseFactoredOut() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests whether an aggregate with a filter clause has it's filter factored out when there is no outer filter
- testFilterClauseFactoredOut() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests whether an aggregate with a filter clause has it's filter factored out when there is no outer filter
- testFilterClauseNotFactoredOut1() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that an aggregate with a filter clause in the presence of another aggregate without a filter clause does not have it's filter factored out into the outer filter
- testFilterClauseNotFactoredOut1() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that an aggregate with a filter clause in the presence of another aggregate without a filter clause does not have it's filter factored out into the outer filter
- testFilterClauseNotFactoredOut2() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that an aggregate with a filter clause in the presence of another aggregate without a filter clause, and an outer filter does not have it's filter factored out into the outer filter
- testFilterClauseNotFactoredOut2() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that an aggregate with a filter clause in the presence of another aggregate without a filter clause, and an outer filter does not have it's filter factored out into the outer filter
- testFilterClauseNotPushable() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that aggregates with filter clauses that Druid cannot handle are not pushed in as filtered aggregates.
- testFilterClauseNotPushable() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that aggregates with filter clauses that Druid cannot handle are not pushed in as filtered aggregates.
- testFilterClauseSameAsOuterFilterGone() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests that an aggregate with a filter clause that is the same as the outer filter has no references to that filter, and that the original outer filter remains
- testFilterClauseSameAsOuterFilterGone() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests that an aggregate with a filter clause that is the same as the outer filter has no references to that filter, and that the original outer filter remains
- testFilterClausesFactoredForPruning1() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that multiple aggregates with filter clauses have their filters extracted to the outer filter field for data pruning
- testFilterClausesFactoredForPruning1() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that multiple aggregates with filter clauses have their filters extracted to the outer filter field for data pruning
- testFilterClausesFactoredForPruning2() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that multiple aggregates with filter clauses have their filters extracted to the outer filter field for data pruning in the presence of an outer filter
- testFilterClausesFactoredForPruning2() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that multiple aggregates with filter clauses have their filters extracted to the outer filter field for data pruning in the presence of an outer filter
- testFilterClauseWithMetricAndTimeAndAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterClauseWithMetricAndTimeAndAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterClauseWithMetricRef() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterClauseWithMetricRef() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterClauseWithMetricRefAndAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterClauseWithMetricRefAndAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterClauseWithNoConjunction() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test case for https://issues.apache.org/jira/browse/CALCITE-2098.
- testFilterClauseWithNoConjunction() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test case for https://issues.apache.org/jira/browse/CALCITE-2098.
- testFilterDistinct() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterDistinct() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterExample() - Method in class org.apache.calcite.test.PigletTest
- testFilterExists() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterExtractionOnMonthWithBetween() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterExtractionOnMonthWithBetween() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterExtractionOnMonthWithIn() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterExtractionOnMonthWithIn() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterFalse() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterFloorOnMetricColumn() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterFloorOnMetricColumn() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterGroupQueryOnStar() - Method in class org.apache.calcite.test.MaterializationTest
-
Tests a complicated star-join query on a complicated materialized star-join query.
- testFilterIsIn() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterIsNotNull() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterIsNull() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterNotExists() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterOnDouble() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterOnDouble() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterOnNullableTimestamp() - Method in class org.apache.calcite.test.CsvTest
- testFilterOnNullableTimestamp2() - Method in class org.apache.calcite.test.CsvTest
- testFilterOr() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterOutEverything() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests a query whose filter removes all rows.
- testFilterOutEverything() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests a query whose filter removes all rows.
- testFilterPair() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
MongoDB's predicates are handed (they can only accept literals on the right-hand size) so it's worth testing that we handle them right both ways around.
- testFilterProjectTranspose() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests a variant of
FilterProjectTransposeRule
that pushes a Filter that contains a correlating variable. - testFilterProjectTransposePreventedByCorrelation() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests that the default instance of
FilterProjectTransposeRule
does not push a Filter that contains a correlating variable. - testFilterQueryOnFilterView() - Method in class org.apache.calcite.test.MaterializationTest
- testFilterQueryOnFilterView10() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition currently has unsupported type being checked on query. - testFilterQueryOnFilterView11() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is weaker in query and columns selected are subset of columns in materialized view. - testFilterQueryOnFilterView12() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition of query is stronger but is on the column not present in MV (salary). - testFilterQueryOnFilterView13() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is weaker in query and columns selected are subset of columns in materialized view. - testFilterQueryOnFilterView14() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView7()
but columns in materialized view are a permutation of columns in the query. - testFilterQueryOnFilterView2() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is stronger in query. - testFilterQueryOnFilterView3() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is weaker in view. - testFilterQueryOnFilterView4() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is stronger in query. - testFilterQueryOnFilterView5() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is stronger in query and columns selected are subset of columns in materialized view. - testFilterQueryOnFilterView6() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is stronger in query and columns selected are subset of columns in materialized view. - testFilterQueryOnFilterView7() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is stronger in query and columns selected are subset of columns in materialized view. - testFilterQueryOnFilterView8() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is stronger in query. - testFilterQueryOnFilterView9() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnFilterView()
but condition is weaker in query. - testFilterQueryOnProjectView() - Method in class org.apache.calcite.test.MaterializationTest
- testFilterQueryOnProjectView0() - Method in class org.apache.calcite.test.MaterializationTest
-
Runs the same test as
MaterializationTest.testFilterQueryOnProjectView()
but more concisely. - testFilterQueryOnProjectView1() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnProjectView()
but with extra column in materialized view. - testFilterQueryOnProjectView2() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnProjectView()
but with extra column in both materialized view and query. - testFilterQueryOnProjectView3() - Method in class org.apache.calcite.test.MaterializationTest
- testFilterQueryOnProjectView4() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnProjectView3()
but materialized view cannot be used because it does not contain required expression. - testFilterQueryOnProjectView5() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnProjectView3()
but also contains an expression column. - testFilterQueryOnProjectView6() - Method in class org.apache.calcite.test.MaterializationTest
-
Cannot materialize because "name" is not projected in the MV.
- testFilterQueryOnProjectView7() - Method in class org.apache.calcite.test.MaterializationTest
-
As
MaterializationTest.testFilterQueryOnProjectView3()
but also contains an expression column. - testFilterQueryOnProjectView8() - Method in class org.apache.calcite.test.MaterializationTest
- testFilterRedundant() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
Tests that we don't generate multiple constraints on the same column.
- testFilterRemoveIsNotDistinctFromRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testFilterReversed() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testFilterReversed() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
MongoDB's predicates are handed (they can only accept literals on the right-hand size) so it's worth testing that we handle them right both ways around.
- testFilterSort() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testFilterSort() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testFilterSortDesc() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testFilterSortDesc() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testFilterSortDesc() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests a query that contains no GROUP BY and is therefore executed as a Druid "select" query.
- testFilterSortDesc() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests a query that contains no GROUP BY and is therefore executed as a Druid "select" query.
- testFilterSortDescNumeric() - Method in class org.apache.calcite.test.DruidAdapterIT
-
As
DruidAdapterIT.testFilterSortDesc()
but the bounds are numeric. - testFilterSortDescNumeric() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
As
DruidAdapterIT2.testFilterSortDesc()
but the bounds are numeric. - testFilterSwapped() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterSwapped() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterTime() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterTimeDistinct() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterTimestamp() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests that conditions applied to time units extracted via the EXTRACT function become ranges on the timestamp column
- testFilterTimestamp() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests that conditions applied to time units extracted via the EXTRACT function become ranges on the timestamp column
- testFilterTrue() - Method in class org.apache.calcite.test.SparkAdapterTest
- testFilterUnionPlan() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testFilterUnionPlan() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterUnionPlan() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterUnionPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testFilterUUID() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testFilterWithCast() - Method in class org.apache.calcite.test.DruidDateRangeRulesTest
-
Test case for [CALCITE-1738] Push CAST of literals to Druid.
- testFilterWithFloorOnTime() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFilterWithFloorOnTime() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFilterWithNestedField() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testFindBiggerNoTh() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads from a local file - finds larger table even without <TH> elements.
- testFirst() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testFirstDuplicate() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Util.firstDuplicate(java.util.List)
. - testFirstOrDefault() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testFirstOrDefaultPredicate1() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testFirstPredicate1() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testFirstValueFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testFlat34Equals() - Method in class org.apache.calcite.util.UtilTest
-
Test case for [CALCITE-2287] FlatList.equals throws StackOverflowError.
- testFlatList() - Method in class org.apache.calcite.util.UtilTest
-
Tests that flat lists behave like regular lists in terms of equals and hashCode.
- testFlatList2() - Method in class org.apache.calcite.util.UtilTest
- testFlatListN() - Method in class org.apache.calcite.util.UtilTest
- testFlatListProduct() - Method in class org.apache.calcite.util.UtilTest
- testFlattenRecords() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testFloat() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testFloor() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloor() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFloor() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testFloorCeil() - Method in class org.apache.calcite.test.SqlValidatorTest
- testFloorDate() - Method in class org.apache.calcite.test.JdbcTest
- testFloorEqRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testFloorExtractBothRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testFloorFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testFloorFuncDateTime() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testFloorFuncInterval() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testFloorGeRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testFloorGtRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testFloorLeRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testFloorLtRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testFloorMssqlMonth() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorMssqlWeek() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorMysqlHour() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorMysqlMinute() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorMysqlMonth() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorMysqlSecond() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorMysqlWeek() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorOracle() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorPostgres() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFloorQuarter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFloorQuarter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFloorQuarterPlusDim() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFloorQuarterPlusDim() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFloorRewriteWithTimezone() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testFloorToDateRangeWithTimeZone() - Method in class org.apache.calcite.test.DruidAdapterIT
- testFloorToDateRangeWithTimeZone() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testFloorWithGroupBy() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFoldAnd() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testFoo() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFoo() - Method in class org.apache.calcite.test.BabelTest
- testFoodmart() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testFoodMartAll() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testFoodMartAllEvolve() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testFoodmartLattice() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that a relatively complex query on the foodmart schema creates an in-memory aggregate table and then uses it.
- testFor() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testFor2() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testForeach() - Method in class org.apache.calcite.test.PigletTest
- testForeach() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testForeachNested() - Method in class org.apache.calcite.test.PigletTest
- testFrameworksValidatorWithIdentifierExpansion() - Method in class org.apache.calcite.tools.FrameworksTest
-
Tests that the validator expands identifiers by default.
- testFrom() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testFromComplete() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testFromReferenceFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testFromValues() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFromValuesWithoutParens() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFromWhere() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testFromWithAs() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFullInnerJoinFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFullJoin() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testFullJoin() - Method in class org.apache.calcite.test.JdbcTest
- testFullJoinOnTrueCondition() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testFullOuterJoin() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFullOuterJoinSimplificationToInner() - Method in class org.apache.calcite.test.RelOptRulesTest
- testFullOuterJoinSimplificationToLeftOuter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testFullOuterJoinSimplificationToRightOuter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testFunction() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFunctionalDistinct() - Method in class org.apache.calcite.test.SqlValidatorTest
- testFunctionCallWithDot() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFunctionDefaultArgument() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFunctionInFunction() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFunctionNamedArgument() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFunctionWithDistinct() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testFunOracle() - Method in class org.apache.calcite.test.JdbcTest
- testFunSpatial() - Method in class org.apache.calcite.test.JdbcTest
- testFusion() - Method in class org.apache.calcite.test.SqlValidatorTest
- testFusionFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testFuzzy() - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- testGC() - Method in class org.apache.calcite.test.HepPlannerTest
- testGcd() - Method in class org.apache.calcite.linq4j.tree.TypeTest
- testGenerate() - Method in class org.apache.calcite.linq4j.function.FunctionTest
-
Unit test for
Functions.generate(int, org.apache.calcite.linq4j.function.Function1<java.lang.Integer, E>)
. - testGenerateKeyWords() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Generates a copy of
reference.md
with the current set of key words. - testGenerateKeyWords() - Method in class org.apache.calcite.test.BabelParserTest
- testGenerateKeyWords() - Method in class org.apache.calcite.test.ServerParserTest
- testGeometry() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testGeometry() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests whether the GEOMETRY data type is allowed.
- testGet2() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testGetByName() - Method in class org.apache.calcite.test.JdbcTest
-
Tests accessing columns by name.
- testGetDate() - Method in class org.apache.calcite.test.JdbcTest
-
Tests accessing a column in a JDBC source whose type is DATE.
- testGetDateAsString() - Method in class org.apache.calcite.test.JdbcTest
-
Tests accessing a date as a string in a JDBC source whose type is DATE.
- testGetPredicatesForFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testGetPredicatesForJoin() - Method in class org.apache.calcite.test.RelMetadataTest
- testGetTimestamp() - Method in class org.apache.calcite.test.JdbcTest
-
Test for timestamps and time zones, based on pgsql TimezoneTest.
- testGetTimestampObject() - Method in class org.apache.calcite.test.JdbcTest
- testGeWithAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testGitCommits() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testGitCommitsTop() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testGreater() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testGreaterThanFilterOnDateType() - Method in class org.apache.calcite.test.CsvTest
- testGreaterThanOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testGreaterThanOperatorIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testGreaterThanOrEqualOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testGreaterThanOrEqualOperatorIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testGreatestFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testGroup() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testGroup() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testGroup() - Method in class org.apache.calcite.test.HepPlannerTest
- testGroup() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testGroup() - Method in class org.apache.calcite.test.PigletTest
- testGroup() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testGroup() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroup() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroup2() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testGroupAgg() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupAlias() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupBug281() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupBug281b() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupBy() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testGroupBy() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
-
Tests the version of
ExtendedEnumerable.groupBy(org.apache.calcite.linq4j.function.Function1<TSource, TKey>)
that uses an accumulator; does not build intermediate lists. - testGroupBy() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Simple GROUP BY.
- testGroupBy() - Method in class org.apache.calcite.test.RelMetadataTest
- testGroupBy() - Method in class org.apache.calcite.test.SparkAdapterTest
- testGroupBy() - Method in class org.apache.calcite.test.SplunkAdapterTest
- testGroupBy1() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupBy1() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupBy1Max1() - Method in class org.apache.calcite.test.JdbcTest
-
Same result (and plan) as
JdbcTest.testSelectDistinct()
. - testGroupByAlias() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupByAliasEqualToColumnName() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupByAliasOfSubExpressionsInProject() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupByAvg() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupByAvgSumCount() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupByAvgSumCount() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByAvgSumCount() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByCaseIn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupByCaseSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test group-by CASE expression involving a non-query IN
- testGroupByContainsLiterals() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupByCorrelatedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupByCube() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testGroupByCube2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testGroupByDayGranularity() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByDayGranularity() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByDaySortDescLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByDaySortDescLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByDaySortDimension() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByDaySortDimension() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByDaySortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByDaySortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByEmpty() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a query that uses no columns from the fact table.
- testGroupByEmpty2() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a query that uses no dimension columns and one measure column.
- testGroupByEmpty3() - Method in class org.apache.calcite.test.LatticeTest
-
Tests that two queries of the same dimensionality that use different measures can use the same materialization.
- testGroupByEmptyHavingUniqueKeys() - Method in class org.apache.calcite.test.RelMetadataTest
- testGroupByEmptyUniqueKeys() - Method in class org.apache.calcite.test.RelMetadataTest
- testGroupByEmptyWithPrelude() - Method in class org.apache.calcite.test.LatticeTest
-
Calls
LatticeTest.testDistinctCount()
followed byLatticeTest.testGroupByEmpty()
. - testGroupByExpression() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupByFloorTimeWithLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByFloorTimeWithLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByFloorTimeWithoutLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByFloorTimeWithoutLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByHaving() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupByHaving() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByHaving() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByHaving() - Method in class org.apache.calcite.test.SparkAdapterTest
- testGroupByHaving2() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupByMax1IsNull() - Method in class org.apache.calcite.test.JdbcTest
-
Same result (and plan) as
JdbcTest.testSelectDistinct()
. - testGroupbyMetric() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupbyMetric() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByMetricAndExtractTime() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByMetricAndExtractTime() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByMiMaxCountCountDistinctOrderByDesc() - Method in class org.apache.calcite.test.SparkAdapterTest
- testGroupByMinMaxCountCountDistinctOrderByAsc() - Method in class org.apache.calcite.test.SparkAdapterTest
- testGroupByMinMaxSum() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupByMonthGranularity() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByMonthGranularity() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByMonthGranularityFiltered() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByMonthGranularityFiltered() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByMonthGranularitySort() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByMonthGranularitySort() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByMonthGranularitySortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByMonthGranularitySortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByNoAggregates() - Method in class org.apache.calcite.test.JdbcTest
-
Same result (and plan) as
JdbcTest.testSelectDistinct()
. - testGroupByNoAggregatesAllColumns() - Method in class org.apache.calcite.test.JdbcTest
-
Same result (and plan) as
JdbcTest.testSelectDistinct()
. - testGroupByNull() - Method in class org.apache.calcite.test.JdbcTest
-
Tests composite GROUP BY where one of the columns has NULL values.
- testGroupByOneColumn() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupByOneColumn() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByOneColumn() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByOneColumnNotProjected() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupByOneColumnNotProjected() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByOneColumnNotProjected() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByOneColumnReversed() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupByOneColumnReversed() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByOneColumnReversed() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByOrderByAsc() - Method in class org.apache.calcite.test.SparkAdapterTest
- testGroupByOrdinal() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupByRaw() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testGroupByRawWithAliases() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testGroupByRollup() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testGroupBySingleSortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupBySingleSortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupBySingleSortLimitApprox() - Method in class org.apache.calcite.test.DruidAdapterIT
-
As
DruidAdapterIT.testGroupBySingleSortLimit()
, but allowing approximate results due toCalciteConnectionConfig.approximateDistinctCount()
. - testGroupBySingleSortLimitApprox() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
As
DruidAdapterIT2.testGroupBySingleSortLimit()
, but allowing approximate results due toCalciteConnectionConfig.approximateDistinctCount()
. - testGroupBySortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupBySortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupBySystemFunction() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-886] System functions in GROUP BY clause.
- testGroupByTimeAndOneColumnNotProjected() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByTimeAndOneColumnNotProjected() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByTimeAndOneColumnNotProjectedWithLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Unlike
DruidAdapterIT.testGroupByTimeAndOneColumnNotProjected()
, we cannot use "topN" because we have a global limit, and that requiresgranularity: all
. - testGroupByTimeAndOneColumnNotProjectedWithLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Unlike
DruidAdapterIT2.testGroupByTimeAndOneColumnNotProjected()
, we cannot use "topN" because we have a global limit, and that requiresgranularity: all
. - testGroupByTimeAndOneMetricNotProjected() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByTimeAndOneMetricNotProjected() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByTimeSortOverMetrics() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByTimeSortOverMetrics() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByTimestampAdd() - Method in class org.apache.calcite.adapter.file.SqlTest
- testGroupByTimestampAdd() - Method in class org.apache.calcite.test.CsvTest
- testGroupByView() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testGroupByViewWithAliases() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testGroupByVirtualColumn() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByVirtualColumn() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByWeekExtract() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByWeekExtract() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupByWithBooleanExpression() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupByWithDuplicates() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
GROUP BY with duplicates.
- testGroupByWithKeySelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupByWithKeySelectorAndComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupByWithKeySelectorAndElementSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupByWithKeySelectorAndElementSelectorAndComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupByWithKeySelectorAndElementSelectorAndResultSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupByWithKeySelectorAndElementSelectorAndResultSelectorAndComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupByWithKeySelectorAndResultSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupByWithKeySelectorAndResultSelectorAndComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupComposite() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testGroupComposite() - Method in class org.apache.calcite.test.DruidAdapterIT
- testGroupComposite() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testGroupEmpty() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testGroupEmpty() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testGroupEmpty() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupExample() - Method in class org.apache.calcite.test.PigletTest
- testGroupExpressionEquivalence() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupExpressionEquivalenceId() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupExpressionEquivalenceLiteral() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupExpressionEquivalenceStringLiteral() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupExpressionsInsideAndOut() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupId() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGrouping() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testGrouping() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupingFunction() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupingFunctionWithGroupBy() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
When the GROUPING function occurs with GROUP BY (effectively just one grouping set), we can translate it directly to 1.
- testGroupingId() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupingSets() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testGroupingSets() - Method in class org.apache.calcite.test.JdbcTest
- testGroupingSets() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupingSets() - Method in class org.apache.calcite.test.SqlValidatorTest
- testGroupingSetsCartesianProduct() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupingSetsCartesianProduct2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupingSetsProduct() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupingSetsWith() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupingSetsWithCube() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupingSetsWithRollup() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupingSetsWithRollupCube() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGroupJoin() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupJoinWithComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testGroupJustOneAgg() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testGrpByColFromStarInSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for Dynamic Table / Dynamic Star support [CALCITE-1150]
- testGtWithAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testHash() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Utilities.hashCode(double)
. - testHaving() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testHaving() - Method in class org.apache.calcite.test.SqlValidatorTest
- testHavingAfterGroup() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testHavingAggrFunctionIn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-694] Scan HAVING clause for sub-queries and IN-lists relating to IN.
- testHavingBeforeGroupFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testHavingBetween() - Method in class org.apache.calcite.test.SqlValidatorTest
- testHavingInSubQueryWithAggrFunction() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-694] Scan HAVING clause for sub-queries and IN-lists, with a sub-query in the HAVING clause.
- testHavingNoGroup() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testHavingNot() - Method in class org.apache.calcite.test.JdbcTest
- testHavingNot2() - Method in class org.apache.calcite.test.JdbcTest
-
Minimal case of
JdbcTest.testHavingNot()
. - testHavingSpecs() - Method in class org.apache.calcite.test.DruidAdapterIT
- testHavingSpecs() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testHeterogeneousConversion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testHeuristicLeftJoin() - Method in class org.apache.calcite.tools.PlannerTest
- testHeuristicPushInnerJoin() - Method in class org.apache.calcite.tools.PlannerTest
-
It would probably be OK to transform
(emps right join depts) join dependents
to(emps join dependents) right join depts
but we do not currently allow it. - testHeuristicRightJoin() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests that a relation (dependents) that is on the null-generating side of an outer join cannot be pushed into an inner join (emps join depts).
- testHexAndBinaryString() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testHexAndBinaryStringFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testHiveDialect() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests that Hive dialect does not generate "AS".
- testHiveSelectCharset() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testHiveSelectQueryWithOrderByAscAndNullsLastShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testHiveSelectQueryWithOrderByAscNullsFirstShouldNotAddNullEmulation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testHiveSelectQueryWithOrderByDescAndHighNullsWithVersion20() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testHiveSelectQueryWithOrderByDescAndHighNullsWithVersionGreaterThanOrEq21() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testHiveSelectQueryWithOrderByDescAndNullsFirstShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testHiveSelectQueryWithOrderByDescNullsLastShouldNotAddNullEmulation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testHook() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that
Hook.PARSE_TREE
works. - testHopTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testHour() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testHuman() - Method in class org.apache.calcite.util.UtilTest
- testHyperUniquePostAggregator() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Turn on now count(distinct )
- testHyperUniquePostAggregator() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Turn on now count(distinct )
- testIdenticalExpressionInSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testIdentifier() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIdentityEqualityComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testIfElseIfElse() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testIllegalCursors() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIllegalUnicodeEscape() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testImmutableCopy() - Method in class org.apache.calcite.util.UtilTest
-
Tests
Util.immutableCopy(Iterable)
. - testImmutableIntList() - Method in class org.apache.calcite.util.UtilTest
- testImmutableNullableList() - Method in class org.apache.calcite.util.UtilTest
-
Test for
ImmutableNullableList
. - testImmutableNullableListBuilder() - Method in class org.apache.calcite.util.UtilTest
-
Test for
ImmutableNullableList.Builder
. - testImplWithCountWithoutGroupBy() - Method in class org.apache.calcite.test.PigAdapterTest
- testImplWithCountWithoutGroupBy() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- testImplWithGroupByAndCount() - Method in class org.apache.calcite.test.PigAdapterTest
- testImplWithGroupByAndCount() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- testImplWithGroupByCountDistinct() - Method in class org.apache.calcite.test.PigAdapterTest
- testImplWithGroupByCountDistinct() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- testImplWithGroupByMultipleFields() - Method in class org.apache.calcite.test.PigAdapterTest
- testImplWithGroupByMultipleFields() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- testImplWithJoin() - Method in class org.apache.calcite.test.PigAdapterTest
- testImplWithJoin() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- testImplWithJoinAndGroupBy() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- testImplWithMultipleFilters() - Method in class org.apache.calcite.test.PigAdapterTest
- testImplWithMultipleFilters() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- testImport() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testIn() - Method in class org.apache.calcite.test.JdbcTest
-
A difficult query: an IN list so large that the planner promotes it to a semi-join against a VALUES relation.
- testIndent8() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testIndexOf() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testInduceGroupingType() - Method in class org.apache.calcite.test.InduceGroupingTypeTest
- testInduceGroupingType0() - Method in class org.apache.calcite.test.InduceGroupingTypeTest
- testInduceGroupingType1() - Method in class org.apache.calcite.test.InduceGroupingTypeTest
-
Tests a singleton grouping set {2}, whose power set has only two elements, { {2}, {} }.
- testInferringPredicatesWithNotOperatorInJoinCondition() - Method in class org.apache.calcite.test.RelOptRulesTest
- testInFilter() - Method in class org.apache.calcite.adapter.druid.DruidQueryFilterTest
- testInfiniteStreamsDoNotBufferInMemory() - Method in class org.apache.calcite.test.StreamTest
- testInitcap() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testInitcapFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testInlineConstant() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testInlineParameter() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testInlineSingleUsage() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testInlineViewLateralTableFunction() - Method in class org.apache.calcite.test.TableFunctionTest
-
Test case for [CALCITE-2382] Sub-query lateral joined to table function.
- testInlineWinDef() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInList() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInListEmptyFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInner() - Method in class org.apache.calcite.linq4j.test.CorrelateJoinTest
- testInnerJoin() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testInnerJoinValues() - Method in class org.apache.calcite.test.JdbcTest
-
Tests inner join to an inline table (
VALUES
clause). - testInnerJoinWithoutUsingOrOnFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInnerOuterJoinFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testInPlan() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testInPlan() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testInPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testInQuery() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInQueryWithComma() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tricky for the parser - looks like "IN (scalar, scalar)" but isn't.
- testInsert() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Test remote Statement insert.
- testInsert() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testInsert() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- testInsert() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsert() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsert() - Method in class org.apache.calcite.util.PermutationTestCase
- testInsert2() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- testInsert3() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Local Statement insert
- testInsertBatch() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Test remote Statement batched insert.
- testInsertBind() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- testInsertBind() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertBind() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindExtendedColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertBindExtendedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertBindExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindFailNullability() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertBindSubset() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertBindSubset() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindSubsetDisallowed() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindSubsetFailNullability() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindSubsetModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertBindSubsetWithCustomInitializerExpressionFactory() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertBindSubsetWithCustomInitializerExpressionFactory() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindViewFailExcludedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindWithCustomColumnResolving() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertBindWithCustomInitializerExpressionFactory() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertBindWithCustomInitializerExpressionFactory() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertCaseSensitiveColumnList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertCaseSensitiveExtendedColumnList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertColumnList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertExtendedColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertExtendedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnFailCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnFailDuplicate() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnModifiableViewCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnModifiableViewExtendedCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnModifiableViewFailCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnModifiableViewFailColumnCount() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnModifiableViewFailConstraint() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnModifiableViewFailExtendedCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnModifiableViewFailUnderlyingCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertExtendedColumnModifiableViewUnderlyingCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertFailCaseSensitivity() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertFailDataType() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertFailExcludedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertFailNullability() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertModifiableView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertModifiableViewFailConstraint() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertModifiableViewPassConstraint() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertMultipleRowMismatch() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Some of the rows have the wrong number of columns.
- testInsertSelect() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertShouldNotCheckForDefaultValue() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-1510] INSERT/UPSERT should allow fewer values than columns, check for default value only when target field is null.
- testInsertSubset() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertSubset() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertSubsetDisallowed() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertSubsetFailNullability() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertSubsetModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertSubsetModifiableView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertSubsetView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertSubsetView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertSubsetViewDisallowed() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertSubsetViewFailNullability() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertSubsetWithCustomInitializerExpressionFactory() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertSubsetWithCustomInitializerExpressionFactory() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertUnion() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertValues() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertValuesDefault() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertValuesRawDefault() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInsertView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertViewFailNullability() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertViewWithCustomColumnResolving() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertWithCustomColumnResolving() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertWithCustomColumnResolving2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertWithCustomInitializerExpressionFactory() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInsertWithCustomInitializerExpressionFactory() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInsertWithExtendedColumns() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInSetFilterWithNestedStringField() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testInSetop() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInstanceofComplexTest() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testInstanceofTest() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testInSubQuery() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInteger() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testIntegerIntervalSet() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
IntegerIntervalSet
. - testIntegerLiteral() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testIntegerValueOfZeroComplexTest() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testInterleaveBetweenAggregateAndGroupOrderByOnDimension() - Method in class org.apache.calcite.test.DruidAdapterIT
- testInterleaveBetweenAggregateAndGroupOrderByOnDimension() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testInterleaveBetweenAggregateAndGroupOrderByOnMetrics() - Method in class org.apache.calcite.test.DruidAdapterIT
- testInterleaveBetweenAggregateAndGroupOrderByOnMetrics() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testInterpreter() - Method in class org.apache.calcite.test.RexProgramTest
- testInterpretOrder() - Method in class org.apache.calcite.test.InterpreterTest
-
Tests a plan where the sort field is projected away.
- testInterpretProjectFilterValues() - Method in class org.apache.calcite.test.InterpreterTest
-
Tests executing a simple plan using an interpreter.
- testInterpretScannableTable() - Method in class org.apache.calcite.test.InterpreterTest
-
Tests executing a plan on a
ScannableTable
using an interpreter. - testInterpretSimpleScannableTable() - Method in class org.apache.calcite.test.InterpreterTest
-
Tests executing a plan on a single-column
ScannableTable
using an interpreter. - testInterpretTable() - Method in class org.apache.calcite.test.InterpreterTest
-
Tests executing a simple plan using an interpreter.
- testInterpretUnion() - Method in class org.apache.calcite.test.InterpreterTest
-
Tests executing a UNION query using an interpreter.
- testInterpretUnionAll() - Method in class org.apache.calcite.test.InterpreterTest
-
Tests executing a UNION ALL query using an interpreter.
- testIntersect() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testIntersect() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIntersect() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Tests INTERSECT.
- testIntersect() - Method in class org.apache.calcite.test.JdbcTest
- testIntersect() - Method in class org.apache.calcite.test.RelBuilderTest
- testIntersect() - Method in class org.apache.calcite.test.SparkAdapterTest
- testIntersect() - Method in class org.apache.calcite.test.SqlValidatorFeatureTest
- testIntersect() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testIntersect3() - Method in class org.apache.calcite.test.RelBuilderTest
- testIntersectMismatchedVarchar() - Method in class org.apache.calcite.test.JdbcTest
- testIntersectOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIntersects() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Util.intersects(java.util.Collection, java.util.Collection)
. - testIntersectToDistinct() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests
IntersectToDistinctRule
, which rewrites anIntersect
operator with 3 inputs. - testIntersectToDistinctAll() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests that
IntersectToDistinctRule
correctly ignores anINTERSECT ALL
. - testInterval() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testIntervalArithmetics() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIntervalCompare() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIntervalCompare() - Method in class org.apache.calcite.test.SqlValidatorTest
- testIntervalLiteralHourToMinute() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testIntervalLiterals() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Runs tests for each of the thirteen different main types of INTERVAL qualifiers (YEAR, YEAR TO MONTH, etc.) Tests in this section fall into two categories: xxxPositive: tests that should pass parser and validator xxxFailsValidation: tests that should pass parser but fail validator
- testIntervalLiterals() - Method in class org.apache.calcite.test.SqlValidatorTest
- testIntervalLiteralYearToMonth() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testIntervalMillisConversion() - Method in class org.apache.calcite.test.SqlValidatorTest
- testIntervalMonthsConversion() - Method in class org.apache.calcite.test.SqlValidatorTest
- testIntervalOperators() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIntervalOperators() - Method in class org.apache.calcite.test.SqlValidatorTest
- testIntervalTimeUnitEnumeration() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInToSemiJoin() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInToSemiJoinWithCast() - Method in class org.apache.calcite.test.CsvTest
- testInToSemiJoinWithoutCast() - Method in class org.apache.calcite.test.CsvTest
- testInUncorrelatedSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInUncorrelatedSubQueryInHavingRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInUncorrelatedSubQueryInSelect() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInUncorrelatedSubQueryInSelectRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInUncorrelatedSubQueryRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInvalidAccessUseStringForIndexOnArray() - Method in class org.apache.calcite.test.CollectionTypeTest
- testInvalidAccessUseStringForIndexOnArrayWithAnyType() - Method in class org.apache.calcite.test.CollectionTypeTest
- testInvalidFunction() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInvalidGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInvalidGroupBy2() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInvalidGroupBy3() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInvalidToken() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testInvalidWindowFunctionWithGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testInValueListLong() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testInValueListShort() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testIs() - Method in class org.apache.calcite.test.SqlValidatorTest
- testIsAlwaysTrueAndFalseNotXisNullisNotNullisFalse() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseNotXisNullisNotNullisNotTrue() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseNotXisNullisNotNullisTrue() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseXisNotNullisNotNull() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseXisNotNullisNull() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseXisNullisNotNull() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseXisNullisNotNullisFalse() - Method in class org.apache.calcite.test.RexProgramTest
-
Unit tests for [CALCITE-2438] RexCall#isAlwaysTrue returns incorrect result.
- testIsAlwaysTrueAndFalseXisNullisNotNullisNotFalse() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseXisNullisNotNullisNotTrue() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseXisNullisNotNullisTrue() - Method in class org.apache.calcite.test.RexProgramTest
- testIsAlwaysTrueAndFalseXisNullisNull() - Method in class org.apache.calcite.test.RexProgramTest
- testIsASet() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIsASet() - Method in class org.apache.calcite.test.SqlValidatorTest
- testIsASetOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsAssignableFrom() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
- testIsBooleanPrecedenceAndAssociativity() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIsBooleans() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIsDeterministic() - Method in class org.apache.calcite.test.RexProgramTest
- testIsDistinctBenchmark() - Method in class org.apache.calcite.util.UtilTest
-
Benchmark for
Util.isDistinct(java.util.List<E>)
. - testIsDistinctFrom() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIsDistinctFrom() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testIsDistinctFromOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsEmptyOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testIsFalseOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsLinux() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Matchers.isLinux(java.lang.String)
. - testIsNotASetOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsNotDistinct() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testIsNotDistinctFrom() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testIsNotDistinctFromOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsNotDistinctInFilter() - Method in class org.apache.calcite.test.JdbcTest
- testIsNotEmptyOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsNotFalseOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsNotNull() - Method in class org.apache.calcite.test.DruidAdapterIT
- testIsNotNull() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testIsNotNullOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsNotTrueOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsNotUnknownOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsNull() - Method in class org.apache.calcite.test.DruidAdapterIT
- testIsNull() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testIsNull() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testIsNullOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsSpecific() - Method in class org.apache.calcite.prepare.LookupOperatorOverloadsTest
- testIsTableFunction() - Method in class org.apache.calcite.prepare.LookupOperatorOverloadsTest
- testIsTrueOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsUnknownOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testIsUserDefined() - Method in class org.apache.calcite.prepare.LookupOperatorOverloadsTest
- testIsUserDefinedNotSpecificFunction() - Method in class org.apache.calcite.prepare.LookupOperatorOverloadsTest
- testItemOp() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testItemPredicate() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testIterableCast() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testIterableOfType() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testIterableProperties() - Method in class org.apache.calcite.util.UtilTest
- testIterator() - Method in class org.apache.calcite.util.ChunkListTest
-
Removing via an iterator.
- testIterator() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
ImmutableBitSet.iterator()
. - testJanino169() - Method in class org.apache.calcite.test.JdbcTest
-
Janino bug [JANINO-169] running queries against the JDBC adapter.
- testJavaBoolean() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testJavaobject() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testJavaVersion(int, String) - Method in class org.apache.calcite.util.TestUtilTest
- testJdbcAggregate() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testJdbcDate() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a date literal against a JDBC data source.
- testJdbcFn() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Tests support for JDBC functions.
- testJdbcFunctionCall() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJdbcFunctionCall() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJdbcSchemaDirectConnection() - Method in class org.apache.calcite.test.JdbcTest
-
Connects to a JDBC schema without writing a model.
- testJdbcTimestamp() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a timestamp literal against JDBC data source.
- testJdbcValues() - Method in class org.apache.calcite.tools.FrameworksTest
-
Test case for [CALCITE-1996] VALUES syntax.
- testJdbcWithEnumerableJoin() - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest
- testJethroDataSelectQueryWithOrderByDescAndNullsFirstShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJG() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a query that is created within
LatticeTest.testTileAlgorithm()
. - testJoin() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testJoin() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testJoin() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testJoin() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Runs a simple query that joins between two in-memory schemas.
- testJoin() - Method in class org.apache.calcite.test.RelBuilderTest
- testJoin(CorrelateJoinType, Integer[][]) - Method in class org.apache.calcite.linq4j.test.CorrelateJoinTest
- testJoin2() - Method in class org.apache.calcite.test.RelBuilderTest
- testJoin3TablesPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testJoinAggregateMaterializationAggregateFuncs1() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs10() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs11() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs12() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs13() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs2() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs3() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs4() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs5() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs6() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs7() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs8() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationAggregateFuncs9() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs1() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs10() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs2() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs3() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs4() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs5() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs6() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs7() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs8() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAggregateMaterializationNoAggregateFuncs9() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinAssociativity() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJoinCartesian() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testJoinCartesian() - Method in class org.apache.calcite.test.RelBuilderTest
- testJoinCartesianCount() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testJoinCartesianProduct() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testJoinCorrelatedScalarSubQuery() - Method in class org.apache.calcite.test.JdbcTest
- testJoinCross() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJoinFiveWay() - Method in class org.apache.calcite.test.JdbcTest
-
Four-way join.
- testJoinGroupByEmpty() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testJoinGroupByOrderBy() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testJoinInCorrelatedSubQuery() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-313] Query decorrelation fails.
- testJoinInner() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testJoinJoin() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-35] Support parenthesized sub-clause in JOIN.
- testJoinKeywords() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testJoinManyWay() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a simple (primary key to primary key) N-way join, with arbitrary N.
- testJoinMaterialization() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization10() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization11() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization2() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization3() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization4() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization5() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization6() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization7() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization8() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterialization9() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK1() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK2() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK3() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK4() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK5() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK6() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK7() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK8() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMaterializationUKFK9() - Method in class org.apache.calcite.test.MaterializationTest
- testJoinMismatchedVarchar() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-1153] Invalid CAST when push JOIN down to Oracle.
- testJoinNatural() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinNaturalMultipleCommonColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinNaturalNoCommonColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinOn() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJoinOn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinOnBoolean() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJoinOnExists() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinOnExistsCorrelated() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinOnExpression() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinOnIn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinOnIn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinOnInCorrelated() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinOnInCorrelatedFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinOnInSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinOnParentheses() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJoinOnParenthesesPlus() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Same as
SqlParserTest.testJoinOnParentheses()
but fancy aliases. - testJoinOnScalarCorrelated() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinOnScalarFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinOnString() - Method in class org.apache.calcite.test.CsvTest
- testJoinOnUnionMaterialization() - Method in class org.apache.calcite.test.MaterializationTest
-
A materialization that is a join of a union cannot at present be converted to a star table and therefore cannot be recognized.
- testJoinOuter() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testJoinPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
-
Test case for [CALCITE-893] Theta join in JdbcAdapter.
- testJoinPlan2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJoinPlan2() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testJoinProject() - Method in class org.apache.calcite.test.SparkAdapterTest
- testJoinProjectAliasProject() - Method in class org.apache.calcite.test.SparkAdapterTest
- testJoinProjectTranspose() - Method in class org.apache.calcite.test.RelOptRulesTest
- testJoinPushTransitivePredicatesRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testJoinPushTransitivePredicatesRule2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testJoinQuery() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJoinRowType() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinSubQuery() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinTheta() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
-
Tests a theta join: a join whose condition cannot be decomposed into input0.x = input1.x and ...
- testJoinToJdbc() - Method in class org.apache.calcite.test.SplunkAdapterTest
- testJoinUniqueKeys() - Method in class org.apache.calcite.test.RelMetadataTest
- testJoinUnnest() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinUnnestRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinUsing() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJoinUsing() - Method in class org.apache.calcite.test.RelBuilderTest
-
Same as
RelBuilderTest.testJoin()
using USING. - testJoinUsing() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinUsing() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinUsingCompound() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinUsingDupColsFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinUsingDynamicTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJoinUsingIncompatibleDatatype() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinUsingInvalidColsFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinUsingThreeWay() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-74] JOIN ...
- testJoinUsingThreeWay() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJoinWithUnion() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJson() - Method in class org.apache.calcite.test.CsvTest
- testJsonApiCommonSyntax() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonArray() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJsonArray() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJsonArray() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testJsonArray() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonArray() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJsonArray() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJsonArrayAgg() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJsonArrayAgg() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJsonArrayAgg() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testJsonArrayAgg() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJsonArrayAgg() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJsonArrayAggAdd() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonBuilder() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
JsonBuilder
. - testJsonExists() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJsonExists() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJsonExists() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testJsonExists() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonExists() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJsonExists() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJsonize() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonObject() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJsonObject() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJsonObject() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testJsonObject() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonObject() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJsonObject() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJsonObjectAgg() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJsonObjectAgg() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJsonObjectAgg() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testJsonObjectAgg() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJsonObjectAgg() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJsonObjectAggAdd() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonPredicate() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJsonPredicate() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJsonPredicate() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testJsonPredicate() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonPredicate() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJsonPredicate() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJsonQuery() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJsonQuery() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJsonQuery() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testJsonQuery() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJsonQuery() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJsonStructuredValueExpression() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonValue() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testJsonValue() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testJsonValue() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testJsonValue() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testJsonValue() - Method in class org.apache.calcite.test.SqlValidatorTest
- testJsonValueAny() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testJsonValueExpression() - Method in class org.apache.calcite.test.SqlJsonFunctionsTest
- testKeywords() - Method in class org.apache.calcite.test.BabelParserTest
-
Tests that there are no reserved keywords.
- testKeywordsLowerCase() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testLagDefaultValue() - Method in class org.apache.calcite.test.JdbcTest
-
Tests default value of LAG function.
- testLagExpressionOffset() - Method in class org.apache.calcite.test.JdbcTest
-
Tests expression in offset value of LAG function.
- testLagInvalidOffsetArgument() - Method in class org.apache.calcite.test.JdbcTest
-
Tests DATE as offset argument of LAG function.
- testLambdaCallsBinaryOp() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testLambdaCallsTwoArgMethod() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testLambdaPrimitiveTwoArgs() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testLarge() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testLarge() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests a large scalar expression, which will expose any O(n^2) algorithms lurking in the validation process.
- testLast() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testLastFunction() - Method in class org.apache.calcite.test.SqlValidatorTest
- testLastOrDefault() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testLastOrDefaultWithPredicate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testLastValueFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLastValueOver() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testLastWithoutList() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testLastWithPredicate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testLateral() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLateral() - Method in class org.apache.calcite.test.JdbcTest
- testLateral() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testLateral() - Method in class org.apache.calcite.test.SqlValidatorTest
- testLateralDecorrelate() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testLateralDecorrelateRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testLateralDecorrelateThetaRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testLateralJoin() - Method in class org.apache.calcite.test.JdbcTest
-
Unit test for LATERAL CROSS JOIN to table function.
- testLateralWithOver() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-531] Window function does not work in LATERAL.
- testLattice() - Method in class org.apache.calcite.test.LatticeTest
-
Tests some of the properties of the
Lattice
data structure. - testLatticeInvalidSql() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a lattice with invalid SQL (for a lattice).
- testLatticeInvalidSql2() - Method in class org.apache.calcite.test.LatticeTest
-
Left join is invalid in a lattice.
- testLatticeInvalidSql3() - Method in class org.apache.calcite.test.LatticeTest
-
Each lattice table must have a parent.
- testLatticeInvalidSqlFails() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a lattice whose SQL is invalid.
- testLatticeRecognizeGroupJoin() - Method in class org.apache.calcite.test.LatticeTest
-
Tests an aggregate on a 2-way join query can use an aggregate table.
- testLatticeRecognizeJoin() - Method in class org.apache.calcite.test.LatticeTest
-
Tests that a 2-way join query can be mapped 4-way join lattice.
- testLatticeSql() - Method in class org.apache.calcite.test.LatticeTest
-
Tests that it's OK for a lattice to have the same name as a table in the schema.
- testLatticeSqlWithGroupByFails() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a lattice whose SQL is invalid because it contains a GROUP BY.
- testLatticeSqlWithJoin() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a lattice with valid join SQL.
- testLatticeSqlWithOrderByFails() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a lattice whose SQL is invalid because it contains a ORDER BY.
- testLatticeSqlWithUnionFails() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a lattice whose SQL is invalid because it contains a UNION ALL.
- testLatticeStarTable() - Method in class org.apache.calcite.test.LatticeTest
-
When a lattice is registered, there is a table with the same name.
- testLatticeWithBadRowCountEstimate() - Method in class org.apache.calcite.test.LatticeTest
- testLatticeWithNoMeasures() - Method in class org.apache.calcite.test.LatticeTest
-
A lattice with no default measure list should get "count(*)" is its default measure.
- testLatticeWithPreDefinedTiles() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a model with pre-defined tiles.
- testLatticeWithPreDefinedTilesFewerMeasures() - Method in class org.apache.calcite.test.LatticeTest
-
A query that uses a pre-defined aggregate table, at the same granularity but fewer calls to aggregate functions.
- testLatticeWithPreDefinedTilesRollUp() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a query that uses a pre-defined aggregate table at a lower granularity.
- testLatticeWithSameNameAsTable() - Method in class org.apache.calcite.test.LatticeTest
-
Tests that it's OK for a lattice to have the same name as a table in the schema.
- testLeadDefaultValue() - Method in class org.apache.calcite.test.JdbcTest
-
Tests default value of LEAD function.
- TestLeafRel(RelOptCluster, RelTraitSet, String) - Constructor for class org.apache.calcite.plan.volcano.PlannerTests.TestLeafRel
- TestLeafRel(RelOptCluster, RelTraitSet, String) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestLeafRel
- testLeastFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLeastRestrictiveWithAny() - Method in class org.apache.calcite.sql.type.SqlTypeFactoryTest
- testLeastRestrictiveWithNull() - Method in class org.apache.calcite.sql.type.SqlTypeFactoryTest
- testLeastRestrictiveWithNullability() - Method in class org.apache.calcite.sql.type.SqlTypeFactoryTest
- testLeastRestrictiveWithNumbers() - Method in class org.apache.calcite.sql.type.SqlTypeFactoryTest
- testLeft() - Method in class org.apache.calcite.linq4j.test.CorrelateJoinTest
- testLeftAssociative() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testLeftJoin() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testLeftJoin() - Method in class org.apache.calcite.test.JdbcTest
- testLeftOuterJoinSimplificationToInner() - Method in class org.apache.calcite.test.RelOptRulesTest
- testLeftOuterJoinWithAlias() - Method in class org.apache.calcite.test.SqlValidatorTest
- testLesser() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testLessThanAssociativity() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLessThanOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLessThanOperatorInterval() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLessThanOrEqualOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLessThanOrEqualOperatorInterval() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLeWithAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testLexAndQuoting() - Method in class org.apache.calcite.test.SqlValidatorTest
- testLexCaseInsensitive() - Method in class org.apache.calcite.test.JdbcTest
-
Tests case-insensitive resolution of schema and table names.
- testLexCaseInsensitiveFindsNonexistentTable() - Method in class org.apache.calcite.test.JdbcTest
- testLexCaseInsensitiveSubQueryField() - Method in class org.apache.calcite.test.JdbcTest
-
Tests case-insensitive resolution of sub-query columns.
- testLexCaseInsensitiveTableAlias() - Method in class org.apache.calcite.test.JdbcTest
- testLexJava() - Method in class org.apache.calcite.test.JdbcTest
-
Tests metadata for the JAVA lexical scheme.
- testLexJava() - Method in class org.apache.calcite.test.SqlValidatorTest
- testLexJavaKeyword() - Method in class org.apache.calcite.test.SqlValidatorTest
- testLexMySQL() - Method in class org.apache.calcite.test.JdbcTest
-
Tests metadata for the MySQL lexical scheme.
- testLexMySQLANSI() - Method in class org.apache.calcite.test.JdbcTest
-
Tests metadata for the MySQL ANSI lexical scheme.
- testLexOracle() - Method in class org.apache.calcite.test.JdbcTest
-
Tests metadata for the ORACLE (and default) lexical scheme.
- testLexOracleAsJava() - Method in class org.apache.calcite.test.JdbcTest
-
Tests metadata for the ORACLE lexical scheme overridden like JAVA.
- testLexSqlServer() - Method in class org.apache.calcite.test.JdbcTest
-
Tests metadata for different the "SQL_SERVER" lexical scheme.
- testLike() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testLike() - Method in class org.apache.calcite.test.JdbcTest
-
Tests the LIKE operator.
- testLikeAndSimilar() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLikeAndSimilar() - Method in class org.apache.calcite.test.SqlValidatorTest
- testLikeDot() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Test case for [CALCITE-1898] LIKE must match '.' (period) literally.
- testLikeEscape() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLikeEscape2() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLikeOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLikeToRegex() - Method in class org.apache.calcite.test.JdbcTest
-
Unit test for
CalciteMetaImpl.likeToRegex(org.apache.calcite.avatica.Meta.Pat)
. - testLimit() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testLimit() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testLimit() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testLimit() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
"LIMIT ...
- testLimit() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testLimit() - Method in class org.apache.calcite.test.PigletTest
- testLimit() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testLimit() - Method in class org.apache.calcite.test.RelBuilderTest
- testLimit() - Method in class org.apache.calcite.test.SparkAdapterTest
- testLimitExample() - Method in class org.apache.calcite.test.PigletTest
- testLimitOffsetWithoutOrder() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLimitOnQueryableTable() - Method in class org.apache.calcite.test.JdbcTest
-
Limit implemented using
ExtendedEnumerable.take(int)
. - testLimitStar() - Method in class org.apache.calcite.test.JdbcTest
-
Alternative formulation for
JdbcTest.testFetchStar()
. - testLimitStartCount() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLimitUnion() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLimitWithoutOrder() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Test case that does not reproduce but is related to [CALCITE-1238] Unparsing LIMIT without ORDER BY after validation.
- testLimitZero() - Method in class org.apache.calcite.test.JdbcTest
-
"SELECT ...
- testLinear() - Method in class org.apache.calcite.test.RelMetadataTest
-
Unit test for
RelMdUtil.linear(int, int, int, double, double)
. - testLineItem() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testList() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testList0() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testList2() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testListener() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
-
Tests whether planner correctly notifies listeners of events.
- TestListener() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTest.TestListener
- testListToString() - Method in class org.apache.calcite.util.UtilTest
- testLiteral() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testLiteral() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLiteralAtLimit() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Tests that CAST fails when given a value just outside the valid range for that type.
- testLiteralBeyondLimit() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Tests that CAST fails when given a value just outside the valid range for that type.
- testLiteralChain() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLiteralChain() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testLiteralCollate() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLitmus() - Method in class org.apache.calcite.util.UtilTest
-
Test case for [CALCITE-1264] Litmus argument interpolation.
- testLnFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLoad() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testLoadSorted() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testLoadSorted2() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
-
As
ArrayTableTest.testLoadSorted()
but column #1 is the unique column, not column #0. - testLocalPreparedStatementFetch() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Test that returns all result sets in one go.
- testLocalStatementFetch() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testLocalTimeFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLocalTimestampFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLog2() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testLogFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLogic() - Method in class org.apache.calcite.test.RexTransformerTest
-
Test case for
LogicVisitor
. - testLongCount() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testLongCountPredicate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testLongIdentifiers() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testLongnvarchar() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testLongvarbinary() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testLongvarchar() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testLosslessCast() - Method in class org.apache.calcite.test.RexProgramTest
-
Unit test for
RexUtil.isLosslessCast(RexNode)
. - testLower() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testLowerFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLtrim() - Method in class org.apache.calcite.test.SqlFunctionsTest
-
Test for
SqlFunctions.ltrim(java.lang.String)
. - testLtrimFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testLtWithAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testMapItem() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMapItemPrecedence() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMappings() - Method in class org.apache.calcite.util.mapping.MappingTest
- testMappingsAppend() - Method in class org.apache.calcite.util.mapping.MappingTest
-
Unit test for
Mappings.append(org.apache.calcite.util.mapping.Mappings.TargetMapping, org.apache.calcite.util.mapping.Mappings.TargetMapping)
. - testMappingsCreateShiftMapping() - Method in class org.apache.calcite.util.mapping.MappingTest
-
Unit test for
Mappings.createShiftMapping(int, int...)
. - testMappingsOffsetSource() - Method in class org.apache.calcite.util.mapping.MappingTest
-
Unit test for
Mappings.offsetSource(org.apache.calcite.util.mapping.Mappings.TargetMapping, int)
. - testMapReduce() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testMapSchemaDirectConnection() - Method in class org.apache.calcite.test.JdbcTest
-
Connects to a map schema without writing a model.
- testMapValueConstructor() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMapValueConstructor() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMatchLimitOneBottomUp() - Method in class org.apache.calcite.test.HepPlannerTest
- testMatchLimitOneTopDown() - Method in class org.apache.calcite.test.HepPlannerTest
- testMatchRecognize() - Method in class org.apache.calcite.test.RelBuilderTest
- testMatchRecognize1() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize1() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMatchRecognize10() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize11() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize4() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize5() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize6() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize7() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize8() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognize9() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeDefineClause() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeDefineClause() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeDefineClause2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeDefineClause2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeDefineClause3() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeDefineClause3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeDefineClause4() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeDefineClause4() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeDefines() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeDefines2() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeDefines3() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeDefines4() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeDefines5() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeDefines6() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeInternals() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
-
Tries to create a calls to some internal operators in MATCH_RECOGNIZE.
- testMatchRecognizeMeasures1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeMeasures1() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeMeasures1() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMatchRecognizeMeasures1() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeMeasures2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeMeasures2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeMeasures2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMatchRecognizeMeasures3() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeMeasures3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeMeasures3() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMatchRecognizeMeasures4() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeMeasures4() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeMeasures5() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeMeasures5() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeMeasures6() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeMeasures6() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeMeasures7() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression10() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression11() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression12() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression13() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression3() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression4() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression5() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression6() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression7() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression8() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternExpression9() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternSkip1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternSkip1() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizePatternSkip1() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMatchRecognizePatternSkip2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternSkip2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizePatternSkip3() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternSkip3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizePatternSkip4() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternSkip4() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizePatternSkip5() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizePatternSkip5() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizePrevDown() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMatchRecognizePrevLast() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMatchRecognizeRowsPerMatch1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeRowsPerMatch1() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeRowsPerMatch2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeRowsPerMatch2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeSkipTo1() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeSkipTo2() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeSkipTo3() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeSkipToCaseInsensitive() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeSubset() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeSubset1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeSubset1() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeSubset1() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMatchRecognizeSubset2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeSubset2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeSubset2() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeSubset3() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeSubset3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeSubset4() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeWithin() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMatchRecognizeWithin() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMatchRecognizeWithin() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchRecognizeWithin2() - Method in class org.apache.calcite.test.SqlValidatorMatchTest
- testMatchUntilFixpoint() - Method in class org.apache.calcite.test.HepPlannerTest
- testMaterialization() - Method in class org.apache.calcite.test.HepPlannerTest
- testMaterializationOnJoinQuery() - Method in class org.apache.calcite.test.MaterializationTest
- testMaterializationReferencesTableInOtherSchema() - Method in class org.apache.calcite.test.MaterializationTest
- testMaterializationSubstitution() - Method in class org.apache.calcite.test.MaterializationTest
- testMaterializationSubstitution2() - Method in class org.apache.calcite.test.MaterializationTest
- testMaterializedView() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testMax() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testMaxFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMaxMinSumAvg() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testMaxMinSumAvgInGroupBy() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testMaxPrecision() - Method in class org.apache.calcite.sql.type.SqlTypeFactoryTest
-
Unit test for
SqlTypeUtil.comparePrecision(int, int)
andSqlTypeUtil.maxPrecision(int, int)
. - testMaxRaw() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testMaxSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testMaxSelector2() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testMazeTableFunction() - Method in class org.apache.calcite.test.ExampleFunctionTest
-
Unit test for
MazeTable
. - testMazeTableFunctionWithSolution() - Method in class org.apache.calcite.test.ExampleFunctionTest
-
Unit test for
MazeTable
. - testMeasureAggIsInvalid() - Method in class org.apache.calcite.test.LatticeTest
- testMeasureArgIsInvalidColumn() - Method in class org.apache.calcite.test.LatticeTest
- testMeasureArgIsNotUniqueAlias() - Method in class org.apache.calcite.test.LatticeTest
-
It is an error for "customer_id" to be a measure arg, because is not a unique alias.
- testMemberOf() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMemberOf() - Method in class org.apache.calcite.test.SqlValidatorTest
- testMemberOfOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMerge() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMergeFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests that filters are combined if they are identical.
- testMergeFilterWithJoinCondition() - Method in class org.apache.calcite.test.RelOptRulesTest
- testMergeIntersect() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests
UnionMergeRule.INTERSECT_INSTANCE
, which merges 2Intersect
operators into a singleIntersect
with 3 inputs. - testMergeJoin() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
- testMergeJoin() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testMergeJoin() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a merge-join.
- testMergeJoin2() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testMergeJoin3() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testMergeJoinFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests that a filters is combined are combined if they are identical, even if one of them originates in an ON clause of a JOIN.
- testMergeMinus() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests
UnionMergeRule.MINUS_INSTANCE
, which merges 2Minus
operators into a singleMinus
with 3 inputs. - testMergeMinusRightDeep() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests
UnionMergeRule.MINUS_INSTANCE
does not mergeMinus(a, Minus(b, c))
intoMinus(a, b, c)
, which would be incorrect. - testMergeProjectForceMode() - Method in class org.apache.calcite.tools.PlannerTest
- testMergeSelectSource() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMergeSetOpMixed() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests that
UnionMergeRule
does nothing if its arguments have are different set operators,Union
andIntersect
. - testMergeTableRefSource() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMergeUnionAll() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests
UnionMergeRule
, which merges 2Union
operators into a singleUnion
with 3 inputs. - testMergeUnionDistinct() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests
UnionMergeRule
, which merges 2Union
DISTINCT
(notALL
) operators into a singleUnion
with 3 inputs. - testMergeUnionMixed() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests that
UnionMergeRule
does nothing if its arguments have differentALL
settings. - testMergeUnionMixed2() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests that
UnionMergeRule
converts all inputs to DISTINCT if the top one is DISTINCT. - testMetadata() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMetadata() - Method in class org.apache.calcite.test.BabelParserTest
- testMetadataAggregatePredicates() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests predicates that can be pulled-up from an Aggregate with
GROUP BY ()
. - testMetadataAggregatePredicates2() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests predicates that can be pulled-up from an Aggregate with a non-empty group key.
- testMetadataAggregatePredicates3() - Method in class org.apache.calcite.tools.PlannerTest
- testMetadataColumns() - Method in class org.apache.calcite.test.DruidAdapterIT
- testMetadataColumns() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testMetaDataColumns() - Method in class org.apache.calcite.test.JdbcTest
-
Tests driver's implementation of
DatabaseMetaData.getColumns(java.lang.String, java.lang.String, java.lang.String, java.lang.String)
. - testMetadataHandlerCacheLimit() - Method in class org.apache.calcite.test.RelMetadataTest
- testMetaDataPrimaryKeys() - Method in class org.apache.calcite.test.JdbcTest
-
Tests driver's implementation of
DatabaseMetaData.getPrimaryKeys(java.lang.String, java.lang.String, java.lang.String)
. - testMetadataTables() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testMetadataUnionPredicates() - Method in class org.apache.calcite.tools.PlannerTest
-
Tests predicates that can be pulled-up from a UNION.
- testMetadataUnionPredicates2() - Method in class org.apache.calcite.tools.PlannerTest
-
Test case for [CALCITE-443] getPredicates from a union is not correct.
- testMetadataUnionPredicates3() - Method in class org.apache.calcite.tools.PlannerTest
- testMetadataUnionPredicates4() - Method in class org.apache.calcite.tools.PlannerTest
- testMetadataUnionPredicates5() - Method in class org.apache.calcite.tools.PlannerTest
- testMetaFunctionsLocal() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testMetaTables() - Method in class org.apache.calcite.test.JdbcTest
-
Tests the TABLES table in the information schema.
- testMin() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testMinFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMinMaxFunctions() - Method in class org.apache.calcite.test.SqlValidatorTest
- testMinSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testMinSelector2() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testMinusAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testMinusArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT
- testMinusArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testMinusDateOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMinusDateOperator() - Method in class org.apache.calcite.test.SqlValidatorTest
- testMinusIntervalOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMinusIsReserved() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
MINUS is a reserved keyword in Calcite in all conformances, even in the default conformance, where it is not allowed as an alternative to EXCEPT.
- testMinusMergeRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testMinusOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMinusPrefixInExpression() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMinute() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMiscIntervalQualifier() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMissing() - Method in class org.apache.calcite.runtime.BinarySearchTest
- testMissingProjectRelationOnGroupByColumnMatchingProjectedFields() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
-
When the group by columns match the projected fields, the optimizers removes the projected relation.
- testMissingProjectRelationOnGroupByColumnMatchingProjectedFields2() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
-
When the group by columns match the projected fields, the optimizers removes the projected relation.
- testMixed1() - Method in class org.apache.calcite.test.RexTransformerTest
- testMixed2() - Method in class org.apache.calcite.test.RexTransformerTest
- testMixed3() - Method in class org.apache.calcite.test.RexTransformerTest
- testMixedEqualAndIsNotDistinctJoin() - Method in class org.apache.calcite.test.JdbcTest
- testMixedFrom() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMixedJoinPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testMixedJoinWithOrPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testMixedStar() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMockDdl() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that a driver can be extended with its own parser and can execute its own flavor of DDL.
- testModel() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model (a single schema based on a JDBC database).
- testModelCustomSchema() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains a custom schema.
- testModelCustomTable() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains custom tables.
- testModelCustomTable2() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains custom tables.
- testModelCustomTableArrayRowSingleColumn() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains custom tables.
- testModelCustomTableIntegerRowSingleColumn() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains custom tables.
- testModelImmutableSchemaCannotContainMaterialization() - Method in class org.apache.calcite.test.ModelTest
-
Tests that an immutable schema in a model cannot contain a materialization.
- testModelImmutableSchemaCannotContainView() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that an immutable schema in a model cannot contain a view.
- testModelView() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains a view.
- testModelWithComment() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JSON model with a comment.
- testModelWithInvalidModifiableView() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a few cases where modifiable views are invalid.
- testModelWithMaterializedView() - Method in class org.apache.calcite.test.JdbcTest
-
Defines a materialized view and tests that the query is rewritten to use it, and that the query produces the same result with and without it.
- testModelWithModifiableView() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a modifiable view.
- testModFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testModFuncDivByZero() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testModFuncNull() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testModifiableViewDdlExtend() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testModifiableViewExtend() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testModifiableViewExtendExpression() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testModifiableViewExtendSubset() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testModOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testModOperatorDivByZero() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testModOperatorNull() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testModPrecedence() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMonotonic() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests that various expressions are monotonic.
- testMonth() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMssql() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testMssqlCharacterSet() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMultiAnd() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Tests that AND(x, AND(y, z)) gets flattened to AND(x, y, z).
- testMultiLevelAlias() - Method in class org.apache.calcite.test.RelBuilderTest
- testMultilineComment() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMultiMaterializationMultiUsage() - Method in class org.apache.calcite.test.MaterializationTest
- testMultiMaterializationOnJoinQuery() - Method in class org.apache.calcite.test.MaterializationTest
- testMultiPassOptimization() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testMultipleDifferentAs() - Method in class org.apache.calcite.test.SqlValidatorTest
- testMultipleDistinctWithGrouping() - Method in class org.apache.calcite.test.RelOptRulesTest
- testMultipleFiltersFactoredOutWithOuterFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that multiple aggregates with the same filter clause have them factored out in the presence of an outer filter, and that they no longer refer to those filters
- testMultipleFiltersFactoredOutWithOuterFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that multiple aggregates with the same filter clause have them factored out in the presence of an outer filter, and that they no longer refer to those filters
- testMultipleFolding() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testMultipleSameAsPass() - Method in class org.apache.calcite.test.SqlValidatorTest
- testMultipleScannableTableFunctionWithNamedParameters() - Method in class org.apache.calcite.test.TableFunctionTest
-
As
TableFunctionTest.testScannableTableFunction()
but with named parameters. - testMultiplyAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testMultiplyArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT
- testMultiplyArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testMultiplyIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMultiplyOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMultiset() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMultiset() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testMultiset() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testMultiset() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMultiset() - Method in class org.apache.calcite.test.SqlValidatorFeatureTest
- testMultiset() - Method in class org.apache.calcite.test.SqlValidatorTest
- testMultisetCast() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMultisetConstructor() - Method in class org.apache.calcite.test.JdbcTest
- testMultisetConstructor() - Method in class org.apache.calcite.test.SqlValidatorTest
- testMultisetExcept() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMultisetIntersect() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMultisetMixed() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMultisetOfColumns() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMultisetOfColumnsRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMultisetQuery() - Method in class org.apache.calcite.test.JdbcTest
- testMultisetQueryWithSingleColumn() - Method in class org.apache.calcite.test.JdbcTest
- testMultisetSetOperators() - Method in class org.apache.calcite.test.SqlValidatorTest
- testMultisetSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testMultisetUnion() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testMultisetUnionAllOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMultisetUnionOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testMysqlCastToBigint() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMysqlCastToInteger() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlSelectQueryWithOrderByAscAndNullsLastShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlSelectQueryWithOrderByAscNullsFirstShouldNotAddNullEmulation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlSelectQueryWithOrderByDescAndNullsFirstShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlSelectQueryWithOrderByDescNullsLastShouldNotAddNullEmulation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithFirstNullsSelectWithOrderByAscAndNullsFirstShouldNotBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithFirstNullsSelectWithOrderByAscAndNullsLastShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithFirstNullsSelectWithOrderByDescAndNullsFirstShouldNotBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithFirstNullsSelectWithOrderByDescAndNullsLastShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithHighNullsSelectWithOrderByAscNullsFirstAndNullEmulation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithHighNullsSelectWithOrderByAscNullsLastAndNoEmulation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithHighNullsSelectWithOrderByDescNullsFirstAndNoEmulation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithHighNullsSelectWithOrderByDescNullsLastAndNullEmulation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithLastNullsSelectWithOrderByAscAndNullsFirstShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithLastNullsSelectWithOrderByAscAndNullsLastShouldNotBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithLastNullsSelectWithOrderByDescAndNullsFirstShouldBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testMySqlWithLastNullsSelectWithOrderByDescAndNullsLastShouldNotBeEmulated() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testNameMap() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
NameMap
. - testNameMatcher() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- testNameMultimap() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
NameMultimap
. - testNameResolutionInValuesClause() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNameSet() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
NameSet
. - testNaturalCrossJoin() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testNaturalCrossJoinFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNaturalJoinCaseSensitive() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNaturalJoinIncompatibleDatatype() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNaturalJoinWithOnFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNaturalJoinWithUsing() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNchar() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testNclob() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testNestedAggFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNestedAggOver() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNestedAggregates() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testNestedAggregates() - Method in class org.apache.calcite.test.RelOptRulesTest
- testNestedAggregates() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNestedAggregatesMySqlStar() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
As
RelToSqlConverterTest.testNestedAggregatesMySqlTable()
, but input is a sub-query, not a table. - testNestedAggregatesMySqlTable() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testNestedArray() - Method in class org.apache.calcite.test.JdbcTest
-
Tests JDBC support for nested arrays.
- testNestedArrayOutOfBoundAccess() - Method in class org.apache.calcite.test.CollectionTypeTest
- testNestedArrayOutOfBoundAccessWithAnyType() - Method in class org.apache.calcite.test.CollectionTypeTest
- testNestedCalls() - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
-
Verifies
IS TRUE(IS NULL(null))
kind of expressions up to 4 level deep. - testNestedCorrelations() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNestedCorrelationsDecorrelated() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNestedCorrelationsDecorrelatedRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNestedFilterClauseFactored() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that an aggregate with a nested filter clause has it's filter factored out
- testNestedFilterClauseFactored() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that an aggregate with a nested filter clause has it's filter factored out
- testNestedFilterClauseInAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to ensure that aggregates with nested filters have their filters factored out into the outer filter for data pruning while still holding a reference to the filter clause
- testNestedFilterClauseInAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to ensure that aggregates with nested filters have their filters factored out into the outer filter for data pruning while still holding a reference to the filter clause
- testNestedFrom() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNestedListsLiteral() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testNestedSchemaNestedColumns() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- testNestedSchemaRootColumns() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- testNestedSchemaSelectStar() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterStructsTest
- testNestedSelect() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testNestSchema() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testNestSchemaSqlServer() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testNestTable1() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testNestTable2() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testNestTable3() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testNestTable4() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testNestTableSchemaMustMatch() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testNewBigInteger() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testNeWithAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testNewSpecification() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testNextPowerOf2() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testNlsStringClone() - Method in class org.apache.calcite.util.UtilTest
- testNoCalcBetweenJoins() - Method in class org.apache.calcite.test.JdbcTest
-
Makes sure that a projection introduced by a call to
JoinCommuteRule
does not manifest as anEnumerableCalc
in the plan. - testNoCommonReturnTypeFails() - Method in class org.apache.calcite.test.RexProgramTest
- testNodeTypeCountAggregate() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountAggregateEmptyKeyOnEmptyTable() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountAggregateGroupingSets() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountCartesian() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountDept() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountEmp() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountFilterAggregateEmptyKey() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountJoin() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountJoinEmptyEmpty() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountJoinEmptyFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountJoinFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountJoinFiniteEmpty() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountLeftJoinEmptyFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountMinusOnFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountRightJoinEmptyFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountSort() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountSortLimit() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountSortLimitOffset() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountSortLimitOffsetOnFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountUnionOnFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testNodeTypeCountValues() - Method in class org.apache.calcite.test.RelMetadataTest
- testNoInlineMultipleUsage() - Method in class org.apache.calcite.linq4j.test.InlinerTest
- testNonAmbiguity() - Method in class org.apache.calcite.util.ReflectVisitorTest
-
Tests that ambiguity detection in method lookup does not kick in when a better match is available.
- testNonBooleans() - Method in class org.apache.calcite.test.RexTransformerTest
- testNonDeterministicMethodCall() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- testNonDisjointUnion() - Method in class org.apache.calcite.test.MaterializationTest
- testNonEquiJoinPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
-
Test case for [CALCITE-631] Push theta joins down to JDBC adapter.
- testNonEquiJoinReverseConditionPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testNonexistentTable() - Method in class org.apache.calcite.test.ExceptionMessageTest
- testNonLocalStar() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNonNullFilterOnDateType() - Method in class org.apache.calcite.test.CsvTest
- testNonOptimizableTernary() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNonPushableFilterSortDesc() - Method in class org.apache.calcite.test.DruidAdapterIT
-
As
DruidAdapterIT.testFilterSortDescNumeric()
but with a filter that cannot be pushed down to Druid. - testNonPushableFilterSortDesc() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
As
DruidAdapterIT2.testFilterSortDescNumeric()
but with a filter that cannot be pushed down to Druid. - testNonSqlException() - Method in class org.apache.calcite.test.ExceptionMessageTest
- testNoOversimplificationBelowIsNull() - Method in class org.apache.calcite.test.RelOptRulesTest
- testNoPublicFields() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests querying an object that has no public fields.
- testNormalize() - Method in class org.apache.calcite.test.RexProgramTest
-
Tests construction and normalization of a RexProgram.
- testNot() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testNotBetween() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNotCaseInMoreClause() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotCaseInThreeClause() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotCaseInWithoutElse() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotEq() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualBoolFalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualBoolTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualDifferentConst() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualDifferentExpr() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualObjectNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualPrimitiveNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualSameConst() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualSameExpr() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualsOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNotEqualsOperatorIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNotEqualStringNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualTypedNullUntypedNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotEqualUnypedNullTypedNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotExists() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testNotExistsCorrelated() - Method in class org.apache.calcite.test.JdbcTest
- testNotExistsCorrelated() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotExistsCorrelated2() - Method in class org.apache.calcite.test.JdbcTest
-
Manual expansion of EXISTS in
JdbcTest.testNotExistsCorrelated()
. - testNotExistsWithExpand() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testNotFalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotFilterForm() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to make sure the "not" filter has only 1 field, rather than an array of fields.
- testNotFilterForm() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to make sure the "not" filter has only 1 field, rather than an array of fields.
- testNotGt() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotGte() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNoThSelect() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads from a local file without table headers <TH> and checks the result.
- testNotIllegalTypeFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNotIn() - Method in class org.apache.calcite.test.JdbcTest
-
Tests the NOT IN operator.
- testNotInEmptyQuery() - Method in class org.apache.calcite.test.JdbcTest
- testNotInOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNotInQuery() - Method in class org.apache.calcite.test.JdbcTest
- testNotInQueryWithNull() - Method in class org.apache.calcite.test.JdbcTest
- testNotInUncorrelatedSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotInUncorrelatedSubQueryInSelect() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Plan should be as
SqlToRelConverterTest.testInUncorrelatedSubQueryInSelect()
, but with an extra NOT. - testNotInUncorrelatedSubQueryInSelectDeduceNotNull() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Even though "mgr" allows nulls, we can deduce from the WHERE clause that it will never be null.
- testNotInUncorrelatedSubQueryInSelectDeduceNotNull2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Similar to
SqlToRelConverterTest.testNotInUncorrelatedSubQueryInSelectDeduceNotNull()
, usingIS NOT NULL
. - testNotInUncorrelatedSubQueryInSelectDeduceNotNull3() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Similar to
SqlToRelConverterTest.testNotInUncorrelatedSubQueryInSelectDeduceNotNull()
, usingIN
. - testNotInUncorrelatedSubQueryInSelectMayBeNull() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Since 'deptno NOT IN (SELECT mgr FROM emp)' can be null, we need a more complex plan, including counts of null and not-null keys.
- testNotInUncorrelatedSubQueryInSelectNotNull() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Since 'deptno NOT IN (SELECT deptno FROM dept)' can not be null, we generate a simpler plan.
- testNotInUncorrelatedSubQueryInSelectNotNullRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotInUncorrelatedSubQueryInSelectRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotInUncorrelatedSubQueryRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotInWithLiteral() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotLike() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testNotLike() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotLikeOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNotLt() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotLte() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotNeq() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotNotA() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotNotIn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testNotNull() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testNotNullImplementor() - Method in class org.apache.calcite.test.UdfTest
-
Tests that IS NULL/IS NOT NULL is properly implemented for non-strict functions.
- testNotOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNotSimilarToOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNotSubMultisetOfOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNotTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testNotTrueSimpleFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testNotTrueSimpleFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testNoUnintendedNewReservedKeywords() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests that reserved keywords are not added to the parser unintentionally.
- testNth() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testNtile1() - Method in class org.apache.calcite.test.JdbcTest
-
Tests NTILE(2).
- testNtile2() - Method in class org.apache.calcite.test.JdbcTest
-
Tests NTILE(2).
- testNtileConstantArgs() - Method in class org.apache.calcite.test.JdbcTest
-
Tests expression in offset value of LAG function.
- testNtileDecimalArg() - Method in class org.apache.calcite.test.JdbcTest
-
Tests expression in offset value of LAG function.
- testNtileNegativeArg() - Method in class org.apache.calcite.test.JdbcTest
-
Tests expression in offset value of LAG function.
- testNull() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testNull() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNullableNumericColumnInCloneSchema() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-730] ClassCastException in table from CloneSchema.
- testNullableTimestamp() - Method in class org.apache.calcite.test.JdbcTest
-
There was a bug representing a nullable timestamp using a
Long
internally. - testNullableTimestamp2() - Method in class org.apache.calcite.test.JdbcTest
-
Similar to
JdbcTest.testNullableTimestamp()
but directly off JDBC. - testNullCast() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNullIf() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testNullIf() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNullifFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNullIfOperatorIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testNullOperand() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Test case for [CALCITE-1864] Allow NULL literal as argument.
- testNulls() - Method in class org.apache.calcite.test.FilteratorTest
- testNumber() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
-
Tests the
Primitive.number(Number)
method. - testNumbers() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNumeric() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testNumericOperators() - Method in class org.apache.calcite.test.SqlValidatorTest
- testNumericOrderingOfOrderByOperatorFullTime() - Method in class org.apache.calcite.test.DruidAdapterIT
- testNumericOrderingOfOrderByOperatorFullTime() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testNumericOrderingOfOrderByOperatorStringDims() - Method in class org.apache.calcite.test.DruidAdapterIT
- testNumericOrderingOfOrderByOperatorStringDims() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testNumericOrderingOfOrderByOperatorTimeExtract() - Method in class org.apache.calcite.test.DruidAdapterIT
- testNumericOrderingOfOrderByOperatorTimeExtract() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testNvarchar() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testNvlFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testObscuredAliasFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOfBox() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
- testOfBoxOr() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
- testOffset() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOffset0() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOffsetFetch() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOffsetFetchWithDynamicParameter() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOffsetLimit() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testOffsetLimit() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testOffsetLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testOffsetLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testOffsetWithDynamicParameter() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOfType() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testOldJoinStyleDeCorrelation() - Method in class org.apache.calcite.tools.PlannerTest
-
Test to determine whether de-correlation correctly removes Correlator.
- testOn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOnCondition() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testOnConnectionClose() - Method in class org.apache.calcite.test.JdbcTest
-
Tests
Handler.onConnectionClose(org.apache.calcite.avatica.AvaticaConnection)
andHandler.onStatementClose(org.apache.calcite.avatica.AvaticaStatement)
. - testOne() - Method in class org.apache.calcite.plan.volcano.TraitPropagationTest
- testOne() - Method in class org.apache.calcite.test.FilteratorTest
- testOne() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
- testOne() - Method in class org.apache.calcite.util.PermutationTestCase
- testOneElementMapLiteral() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testOneLatticeOneMV() - Method in class org.apache.calcite.test.LatticeTest
- testOneValueOneNull() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testOneWinFunc() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOnlyPostfix() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testOnlyPrefix() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testOnlyQuoteIdentifiersWhichNeedIt() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testOp() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testOperateOnColumn() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOperator() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests a relation that is accessed via method syntax.
- testOperatorsSortedByPrecedence() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests that operators, sorted by precedence, are in a sane order.
- testOptimize() - Method in class org.apache.calcite.tools.FrameworksTest
- testOptimizeBoxedFalseEqNull() - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest
-
CALCITE-2611: unknown on one side of an or may lead to uncompilable code
- testOptimizeComparison() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeNonNullLiterals() - Method in class org.apache.calcite.test.RexTransformerTest
- testOptimizeTernaryABfalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryABtrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAeqBAB() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAeqBBA() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAfalseB() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAlwaysFalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAlwaysSame() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAlwaysTrue() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAneqBAB() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAneqBBA() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAtrueB() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAtrueBoxed() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryAtrueNull() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryInEqualABCeqB() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryInEqualABCeqC() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryInEqualABCneqB() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryInEqualABCneqC() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryRotateEqualFalse() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOptimizeTernaryRotateNot() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOr() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testOrAlwaysTrue() - Method in class org.apache.calcite.test.RelOptRulesTest
- testOrAlwaysTrue2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testOrCombinationOfExpAndSimpleFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testOrCombinationOfExpAndSimpleFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testOrder() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOrder() - Method in class org.apache.calcite.test.PigletTest
- testOrder() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrder() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOrderBasedRepeatFields() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Tests that if a column occurs twice in ORDER BY, only the first key is kept.
- testOrderBy() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testOrderBy() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Simple ORDER BY.
- testOrderBy() - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY with no options.
- testOrderBy() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testOrderByAlias() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByAliasDoesNotOverride() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByAliasInExpr() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByAliasOverrides() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByCase() - Method in class org.apache.calcite.test.JdbcTest
- testOrderByCast() - Method in class org.apache.calcite.test.JdbcTest
-
Tests sorting by a CAST expression not in the select clause.
- testOrderByColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOrderByComparator() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testOrderByDesc() - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY ...
- testOrderByDesc() - Method in class org.apache.calcite.test.SqlValidatorFeatureTest
- testOrderByDescending() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testOrderByExpr() - Method in class org.apache.calcite.test.JdbcTest
-
Tests sorting by an expression not in the select clause.
- testOrderByFetch() - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY ...
- testOrderByIdenticalExpr() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByInSeries() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testOrderByLimit() - Method in class org.apache.calcite.test.SparkAdapterTest
- testOrderByList() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testOrderByNegativeOrdinal() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByNonSelectColumn() - Method in class org.apache.calcite.tools.PlannerTest
- testOrderByNulls() - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY with all combinations of ASC, DESC, NULLS FIRST, NULLS LAST.
- testOrderByOffset() - Method in class org.apache.calcite.test.SparkAdapterTest
- testOrderByOffsetFetch() - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY ...
- testOrderByOneColumnNotProjected() - Method in class org.apache.calcite.test.DruidAdapterIT
- testOrderByOneColumnNotProjected() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testOrderByOnMetricsInSelectDruidQuery() - Method in class org.apache.calcite.test.DruidAdapterIT
- testOrderByOnMetricsInSelectDruidQuery() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testOrderByOnSortedTable() - Method in class org.apache.calcite.test.JdbcTest
-
Tests sorting by a column that is already sorted.
- testOrderByOnSortedTable2() - Method in class org.apache.calcite.test.JdbcTest
-
Tests sorting by a column that is already sorted.
- testOrderByOrdinalDesc() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByOrdinalInExpr() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByOver() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByQueryOnOrderByView() - Method in class org.apache.calcite.test.MaterializationTest
- testOrderByQueryOnProjectView() - Method in class org.apache.calcite.test.MaterializationTest
- testOrderBySameExpr() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderByVarious() - Method in class org.apache.calcite.test.JdbcTest
-
Tests ORDER BY ...
- testOrderByView() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a view with ORDER BY and LIMIT clauses.
- testOrderDescNullsLast() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderDistinct() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderDistinct() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests validation of the ORDER BY clause when DISTINCT is present.
- testOrderExample() - Method in class org.apache.calcite.test.PigletTest
- testOrderGroup() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderGroup() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests validation of the ORDER BY clause when GROUP BY is present.
- testOrderGroupDistinct() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests validation of the ORDER BY clause when DISTINCT and GROUP BY are present.
- testOrderIllegalInExpression() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOrderInternal() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOrderJoin() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOrderNullsFirst() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOrderOffsetFetch() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOrderOffsetFetch() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderOffsetFetchWithDynamicParameter() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderOnSortedTable() - Method in class org.apache.calcite.test.JdbcTest
-
ORDER BY on a sort-key does not require a sort.
- testOrders() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testOrderSorted() - Method in class org.apache.calcite.test.JdbcTest
-
ORDER BY on a sort-key does not require a sort.
- testOrderStar() - Method in class org.apache.calcite.test.PigletTest
- testOrderStarByExpr() - Method in class org.apache.calcite.test.JdbcTest
-
Tests sorting by an expression not in the '*' select clause.
- testOrderUnion() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOrderUnion() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderUnion() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOrderUnionExprs() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderUnionOrdinal() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOrderUnionStarByExpr() - Method in class org.apache.calcite.test.JdbcTest
- testOrdinalInGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests validation of ordinals in GROUP BY.
- testOrdReverse() - Method in class org.apache.calcite.util.UtilTest
- testOrElseFalseBool() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOrElseNullBool() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOrElseTrueBool() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOrElseXX() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOrElseXY() - Method in class org.apache.calcite.linq4j.test.OptimizerTest
- testOrOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testOrOperatorLazy() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testOrUnchanged() - Method in class org.apache.calcite.test.RexTransformerTest
-
the or operator should pass through unchanged since e.g.
- testOther() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testOuterApply() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests OUTER APPLY.
- testOuterApplyFunctionFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Even in SQL Server conformance mode, we do not yet support 'function(args)' as an abbreviation for 'table(function(args)'.
- testOuterApplySubQuery() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOuterApplyValues() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOuterFilterFalseAfterFactorSimplification() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests that when the resulting filter from factoring filter clauses out is always false, that they are still pushed to Druid to handle.
- testOuterFilterFalseAfterFactorSimplification() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests that when the resulting filter from factoring filter clauses out is always false, that they are still pushed to Druid to handle.
- testOuterFilterRemainsWithAlwaysTrueClause() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests whether an existing outer filter is untouched when an aggregate has a filter clause that is always true
- testOuterFilterRemainsWithAlwaysTrueClause() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests whether an existing outer filter is untouched when an aggregate has a filter clause that is always true
- testOuterJoinNoiseWord() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOver() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOverAvg() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOverAvg2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOverCountStar() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOverDefault() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testOverDisallowPartial() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testOverInOrderBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOverInPartitionBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOverlaps() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOverlaps() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testOverlaps() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOverlapsOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testOverlay() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testOverlay() - Method in class org.apache.calcite.test.SqlValidatorTest
- testOverlayFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testOverMultiple() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testOverNonSupportedDialect() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testOverNoOrder() - Method in class org.apache.calcite.test.JdbcTest
-
Tests windowed aggregation with no ORDER BY clause.
- testOverOrderFollowingWindow() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Tests that a window with a FOLLOWING bound becomes BETWEEN CURRENT ROW AND FOLLOWING.
- testOverOrderWindow() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Tests that a window containing only ORDER BY is implicitly CURRENT ROW.
- testOverRowsBetweenBoundFollowingAndFollowing() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testOverRowsBetweenBoundPrecedingAndCurrent() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testOversimplifiedCaseStatement() - Method in class org.apache.calcite.test.RelOptRulesTest
- testOverUnboundedPreceding() - Method in class org.apache.calcite.test.JdbcTest
-
Tests UNBOUNDED PRECEDING clause.
- testPairAdjacents() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Pair.adjacents(Iterable)
. - testPairFirstAnd() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Pair.firstAnd(Iterable)
. - testPairZip() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Pair.zip(java.util.List, java.util.List)
. - testParameterConvert() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
For each (source, destination) type, make sure that we can convert bind variables.
- testParameterName() - Method in class org.apache.calcite.util.UtilTest
-
Tests
ReflectUtil.getParameterName(java.lang.reflect.Method, int)
. - testParametersShouldWorkWithRaw() - Method in class org.apache.calcite.chinook.RemotePreparedStatementParametersTest
- testParensInFrom() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testParenthesizeAllExprs() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testParse2() - Method in class org.apache.calcite.test.PigletTest
-
Tests parsing and un-parsing all kinds of operators.
- testParseAndConvert() - Method in class org.apache.calcite.tools.PlannerTest
- testParseAndConvertWithOrderByAndOffset() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that parses, validates and converts the query using order by and offset.
- testParseFails() - Method in class org.apache.calcite.tools.PlannerTest
- testParseIdentiferMaxLengthWithDefault() - Method in class org.apache.calcite.tools.PlannerTest
- testParseIdentiferMaxLengthWithIncreased() - Method in class org.apache.calcite.tools.PlannerTest
- testParseLoad() - Method in class org.apache.calcite.test.PigletTest
- testParseLocale() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Util.parseLocale(String)
method. - testParseNumber() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testParseNumberFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testParseWithReader() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPartialIdentifier() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testPartiallyPostAggregation() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPartiallyPostAggregation() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPartialUnion() - Method in class org.apache.calcite.test.MaterializationTest
- testPartitionByColumnInJoinAlias() - Method in class org.apache.calcite.test.SqlValidatorTest
- testPartitionByExpr() - Method in class org.apache.calcite.test.SqlValidatorTest
- testPath() - Method in class org.apache.calcite.test.UdfTest
-
Tests resolution of functions using schema paths.
- testPaths() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
-
Unit test for
Graphs.FrozenGraph
. - testPercentageOriginalRowsAgg() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsJoin() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsJoinTwoFilters() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsOneFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsRedundantFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsTableOnly() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsTwoFilters() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsUnionBigFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsUnionLittleFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentageOriginalRowsUnionNoFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testPercentRankFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPerformance() - Method in class org.apache.calcite.util.ChunkListTest
- testPeriod() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPeriodOperators() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPermute() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
-
Test for
Primitive.permute(Object, int[])
. - testPermute() - Method in class org.apache.calcite.test.RelBuilderTest
- testPFPushDownProjectFilterAggregateGroup() - Method in class org.apache.calcite.test.ScannableTableTest
- testPFPushDownProjectFilterAggregateNested() - Method in class org.apache.calcite.test.ScannableTableTest
- testPFPushDownProjectFilterInAggregateNoGroup() - Method in class org.apache.calcite.test.ScannableTableTest
- testPFTableRefusesFilterCooperative() - Method in class org.apache.calcite.test.ScannableTableTest
-
A filter and project on a
ProjectableFilterableTable
. - testPFTableRefusesFilterSingleColumn() - Method in class org.apache.calcite.test.ScannableTableTest
- testPiFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPlan() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testPlan() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that parses, validates, converts and plans.
- testPlan2() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testPlan3() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testPlanNWayJoin() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that plans a query with a large number of joins.
- testPlanTransformTwice() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that calls
Planner.transform(int, org.apache.calcite.plan.RelTraitSet, org.apache.calcite.rel.RelNode)
twice. - testPlanTransformWithDiffRuleSetAndConvention() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that calls
Planner.transform(int, org.apache.calcite.plan.RelTraitSet, org.apache.calcite.rel.RelNode)
twice, with different rule sets, with different conventions. - testPlanTransformWithRuleNameConflicts() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that calls
Planner.transform(int, org.apache.calcite.plan.RelTraitSet, org.apache.calcite.rel.RelNode)
twice with rule name conflicts - testPlanWithExplicitTraitDefs() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that parses, validates, converts and plans.
- testPlusAny() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testPlusArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPlusArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPlusIntervalOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPlusOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPlusOperatorAny() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPoset() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testPosetBits() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testPosetBitsLarge() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testPosetBitsLarge2() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testPosetBitsRemoveParent() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testPosetTricky() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testPosition() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPosition() - Method in class org.apache.calcite.test.SqlValidatorTest
- testPositionFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPosixTimeZone() - Method in class org.apache.calcite.util.UtilTest
-
Tests the
Util.toPosix(TimeZone, boolean)
method. - testPostAggregationWithComplexColumns() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test post aggregation support with +, -, /, * operators
- testPowerFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPowerSet() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testPrecedence0() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPrecedence1() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPrecedence2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPrecedence2b() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPrecedence3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPrecedence4() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPrecedence5() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPrecedenceSetOps() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testPredecessorList() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
-
Unit test for
DepthFirstIterator
. - testPredicates() - Method in class org.apache.calcite.test.RelMetadataTest
-
Unit test for
RelMdPredicates.getPredicates(Join, RelMetadataQuery)
. - testPrefix() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Test case for a bug where a Java string 'Abc' compared to a char 'Ab' would be truncated to the char precision and falsely match.
- testPrefix() - Method in class org.apache.calcite.test.SqlValidatorTest
- testPrefixMinusOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPrefixMinusOperatorIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPrefixPlusOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPrefixPlusOperatorIntervals() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testPrepared() - Method in class org.apache.calcite.test.CsvTest
- testPrepared2() - Method in class org.apache.calcite.test.ScannableTableTest
- testPreparedOffsetFetch() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-2061] Dynamic parameters in offset/fetch.
- testPreparedStatement() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a
PreparedStatement
with parameters. - testPreparedStatementInsert() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Local PreparedStatement insert WITHOUT bind variables
- testPreparedStatementInsert2() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Local PreparedStatement insert WITH bind variables
- testPrePopulated() - Method in class org.apache.calcite.test.MaterializationTest
-
Test case for [CALCITE-761] Pre-populated materializations.
- testPreserveAlias() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testPreservePermutation() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testPreTests() - Method in class org.apache.calcite.test.RexTransformerTest
- testPrevClassifier() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testPreviousClearBit() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.previousClearBit(java.util.BitSet, int)
. - testPreviousClearBit() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
ImmutableBitSet.previousClearBit(int)
. - testPrimitiveArray() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testPrimitiveColumnsWithNullValues() - Method in class org.apache.calcite.test.JdbcTest
- testPrintEquals() - Method in class org.apache.calcite.util.UtilTest
- testPrintEquals2() - Method in class org.apache.calcite.util.UtilTest
- testPrintEquals3() - Method in class org.apache.calcite.util.UtilTest
- testPrintEquals4() - Method in class org.apache.calcite.util.UtilTest
- testPrintEquals5() - Method in class org.apache.calcite.util.UtilTest
- testPrintLimits() - Method in class org.apache.calcite.test.SqlLimitsTest
- testProcedureCall() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testProfileFoodmart() - Method in class org.apache.calcite.profile.ProfilerTest
-
Profiles a star-join query on the Foodmart schema using the breadth-first profiler.
- testProfileOneRow() - Method in class org.apache.calcite.profile.ProfilerTest
- testProfileScott() - Method in class org.apache.calcite.profile.ProfilerTest
- testProfileScott2() - Method in class org.apache.calcite.profile.ProfilerTest
-
As
ProfilerTest.testProfileScott()
, but prints only the most surprising distributions. - testProfileScott3() - Method in class org.apache.calcite.profile.ProfilerTest
-
As
ProfilerTest.testProfileScott2()
, but uses the breadth-first profiler. - testProfileScott4() - Method in class org.apache.calcite.profile.ProfilerTest
-
As
ProfilerTest.testProfileScott3()
, but uses the breadth-first profiler and deems everything uninteresting. - testProfileScott5() - Method in class org.apache.calcite.profile.ProfilerTest
-
As
ProfilerTest.testProfileScott3()
, but uses the breadth-first profiler. - testProfileTwoRows() - Method in class org.apache.calcite.profile.ProfilerTest
- testProfileZeroRows() - Method in class org.apache.calcite.profile.ProfilerTest
- testProject() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testProject() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testProject() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testProject() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests that projections of columns are pushed into the DruidQuery, and projections of expressions that Druid cannot handle (in this case, a literal 0) stay up.
- testProject() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Tests that projections of columns are pushed into the DruidQuery, and projections of expressions that Druid cannot handle (in this case, a literal 0) stay up.
- testProject() - Method in class org.apache.calcite.test.RelBuilderTest
- testProject2() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests each method that creates a scalar expression.
- testProjectableFilterableCooperative() - Method in class org.apache.calcite.test.ScannableTableTest
-
A filter on a
ProjectableFilterableTable
with two columns (cooperative). - testProjectableFilterableNonCooperative() - Method in class org.apache.calcite.test.ScannableTableTest
- testProjectableFilterableWithProjectAndFilter() - Method in class org.apache.calcite.test.ScannableTableTest
-
A filter on a
ProjectableFilterableTable
with two columns, and a project in the query. - testProjectableFilterableWithProjectFilterNonCooperative() - Method in class org.apache.calcite.test.ScannableTableTest
-
A filter on a
ProjectableFilterableTable
with two columns, and a project in the query (NonCooperative). - testProjectAlias() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testProjectConstant() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testProjectCorrelateTranspose() - Method in class org.apache.calcite.test.RelOptRulesTest
- testProjectCorrelateTransposeDynamic() - Method in class org.apache.calcite.test.RelOptRulesTest
- testProjectCorrelateTransposeRuleAntiCorrelate() - Method in class org.apache.calcite.test.RelOptRulesTest
- testProjectCorrelateTransposeRuleLeftCorrelate() - Method in class org.apache.calcite.test.RelOptRulesTest
- testProjectCorrelateTransposeRuleSemiCorrelate() - Method in class org.apache.calcite.test.RelOptRulesTest
- testProjectCorrelateTransposeWithExprCond() - Method in class org.apache.calcite.test.RelOptRulesTest
- testProjectIdentity() - Method in class org.apache.calcite.test.RelBuilderTest
- testProjectIdentityWithFieldsRename() - Method in class org.apache.calcite.test.RelBuilderTest
- testProjectIdentityWithFieldsRenameFilter() - Method in class org.apache.calcite.test.RelBuilderTest
-
Variation on
RelBuilderTest.testProjectIdentityWithFieldsRename()
: don't use a table alias, and make sure the field names propagate through a filter. - testProjectionsAndWhereGreatThan() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testProjectJoin() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests that a projection retains field names after a join.
- testProjectLeadingEdge() - Method in class org.apache.calcite.test.RelBuilderTest
- testProjectPermutation() - Method in class org.apache.calcite.util.PermutationTestCase
- testProjectProject() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests that a projection after a projection.
- testProjectSameColumnMultipleTimes() - Method in class org.apache.calcite.test.DruidAdapterIT
- testProjectSameColumnMultipleTimes() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testProjectSameMetricsColumnMultipleTimes() - Method in class org.apache.calcite.test.DruidAdapterIT
- testProjectSameMetricsColumnMultipleTimes() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testProjectToWindowRuleForMultipleWindows() - Method in class org.apache.calcite.test.RelOptRulesTest
- testProjectWindowTransposeRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testProjectWindowTransposeRuleWithConstants() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPs() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testPsDistinct() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testPullAggregateThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullAggregateThroughUnion2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantIntoFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantIntoJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantIntoJoin2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantIntoProject() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughAggregateAllConst() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughAggregateAllLiterals() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughAggregateConstGroupBy() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughAggregatePermuted() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughAggregatePermutedConstFirst() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughAggregatePermutedConstGroupBy() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughAggregateSimpleNonNullable() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughConstLast() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughUnion2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullConstantThroughUnion3() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullFactors() - Method in class org.apache.calcite.test.RexProgramTest
-
Unit test for
RexUtil.pullFactors(org.apache.calcite.rex.RexBuilder, org.apache.calcite.rex.RexNode)
. - testPullFilterThroughAggregate() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullFilterThroughAggregateGroupingSets() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullNull() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPullUpPredicatesForExprsItr() - Method in class org.apache.calcite.test.RelMetadataTest
- testPullUpPredicatesFromAggregation() - Method in class org.apache.calcite.test.RelMetadataTest
-
Unit test for
RelMdPredicates.getPredicates(Aggregate, RelMetadataQuery)
. - testPullUpPredicatesOnConstant() - Method in class org.apache.calcite.test.RelMetadataTest
- testPullUpPredicatesOnNullableConstant() - Method in class org.apache.calcite.test.RelMetadataTest
- testPushAggregateFunctionsThroughJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Push a variety of aggregate functions.
- testPushAggregateOnTime() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushAggregateOnTime() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushAggregateOnTimeWithExtractDay() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushAggregateOnTimeWithExtractDay() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushAggregateOnTimeWithExtractHourOfDay() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushAggregateOnTimeWithExtractHourOfDay() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushAggregateOnTimeWithExtractMonth() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushAggregateOnTimeWithExtractMonth() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushAggregateOnTimeWithExtractWithOutRenaming() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushAggregateOnTimeWithExtractWithOutRenaming() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushAggregateOnTimeWithExtractYear() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushAggregateOnTimeWithExtractYear() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushAggregateOnTimeWithExtractYearMonthDay() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushAggregateOnTimeWithExtractYearMonthDay() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushAggregateOnTimeWithExtractYearMonthDayWithOutRenaming() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushAggregateOnTimeWithExtractYearMonthDayWithOutRenaming() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushAggregateSumNoGroup() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Push count(*) through join, no GROUP BY.
- testPushAggregateSumThroughJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
-
SUM is the easiest aggregate function to split.
- testPushAggregateSumThroughJoinAfterAggregateReduce() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAggregateSumWithoutGroupKeyThroughJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAggregateThroughJoin1() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAggregateThroughJoin2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAggregateThroughJoin3() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAggregateThroughJoin4() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAggregateThroughJoin5() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAggregateThroughJoin6() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAggregateThroughJoinDistinct() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Push a aggregate functions into a relation that is unique on the join key.
- testPushAggregateThroughJoinWithUniqueInput() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAvgGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushAvgThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushCast() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test case for [CALCITE-1770] Druid adapter: CAST(NULL AS ...) gives NPE.
- testPushCast() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test case for [CALCITE-1770] Druid adapter: CAST(NULL AS ...) gives NPE.
- testPushCastNumeric() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushCastNumeric() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushComplexFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushComplexFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushCountFilterThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushCountNullableGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushCountNullableThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushCountStarGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushCountStarThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushDownProject() - Method in class org.apache.calcite.test.CsvTest
- testPushDownProject2() - Method in class org.apache.calcite.test.CsvTest
- testPushDownProjectAggregate() - Method in class org.apache.calcite.test.CsvTest
- testPushDownProjectAggregateNested() - Method in class org.apache.calcite.test.CsvTest
- testPushDownProjectAggregateWithFilter() - Method in class org.apache.calcite.test.CsvTest
- testPushDownProjectDumb() - Method in class org.apache.calcite.test.CsvTest
- testPushEqualsCastDimension() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushEqualsCastDimension() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushFieldEqualsLiteral() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushFieldEqualsLiteral() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushFilterPastAgg() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushFilterPastAggFour() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushFilterPastAggThree() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-799] Incorrect result for
HAVING count(*) > 1
. - testPushFilterPastAggTwo() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushFilterPastAggWithGroupingSets1() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushFilterPastAggWithGroupingSets2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushFilterPastProject() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushFilterThroughSemiJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-438] Push predicates through SemiJoin.
- testPushFilterWithRank() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushFilterWithRankExpr() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushJoinCondDownToProject() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushJoinThroughUnionOnLeft() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushJoinThroughUnionOnRight() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushMaxNullableGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushMaxNullableThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushMinGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushMinThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushNotEqualsCastDimension() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushNotEqualsCastDimension() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushOfFilterExtractionOnDayAndMonth() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushOfFilterExtractionOnDayAndMonth() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushOfFilterExtractionOnDayAndMonthAndYear() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushOfFilterExtractionOnDayAndMonthAndYear() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushofOrderByMetricWithYearMonthExtract() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushofOrderByMetricWithYearMonthExtract() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushOfOrderByWithMonthExtract() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushOfOrderByWithMonthExtract() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushofOrderByYearWithYearMonthExtract() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushofOrderByYearWithYearMonthExtract() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushOfSimpleColumnAPlusColumnB() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushOfSimpleColumnAPlusColumnB() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushOfSimpleMathOps() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushOfSimpleMathOps() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushProjectPastFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastFilter2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastFullJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastFullJoinStrong() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastInnerJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastInnerJoinStrong() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastLeftJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastLeftJoinSwap() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastLeftJoinSwapStrong() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastRightJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastRightJoinStrong() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastRightJoinSwap() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastRightJoinSwapStrong() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushProjectPastSetOp() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSemiJoinPastFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSemiJoinPastJoinRuleLeft() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSemiJoinPastJoinRuleRight() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSemiJoinPastProject() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSimpleGroupBy() - Method in class org.apache.calcite.test.DruidAdapterIT
- testPushSimpleGroupBy() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testPushSumConstantGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSumConstantThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSumCountStarGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSumCountStarThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSumNullableGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSumNullableNOGBYThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSumNullableThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSumNullConstantGroupingSetsThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPushSumNullConstantThroughUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testPut() - Method in class org.apache.calcite.linq4j.test.LookupImplTest
- testQuarter() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testQuery01() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testQuery01() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery02() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery02Conversion() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery03() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery04() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery05() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery06() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery07() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery08() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery09() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery10() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery11() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery12() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery13() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery14() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery15() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery16() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery17() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery17Plan() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testQuery18() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery19() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery20() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery21() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery22() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testQuery27() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testQuery27Builder() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
-
Builder query 27 using
RelBuilder
. - testQuery58() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testQuery72() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testQuery72Plan() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testQuery95() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testQueryInFrom() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testQueryInIllegalContext() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
In modern SQL, a query can occur almost everywhere that an expression can.
- testQueryOnStar() - Method in class org.apache.calcite.test.MaterializationTest
-
Simpler than
MaterializationTest.testFilterGroupQueryOnStar()
, tests a query on a materialization that is just a join. - testQueryProvider() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Test that uses a JDBC connection as a linq4j
QueryProvider
. - testQueryProviderSingleColumn() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testQueryWithAggregateGroupingSets() - Method in class org.apache.calcite.test.RelMdColumnOriginsTest
- testQueryWithExtractsTimes() - Method in class org.apache.calcite.test.DruidAdapterIT
- testQueryWithParameter() - Method in class org.apache.calcite.test.JdbcTest
- testQuotedCaseSensitiveSubQueryMySql() - Method in class org.apache.calcite.test.JdbcTest
- testQuotedCaseSensitiveSubQuerySqlServer() - Method in class org.apache.calcite.test.JdbcTest
- testQuotedFunction() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests that you can't quote the names of builtin functions.
- testQuotedFunction() - Method in class org.apache.calcite.test.SqlValidatorTest
- testQuotesInString() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testQuotientList() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Util.quotientList(java.util.List, int, int)
andUtil.pairs(List)
. - testRadiansFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRandFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRandIntegerFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRandIntegerSeedFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRandom() - Method in class org.apache.calcite.util.ChunkListTest
-
Unit test for
ChunkList
that applies random operations. - testRandSeedFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRange() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
BitSets.range(int, int)
. - testRangeTable(String) - Method in class org.apache.calcite.test.JdbcTest
- testRank() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testRankFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRead() - Method in class org.apache.calcite.test.ModelTest
-
Reads a simple schema from a string into objects.
- testReadBadMultiLineSql() - Method in class org.apache.calcite.test.ModelTest
-
Tests a model with bad multi-line SQL.
- testReader() - Method in class org.apache.calcite.plan.RelWriterTest
-
Unit test for
RelJsonReader
. - testReadLattice() - Method in class org.apache.calcite.test.ModelTest
-
Tests a model containing a lattice and some views.
- testReadme() - Method in class org.apache.calcite.test.CsvTest
- testReadme() - Method in class org.apache.calcite.test.JdbcTest
-
The example in the README.
- testReal() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testRecordType() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRecordTypeElided() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRecursiveArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT
- testRecursiveArithmeticOperation() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testReduceAverage() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceCase() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-1439] Handling errors during constant reduction.
- testReduceCaseNullabilityChange() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceCastAndConsts() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceCasts() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceCastsNullable() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceCastTimeUnchanged() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests that a cast from a TIME to a TIMESTAMP is not reduced.
- testReduceCompositeCountNotNullable() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that
count(deptno, commission, commission + 1)
is reduced tocount(commission, commission + 1)
, because deptno is NOT NULL. - testReduceCompositeInSubQuery() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstants() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstants2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstants3() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsCalc() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsCaseEquals() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsCaseEquals2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsCaseEquals3() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsDup() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsDup2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsDynamicFunction() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Checks that constant reducer duplicates calls to dynamic functions, if appropriate.
- testReduceConstantsEliminatesFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsIsNotNull() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsIsNull() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsNegated() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsNegatedInverted() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsNonDeterministicFunction() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsNull() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsNullEqualsOne() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsProjectNullable() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceConstantsRequiresExecutor() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceCountNotNullable() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that count(deptno) is reduced to count().
- testReduceExpressionsNot() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceNestedCaseWhen() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceNot() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceNullableCase() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceNullableCase2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceNullableToNotNull() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case that reduces a nullable expression to a NOT NULL literal that is cast to nullable.
- testReduceNullableToNotNull2() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case that reduces a nullable expression to a NOT NULL literal.
- testReduceOrCaseWhen() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceValuesNull() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceValuesToEmpty() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceValuesUnderFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceValuesUnderProject() - Method in class org.apache.calcite.test.RelOptRulesTest
- testReduceValuesUnderProjectFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testRef() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testReferDynamicStarInSelectOB() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for Dynamic Table / Dynamic Star support [CALCITE-1150]
- testReferDynamicStarInSelectWhereGB() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for Dynamic Table / Dynamic Star support [CALCITE-1150]
- testReflectiveSchemaInUnnamedPackage() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testRegion() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- testRegrSxxFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRegrSyyFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRelative() - Method in class org.apache.calcite.util.SourceTest
- testRelBuilderExample() - Method in class org.apache.calcite.util.UtilTest
- testRelBuilderToString() - Method in class org.apache.calcite.test.RelBuilderTest
- TestRelCollationImpl(ImmutableList<RelFieldCollation>) - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationImpl
- TestRelCollationTraitDef() - Constructor for class org.apache.calcite.plan.volcano.CollationConversionTest.TestRelCollationTraitDef
- testRelDistributionSatisfy() - Method in class org.apache.calcite.rel.RelDistributionTest
- testRemoteCatalogs() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemoteColumns() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemoteExecute() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemoteExecuteMaxRow() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemoteExecuteQuery() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemoteExecuteQuery2() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Same query as
CalciteRemoteDriverTest.testRemoteExecuteQuery()
, run without the test infrastructure. - testRemotePreparedStatementFetch() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemotePreparedStatementInsert() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Remote PreparedStatement insert WITHOUT bind variables
- testRemotePreparedStatementInsert2() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Remote PreparedStatement insert WITH bind variables
- testRemotePrepareExecute() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Test case for [CALCITE-661] Remote fetch in Calcite JDBC driver.
- testRemoteSchemas() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemoteStatementExecute() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Checks
Statement.execute(java.lang.String)
on a query over a remote connection. - testRemoteStatementFetch() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemoteTableTypes() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemoteTypeInfo() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testRemovalOfNullabilityWideningCast() - Method in class org.apache.calcite.test.RexProgramTest
- testRemoveAllVertices() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
-
Unit test for
DefaultDirectedGraph.removeAllVertices(java.util.Collection)
. - testRemoveSemiJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testRemoveSemiJoinRight() - Method in class org.apache.calcite.test.RelOptRulesTest
- testRemoveSemiJoinRightWithFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testRemoveSemiJoinWithFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testRemoveSingleGood() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
-
This always worked (in contrast to testRemoveSingleReformed) because it uses a completely-physical pattern (requiring GoodSingleRule to fire first).
- testRemoveSingleReformed() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
-
Previously, this didn't work because ReformedRemoveSingleRule uses a pattern which spans calling conventions.
- testRename() - Method in class org.apache.calcite.test.RelBuilderTest
- testRenameValues() - Method in class org.apache.calcite.test.RelBuilderTest
- testRenameVariablesWithEmptyInitializer() - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest
- testRenameVariablesWithInitializer() - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest
- testRepeated() - Method in class org.apache.calcite.runtime.BinarySearchTest
- testRepeatedPrefixPostfix() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testReplace() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testReplaceCommonSubexpression() - Method in class org.apache.calcite.test.HepPlannerTest
- testReplaceFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testReservedWords() - Method in class org.apache.calcite.test.BabelParserTest
- testResources() - Method in class org.apache.calcite.util.UtilTest
- testResultSetMetaData() - Method in class org.apache.calcite.test.JdbcTest
-
Tests driver's implementation of
DatabaseMetaData.getColumns(java.lang.String, java.lang.String, java.lang.String, java.lang.String)
, and also [CALCITE-1222] DatabaseMetaData.getColumnLabel returns null when query has ORDER BY, - testReturn() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testReturnDate() - Method in class org.apache.calcite.test.UdfTest
- testReturnDate2() - Method in class org.apache.calcite.test.UdfTest
- testReuseExpressionsFromUpperLevel() - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest
- testReuseExpressionWhenNullChecking() - Method in class org.apache.calcite.test.JdbcTest
- testReuseExpressionWhenNullChecking2() - Method in class org.apache.calcite.test.JdbcTest
- testReuseExpressionWhenNullChecking3() - Method in class org.apache.calcite.test.JdbcTest
- testReuseExpressionWhenNullChecking4() - Method in class org.apache.calcite.test.JdbcTest
- testReuseExpressionWhenNullChecking5() - Method in class org.apache.calcite.test.JdbcTest
- testReverse() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testReverseSolidus() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testRewriteWithColumnReferenceExpansion() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRewriteWithColumnReferenceExpansionAndFromAlias() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRewriteWithIdentifierExpansion() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRewriteWithLimitWithDynamicParameters() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRewriteWithLimitWithoutOrderBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRewriteWithOffsetWithoutOrderBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRewriteWithoutIdentifierExpansion() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRewriteWithUnionFetchWithoutOrderBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRexNodeLiteral() - Method in class org.apache.calcite.test.SqlOperatorBindingTest
-
Tests
RexUtil.isLiteral(RexNode, boolean)
, which was added to enhance Calcite's public API [CALCITE-1219] Add a method to SqlOperatorBinding to determine whether operand is a literal. - testRightAssociative() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testRightJoin() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testRightJoin() - Method in class org.apache.calcite.test.JdbcTest
- testRightOuterJoinSimplificationToInner() - Method in class org.apache.calcite.test.RelOptRulesTest
- testRolledUpColumnInHaving() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRolledUpColumnInWhere() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRollup() - Method in class org.apache.calcite.test.JdbcTest
- testRollup() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testRollup() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRollupBitSets() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Unit test for
SqlValidatorUtil.rollup(java.util.List<org.apache.calcite.util.ImmutableBitSet>)
. - testRollUpInGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRollUpInJoin() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRollUpInOrderBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRollUpInWindow() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRollupSimple() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testRollupTuples() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testRoundFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRow() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testRow() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRow() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRowComparison() - Method in class org.apache.calcite.test.JdbcTest
- testRowCountAggregate() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountAggregateEmptyKey() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountAggregateEmptyKeyOnEmptyTable() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountAggregateGroupingSets() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountAggregateGroupingSetsOneEmpty() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountCartesian() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountDept() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountEmp() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountFilterAggregateEmptyKey() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountFilterFalse() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountFilterOnFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountIntersectOnFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountJoin() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountJoinEmptyEmpty() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountJoinEmptyFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountJoinFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountJoinFiniteEmpty() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountLeftJoinEmptyFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountMinusOnFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountRightJoinEmptyFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountSort() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountSortHighLimit() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountSortHighOffset() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountSortHighOffsetLimit() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountSortLimit() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountSortLimit0() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountSortLimitOffset() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountSortLimitOffsetOnFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountUnionOnFinite() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowCountValues() - Method in class org.apache.calcite.test.RelMetadataTest
- testRowid() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testRowNumberFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRowtype() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRowWitDot() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testRowWithInvalidDotOperation() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRowWitValidDot() - Method in class org.apache.calcite.test.SqlValidatorTest
- testRtrim() - Method in class org.apache.calcite.test.SqlFunctionsTest
-
Test for
SqlFunctions.rtrim(java.lang.String)
. - testRtrimFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testRuleApplyCount() - Method in class org.apache.calcite.test.HepPlannerTest
- testRuleClass() - Method in class org.apache.calcite.test.HepPlannerTest
- testRuleDescription() - Method in class org.apache.calcite.test.HepPlannerTest
- testRuleGuessDescription() - Method in class org.apache.calcite.plan.RelOptUtilTest
-
Tests the rules for how we name rules.
- testRuleMatchAfterConversion() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
- testRun() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests
RelRunner
for a table scan + filter query. - testRunValues() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests
RelRunner
for a VALUES query. - testSalesDepts() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads the DEPTS table.
- testSalesEmps() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads the EMPS table.
- testSample() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testSample() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSample() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSampleBernoulli() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSampleBernoulliQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSampleQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSampleSystem() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSampleSystemQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSatisfiable() - Method in class org.apache.calcite.test.MaterializationTest
-
Unit test for logic functions
SubstitutionVisitor.mayBeSatisfiable(org.apache.calcite.rex.RexNode)
andRexUtil.simplify(org.apache.calcite.rex.RexBuilder, org.apache.calcite.rex.RexNode)
. - testScalarQueryInSelect() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testScalarQueryInWhere() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testScalars() - Method in class org.apache.calcite.test.SqlValidatorTest
- testScalarsFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testScalarSubQuery() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testScalarSubQuery() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a correlated scalar sub-query in the SELECT clause.
- testScalarSubQuery() - Method in class org.apache.calcite.test.SqlValidatorTest
- testScalarSubQueryInCase() - Method in class org.apache.calcite.test.JdbcTest
- testScalarSubQueryInCase2() - Method in class org.apache.calcite.test.JdbcTest
- testScalarSubQueryUncorrelated() - Method in class org.apache.calcite.test.JdbcTest
- testScan() - Method in class org.apache.calcite.test.MaterializationTest
- testScan() - Method in class org.apache.calcite.test.PigletTest
- testScan() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testScan() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanAndFilter() - Method in class org.apache.calcite.test.PigAdapterTest
- testScanAndFilter() - Method in class org.apache.calcite.test.PigRelBuilderStyleTest
- testScanFilterAndFalse() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanFilterAndTrue() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanFilterDuplicateAnd() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanFilterEquals() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanFilterOr() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanFilterOr2() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanFilterTriviallyFalse() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanFilterTrue() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanInvalidQualifiedTable() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanInvalidSchema() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanInvalidTable() - Method in class org.apache.calcite.test.RelBuilderTest
- testScannableTableFunction() - Method in class org.apache.calcite.test.TableFunctionTest
-
Tests a table function that implements
ScannableTable
and returns a single column. - testScannableTableFunctionWithNamedParameters() - Method in class org.apache.calcite.test.TableFunctionTest
-
As
TableFunctionTest.testScannableTableFunction()
but with named parameters. - testScanQualifiedTable() - Method in class org.apache.calcite.test.RelBuilderTest
- testScanValidTableWrongCase() - Method in class org.apache.calcite.test.RelBuilderTest
- TestSchema() - Constructor for class org.apache.calcite.test.ExceptionMessageTest.TestSchema
- testSchemaCaching() - Method in class org.apache.calcite.test.JdbcTest
- testSchemaConsistency() - Method in class org.apache.calcite.test.MultiJdbcSchemaJoinTest
- testSchemaFieldHasBadType() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests that a schema with a field whose type cannot be recognized throws an informative exception.
- testSchemaPath() - Method in class org.apache.calcite.tools.FrameworksTest
-
Test for
Path
. - testSchemasLocal() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- testSchemaTableColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSchemaTableColumnInGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSchemaTableStar() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSchemaTableStar() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSchemaWithoutName() - Method in class org.apache.calcite.test.ModelTest
- testScientificNotation() - Method in class org.apache.calcite.util.UtilTest
- testSecond() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSelect() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSelect() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSelect() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSelect() - Method in class org.apache.calcite.test.BabelParserTest
- testSelect() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testSelect() - Method in class org.apache.calcite.test.CsvTest
-
Reads from a table.
- testSelect() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Runs a simple query that reads from a table in an in-memory schema.
- testSelect() - Method in class org.apache.calcite.test.SplunkAdapterTest
-
Reads from a table.
- testSelectAggregateOnRolledUpColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectAll() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectCount() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectCount() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSelectCountStarPlusOtherAggs() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectDistinct() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectDistinct() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectDistinct() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSelectDistinct() - Method in class org.apache.calcite.test.JdbcTest
- testSelectDistinct() - Method in class org.apache.calcite.test.SparkAdapterTest
- testSelectDistinct() - Method in class org.apache.calcite.test.SplunkAdapterTest
- testSelectDistinct() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectDistinct() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectDistinctComposite() - Method in class org.apache.calcite.test.JdbcTest
-
Select distinct on composite key, one column of which is boolean to boot.
- testSelectDistinctDup() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Tests that if the clause of SELECT DISTINCT contains duplicate expressions, they are only aggregated once.
- testSelectDistinctGroup() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectDistinctStar() - Method in class org.apache.calcite.test.JdbcTest
- testSelectDistinctWiki() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests a query against the
DruidAdapterIT.WIKI
data set. - testSelectDistinctWikiNoColumns() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectDistinctWikiNoTables() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectDistinctWithoutFrom() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectDynamicStarOrderBy() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectExtendedColumnCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectExtendedColumnDuplicate() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectExtendedColumnFailCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectExtractMonth() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectExtractMonth() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSelectFailCaseSensitivity() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectFloorOnTimeWithFilterOnFloorOnTime() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectFloorOnTimeWithFilterOnFloorOnTime() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSelectFromBareExplicitTableFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectFromDynamicTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-1150] Dynamic Table / Dynamic Star support
- testSelectFromExplicitTable() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectGroupBySum() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectGroupBySum() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSelectIsNotDdl() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectivityAgg() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivityAggCached() - Method in class org.apache.calcite.test.RelMetadataTest
-
Checks that we can cache a metadata request that includes a null argument.
- testSelectivityAndFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivityComparisonFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivityIsNotNullFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivityIsNotNullFilterOnNotNullColumn() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivityJoin() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivityOrFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivityRedundantFilter() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivitySort() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectivityUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testSelectList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectList() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSelectList3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectList4() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectListExtraIndentFlag() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testSelectListItemsOnSeparateLines() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testSelectLocItem() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testSelectLongMultiplyInteger() - Method in class org.apache.calcite.test.CsvTest
- testSelectMany() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSelectManyWithIndexableSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSelectManyWithIndexableSelectorAndResultSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSelectManyWithResultSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSelectModifiableViewConstraint() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectNonBuiltInColumn() - Method in class org.apache.calcite.test.SplunkAdapterTest
-
"status" is not a built-in column but we know it has some values in the test data.
- testSelectNOT() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests NOT for nullable columns
- testSelectorEqualityComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSelectOverDistinct() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-476] DISTINCT flag in windowed aggregates.
- testSelectQueryComplex() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithAscDescOrderByClause() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithFetchOffsetClause() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithGroup() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithGroupBy() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithGroupByAndProjectList() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithGroupByAndProjectList1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithGroupByEmpty() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithGroupByEmpty2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithGroupByHaving() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithGroupByHaving2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
Test case for [CALCITE-1665] Aggregates and having cannot be combined.
- testSelectQueryWithGroupByHaving3() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
Test case for [CALCITE-1665] Aggregates and having cannot be combined.
- testSelectQueryWithLimitClause() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithLimitClauseWithoutOrder() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithLimitOffsetClause() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithMinAggregateFunction() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithMinAggregateFunction1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithMultipleAggregateFunction() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithMultipleAggregateFunction1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithOrderByClause() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithOrderByClause1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithParameters() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithSumAggregateFunction() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithTwoOrderByClause() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithWhereClauseOfBasicOperators() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectQueryWithWhereClauseOfLessThan() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSelectRolledUpColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectSingleProject() - Method in class org.apache.calcite.test.CsvTest
- testSelectSingleProjectGz() - Method in class org.apache.calcite.test.CsvTest
- testSelectStarFromDynamicTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for Dynamic Table / Dynamic Star support [CALCITE-1150]
- testSelectStarWithRollUp() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to make sure that SELECT * doesn't fail, and that the rolled up column is not requested in the JSON query.
- testSelectStream() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectStreamDistinct() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectStreamPartitionDistinct() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
As
SqlToRelConverterTest.testSelectOverDistinct()
but for streaming queries. - testSelectTimestampColumnNoTables1() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectTimestampColumnNoTables2() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectTimestampColumnNoTables3() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectTimestampColumnNoTables4() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSelectView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectViewExtendedColumnCaseSensitiveCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectViewExtendedColumnCaseSensitiveExtendedCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectViewExtendedColumnCaseSensitiveUnderlyingCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectViewExtendedColumnCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectViewExtendedColumnCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectViewExtendedColumnExtendedCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectViewExtendedColumnExtendedCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectViewExtendedColumnFailCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectViewExtendedColumnFailExtendedCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectViewExtendedColumnFailUnderlyingCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectViewExtendedColumnUnderlyingCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectViewExtendedColumnUnderlyingCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectViewFailExcludedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectWhere() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testSelectWithFieldAccessOnFirstLevelRecordType() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testSelectWithFieldAccessOnFirstLevelRecordTypeArray() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testSelectWithFieldAccessOnSecondLevelRecordType() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testSelectWithFieldAccessOnSecondLevelRecordTypeArray() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testSelectWithNestedPdx() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSelectWithNestedPdx2() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSelectWithNestedPdxFieldAccess() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSelectWithNullFieldValue() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSelectWithoutFrom() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectWithoutFrom() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-1120] Support SELECT without FROM.
- testSelectWithoutFrom() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSelectWithoutFrom() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSelectWithoutFrom2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectWithoutFromGroupByFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectWithoutFromHavingFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelectWithoutFromWhereFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSelfJoin() - Method in class org.apache.calcite.test.JdbcTest
-
Unit test for self-join.
- testSelfJoinCount() - Method in class org.apache.calcite.test.JdbcTest
-
Limit implemented using
ExtendedEnumerable.take(int)
. - testSelfJoinDifferentColumns() - Method in class org.apache.calcite.test.JdbcTest
-
Self-join on different columns, select a different column, and sort and limit on yet another column.
- testSelfPopulatingList() - Method in class org.apache.calcite.rex.RexExecutorTest
-
Test case for [CALCITE-1009] SelfPopulatingList is not thread-safe.
- testSelfPopulatingList30() - Method in class org.apache.calcite.rex.RexExecutorTest
- testSelfReferentialView() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-1900] Improve error message for cyclic views.
- testSelfReferentialView2() - Method in class org.apache.calcite.test.JdbcTest
- testSemanticError() - Method in class org.apache.calcite.test.ExceptionMessageTest
- testSemi() - Method in class org.apache.calcite.linq4j.test.CorrelateJoinTest
- testSemiJoin() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testSemiJoinReduceConstants() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSemiJoinRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSemiJoinRuleExists() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSemiJoinRuleFull() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Similar to
RelOptRulesTest.testSemiJoinRuleRight()
but FULL. - testSemiJoinRuleLeft() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Similar to
RelOptRulesTest.testSemiJoinRule()
but LEFT. - testSemiJoinRuleRight() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSemiJoinTrim() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSemiStrict() - Method in class org.apache.calcite.test.UdfTest
-
Tests that we generate the appropriate checks for a "semi-strict" function.
- testSendSource() - Method in class org.apache.calcite.linq4j.test.PrimitiveTest
-
Test for
Primitive.send(org.apache.calcite.linq4j.tree.Primitive.Source, org.apache.calcite.linq4j.tree.Primitive.Sink)
. - testSequence() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSequenceEqual() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSequenceEqualWithComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSequenceEqualWithComparerWithoutCollection() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSequenceEqualWithoutCollection() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSessionTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSessionUserFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSet() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testSet2() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testSetMaxRows() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that
Statement.setMaxRows(int)
is honored. - testSetMinus() - Method in class org.apache.calcite.sql.parser.SqlParserTest
-
Tests MINUS, which is equivalent to EXCEPT but only supported in some conformance levels (e.g.
- testSetup() - Method in class org.apache.calcite.adapter.druid.DruidQueryFilterTest
- testSeveralParametersShouldWorkWithCalcite() - Method in class org.apache.calcite.chinook.RemotePreparedStatementParametersTest
- testSharedSnowflake() - Method in class org.apache.calcite.materialize.LatticeSuggesterTest
- testShift() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testSignFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSimilarToOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSimlifyMinus() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimlifySubQueryMultipleFrom() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimlifySubQueryStar() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimple() - Method in class org.apache.calcite.runtime.BinarySearchTest
- testSimple() - Method in class org.apache.calcite.test.JdbcTest
-
Tests some queries that have expedited processing because connection pools like to use them to check whether the connection is alive.
- testSimple() - Method in class org.apache.calcite.test.ScannableTableTest
-
A table with one column.
- testSimple2() - Method in class org.apache.calcite.test.ScannableTableTest
-
A table with two columns.
- testSimpleAnd() - Method in class org.apache.calcite.test.RexTransformerTest
- testSimpleBetween() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleBetweenCornerCases() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleBoolean() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleCalciteSchema() - Method in class org.apache.calcite.test.JdbcTest
- testSimpleCalciteSchemaWithView() - Method in class org.apache.calcite.test.JdbcTest
- testSimpleChar() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleDate() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleDec() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleDynamicVars() - Method in class org.apache.calcite.test.RexProgramTest
- testSimpleEq() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleEquals() - Method in class org.apache.calcite.test.RexTransformerTest
- testSimpleGreaterCond() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleGreaterEquals() - Method in class org.apache.calcite.test.RexTransformerTest
- testSimpleGreaterThan() - Method in class org.apache.calcite.test.RexTransformerTest
- testSimpleIdentifier() - Method in class org.apache.calcite.test.RexTransformerTest
- testSimpleIn() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSimpleIn() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a simple IN query implemented as a semi-join.
- testSimpleJoin() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSimpleJoinConditionWithIsNullOperators() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSimpleJoinUsing() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSimpleLessEqual() - Method in class org.apache.calcite.test.RexTransformerTest
- testSimpleLesserCond() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleLessThan() - Method in class org.apache.calcite.test.RexTransformerTest
- testSimpleLong() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleNotEquals() - Method in class org.apache.calcite.test.RexTransformerTest
- testSimpleParser() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimpleParserQuotedIdDefault() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimpleParserQuotedIdImpl() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimpleParserQuotedIdJava() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimpleParserQuotedIdMySql() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimpleParserQuotedIdSqlServer() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimpleParserTokenizer() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimpleSelectQueryFromProductTable() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSimpleSelectStarFromProductTable() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSimpleShort() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleString() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleStringParameterShouldWorkWithCalcite() - Method in class org.apache.calcite.chinook.RemotePreparedStatementParametersTest
- testSimpleTime() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimpleTimeStamp() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
- testSimplify() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyAnd() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyAnd3() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyAndNot() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyAndPush() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseAndNotSimplicationIsInAction() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseBranchesCollapse() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseBranchesCollapse2() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseBranchRemovalStrengthensType() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseCasting() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseCompaction() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseCompaction2() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseCompactionDiv() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseDiv1() - Method in class org.apache.calcite.test.RexProgramTest
-
Tests a CASE value branch that contains division.
- testSimplifyCaseDiv2() - Method in class org.apache.calcite.test.RexProgramTest
-
Tests a CASE condition that contains division,
- testSimplifyCaseNotNullableBoolean() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseNullableBoolean() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCaseNullableVarChar() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCastLiteral() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCastLiteral2() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCastLiteral3() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCastMatchNullability() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
-
Test case for [CALCITE-2041] When simplifying a nullable expression, allow the result to change type to NOT NULL and match nullability.
- testSimplifyCeilFloor() - Method in class org.apache.calcite.test.RexImplicationCheckerTest
-
Test case for simplifier of ceil/floor.
- testSimplifyCoalesce() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyCondition() - Method in class org.apache.calcite.test.RexProgramTest
-
Tests how the condition is simplified.
- testSimplifyCondition2() - Method in class org.apache.calcite.test.RexProgramTest
-
Tests how the condition is simplified.
- testSimplifyDynamicParam() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyFalse() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyFilter() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSimplifyFilter() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyIsNotNull() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyLiterals() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyNot() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyNotAnd() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyOrNot() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyOrTerms() - Method in class org.apache.calcite.test.RexProgramTest
- testSimplifyStarAlias() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSimplifyUnknown() - Method in class org.apache.calcite.test.RexProgramTest
- testSinFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSingle() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSingle() - Method in class org.apache.calcite.runtime.BinarySearchTest
- testSingleAverageFunction() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSingleAverageFunction() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSingleMaterializationMultiUsage() - Method in class org.apache.calcite.test.MaterializationTest
- testSingleNoAlias() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSingleOrDefault() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSingleOrDefaultPredicate1() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSinglePredicate1() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- TestSingleRel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.plan.volcano.PlannerTests.TestSingleRel
- TestSingleRel(RelOptCluster, RelTraitSet, RelNode) - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.TestSingleRel
- testSingletonEnumerable() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSingletonEnumerator() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSingletonGroupingSet() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSingletonNullEnumerator() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSkip() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testSkipEmptyBuckets() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSkipReduceConstantsCaseEquals() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSmallint() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testSome() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSome() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSome() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSomeValueList() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSort() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testSort() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testSort() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testSort() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSort() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSort() - Method in class org.apache.calcite.test.RelBuilderTest
- testSortBy2Columns() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSortByExpression() - Method in class org.apache.calcite.test.RelBuilderTest
- testSortDuplicate() - Method in class org.apache.calcite.test.RelBuilderTest
- testSortedSet() - Method in class org.apache.calcite.util.UtilTest
-
Tests that sorted sets behave the way we expect.
- testSortExchange() - Method in class org.apache.calcite.test.RelBuilderTest
- testSortExpThenLimit() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests that a sort on an expression followed by a limit gives the same effect as calling sortLimit.
- testSortJoinTranspose1() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortJoinTranspose2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortJoinTranspose3() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortJoinTranspose4() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortJoinTranspose5() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortJoinTranspose6() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortJoinTranspose7() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortLimit() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testSortLimit() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testSortLimit() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testSortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSortLimit() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSortLimit() - Method in class org.apache.calcite.test.RelBuilderTest
- testSortLimit0() - Method in class org.apache.calcite.test.RelBuilderTest
- testSortOffset() - Method in class org.apache.calcite.test.CassandraAdapterTest
- testSortOverProjectSort() - Method in class org.apache.calcite.test.RelBuilderTest
- testSortPlan() - Method in class org.apache.calcite.tools.PlannerTest
-
Unit test that parses, validates, converts and plans for query using order by
- testSortProjectTranspose1() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortProjectTranspose2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortProjectTranspose3() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortRemovalAllKeysConstant() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortRemovalOneKeyConstant() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSortThenLimit() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests that a sort on a field followed by a limit gives the same effect as calling sortLimit.
- testSortUnionTranspose() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-889] Implement SortUnionTransposeRule.
- testSortUnionTranspose2() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-889] Implement SortUnionTransposeRule.
- testSortUnionTranspose3() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-987] Push limit 0 will result in an infinite loop.
- testSortWithProjection() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSortWithProjectionAndLimit() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSortWithTrim() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSortXAscProjectY() - Method in class org.apache.calcite.test.SparkAdapterTest
- testSortXAscYDescProjectY() - Method in class org.apache.calcite.test.SparkAdapterTest
- testSortXDescYAscProjectY() - Method in class org.apache.calcite.test.SparkAdapterTest
- testSortXDescYDescProjectY() - Method in class org.apache.calcite.test.SparkAdapterTest
- testSource() - Method in class org.apache.calcite.util.mapping.MappingTest
-
Unit test for
Mappings.source(List, int)
and its converse,Mappings.asList(Mappings.TargetMapping)
. - testSpaceInRelativeUrl() - Method in class org.apache.calcite.util.SourceTest
- testSpaceInUrl() - Method in class org.apache.calcite.util.SourceTest
- testSpaces() - Method in class org.apache.calcite.util.UtilTest
- testSpaceString() - Method in class org.apache.calcite.util.UtilTest
- testSpecial() - Method in class org.apache.calcite.util.PrecedenceClimbingParserTest
- testSplit() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testSplitFilter() - Method in class org.apache.calcite.test.MaterializationTest
- testSplitJoinCondition() - Method in class org.apache.calcite.test.RexTransformerTest
- testSplitJoinConditionEquals() - Method in class org.apache.calcite.plan.RelOptUtilTest
-
Test
RelOptUtil.splitJoinCondition(RelNode, RelNode, RexNode, List, List, List)
where the join condition contains just one which is a EQUAL operator. - testSplitJoinConditionExpandedIsNotDistinctFrom() - Method in class org.apache.calcite.plan.RelOptUtilTest
-
Test
RelOptUtil.splitJoinCondition(RelNode, RelNode, RexNode, List, List, List)
where the join condition contains an expanded version of IS NOT DISTINCT - testSplitJoinConditionIsNotDistinctFrom() - Method in class org.apache.calcite.plan.RelOptUtilTest
-
Test
RelOptUtil.splitJoinCondition(RelNode, RelNode, RexNode, List, List, List)
where the join condition contains just one which is a IS NOT DISTINCT operator. - testSql92JoinParenthesized() - Method in class org.apache.calcite.test.JdbcTest
-
Query that uses parenthesized JOIN.
- testSqlAdvisorGetHintsFunction() - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
- testSqlAdvisorGetHintsFunction2() - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
- testSqlAdvisorNonExistingColumn() - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
- testSqlAdvisorNonStructColumn() - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
- testSqlAdvisorSchemaNames() - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
-
Tests
SqlAdvisorGetHintsFunction
. - testSqlAdvisorSubSchema() - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
- testSqlAdvisorSubSchema2() - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
- testSqlAdvisorTableInSchema() - Method in class org.apache.calcite.test.SqlAdvisorJdbcTest
- testSqlBookMasterCount() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlBookMasterWhere() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlBuilder() - Method in class org.apache.calcite.util.UtilTest
-
Tests SQL builders.
- testSqlConjunction() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlDisjunction() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlDistinctSort() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlDistinctSort2() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlDistinctSort3() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlDummy() - Method in class org.apache.calcite.test.CoreQuidemTest
-
Runs the dummy script "sql/dummy.iq", which is checked in empty but which you may use as scratch space during development.
- testSqlInlineComment() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSqlLimit2() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlLine() - Method in class org.apache.calcite.test.SqlLineTest
- testSqlMisc() - Method in class org.apache.calcite.test.CoreQuidemTest
-
Override settings for "sql/misc.iq".
- testSqlMultipleBooleanWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlMultipleDateWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlMultipleTimestampWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlMultipleTimeWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlNodeLiteral() - Method in class org.apache.calcite.test.SqlOperatorBindingTest
-
Tests
SqlUtil.isLiteral(SqlNode, boolean)
, which was added to enhance Calcite's public API [CALCITE-1219] Add a method to SqlOperatorBinding to determine whether operand is a literal. - testSqlOperatorOverloading() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSqlOptions() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSqlScalar() - Method in class org.apache.calcite.test.CoreQuidemTest
-
Override settings for "sql/scalar.iq".
- testSqlSetOptionOperatorReset() - Method in class org.apache.calcite.sql.SqlSetOptionOperatorTest
- testSqlSetOptionOperatorScopeReset() - Method in class org.apache.calcite.sql.SqlSetOptionOperatorTest
- testSqlSetOptionOperatorScopeSet() - Method in class org.apache.calcite.sql.SqlSetOptionOperatorTest
- testSqlSetOptionOperatorSet() - Method in class org.apache.calcite.sql.SqlSetOptionOperatorTest
- testSqlShellFormat() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testSqlShellHelp() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testSqlSimple() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlSingleBooleanWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlSingleDateWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlSingleNumberWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testSqlSingleStringWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testSqlSingleTimestampWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlSingleTimeWhereFilter() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlstateProperty() - Method in class org.apache.calcite.test.CalciteResourceTest
-
Verifies that resource properties such as SQLSTATE are available at runtime.
- testSqlWhereWithMultipleOrForAllFields() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlWhereWithMultipleOrForLiteralFields() - Method in class org.apache.calcite.adapter.geode.rel.GeodeAllDataTypesTest
- testSqlxml() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testSqrtFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSRoundDouble() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testSRoundInt() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testSRoundLong() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testStackedAggregateFilters() - Method in class org.apache.calcite.test.DruidAdapterIT
- testStackedAggregateFilters() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testStandardOperatorNamesAreUpperCase() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Sanity check: All built-ins are upper-case.
- testStar() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testStarAliasFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStarAsFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testStarDotIdFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStarDynamicSchemaUnnest() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testStarDynamicSchemaUnnest2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testStarDynamicSchemaUnnestNestedSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testStarIdentifier() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-546] Allow table, column and field called '*'.
- testStarInFromFails() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Parser allows "*" in FROM clause because "*" can occur in any identifier.
- testStarJoinStaticDynTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for Dynamic Table / Dynamic Star support [CALCITE-1150]
- testStartOfGroupLagStep1() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartOfGroupLagStep3() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartOfGroupLagValueStep2() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartOfGroupLastValueStep1() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartOfGroupLastValueStep2() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartOfGroupLastValueStep3() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartOfGroupLeadStep1() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartOfGroupLeadStep3() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartOfGroupLeadValueStep2() - Method in class org.apache.calcite.test.JdbcTest
-
Tests start_of_group approach for grouping of adjacent intervals.
- testStartsWithList() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Util.startsWith(java.util.List<E>, java.util.List<E>)
. - testStatement() - Method in class org.apache.calcite.test.ServerTest
- testStatementCloseOnCompletion() - Method in class org.apache.calcite.test.JdbcTest
-
Tests
Statement
.closeOnCompletion()
. - testStaticField() - Method in class org.apache.calcite.linq4j.test.DeterministicTest
- TestStaticTableFunction() - Constructor for class org.apache.calcite.util.Smalls.TestStaticTableFunction
- testStaticTableFunctionInModel() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains a table function defined as a static method.
- testStaticTableMacroInModel() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains a table macro defined as a static method.
- testStddevFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testStddevPopFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testStddevSampFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testStdin() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testStdinExplain() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testStore() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testStoredGeneratedColumn() - Method in class org.apache.calcite.test.ServerTest
- testStoredGeneratedColumn2() - Method in class org.apache.calcite.test.ServerTest
- testStream() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testStream() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStream() - Method in class org.apache.calcite.test.StreamTest
- testStreamCancel() - Method in class org.apache.calcite.test.StreamTest
- testStreamFilterProject() - Method in class org.apache.calcite.test.StreamTest
- testStreamGroupBy() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testStreamGroupBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamGroupByHaving() - Method in class org.apache.calcite.test.StreamTest
- testStreamHaving() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamHop() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamJoin() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamOrderBy() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamOrderBy() - Method in class org.apache.calcite.test.StreamTest
- testStreamSession() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamToRelationJoin() - Method in class org.apache.calcite.test.StreamTest
- testStreamTumble() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamUnionAll() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamUnionAllOrderBy() - Method in class org.apache.calcite.test.StreamTest
- testStreamValues() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamWhere() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStreamWindowedAggregation() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testStrengthenJoinType() - Method in class org.apache.calcite.test.RelOptRulesTest
- testStringCompare() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStringCompareType() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStringLiteral() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Test string literal encoding.
- testStringLiteral() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testStringLiteral() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStringLiteralBroken() - Method in class org.apache.calcite.test.SqlValidatorTest
- testStringLiteralChain() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testStringLiteralFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testStrings() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testStrong() - Method in class org.apache.calcite.test.RexProgramTest
-
Unit test for
Strong
. - testStruct() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testStructTypeAlias() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for: [CALCITE-2468] struct type alias should not cause IOOBE..
- testStructuredTypes() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSTruncateDouble() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testSTruncateInt() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testSTruncateLong() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testSubExpressionElimination() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
-
Test for common sub-expression elimination.
- testSubMultisetOf() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSubMultisetOfOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSubMultisetrOf() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSubprogram() - Method in class org.apache.calcite.test.HepPlannerTest
- testSubQuery() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSubQuery() - Method in class org.apache.calcite.test.MaterializationTest
- testSubQueryAggregateFunctionFollowedBySimpleOperation() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSubQueryAlias() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSubQueryAll() - Method in class org.apache.calcite.test.SparkAdapterTest
- testSubQueryAny() - Method in class org.apache.calcite.test.SparkAdapterTest
- testSubQueryInJoin() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSubQueryInOnClause() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSubQueryInWhere() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testSubQueryInWithExpand() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSubQueryInWithExpand2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSubQueryLimitOne() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSubQueryNotInWithExpand() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSubQueryOr() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-1799] "OR ..
- testSubQueryValues() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testSubQueryWithSingleValue() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testSubsetRandom() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testSubsetRule() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
-
Tests a rule that is fired once per subset (whereas most rules are fired once per rel in a set or rel in a subset)
- testSubsetSeries() - Method in class org.apache.calcite.util.PartiallyOrderedSetTest
- testSubstring() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSubstring() - Method in class org.apache.calcite.rex.RexExecutorTest
- testSubstring() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testSubstring() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSubStringExpressionFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSubStringExpressionFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSubstringFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSubstringFunction() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSubStringOverPostAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSubStringOverPostAggregates() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSubstringWithFor() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSubStringWithNonConstantIndex() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSubStringWithNonConstantIndex() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSubStringWithNonConstantIndexes() - Method in class org.apache.calcite.test.DruidAdapterIT
- testSubStringWithNonConstantIndexes() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testSubtype() - Method in class org.apache.calcite.test.ModelTest
-
Reads a simple schema containing JdbcSchema, a sub-type of Schema.
- testSubtypes() - Method in class org.apache.calcite.test.FilteratorTest
- testSuggester() - Method in class org.apache.calcite.test.LatticeTest
- testSum() - Method in class org.apache.calcite.test.LatticeTest
-
Rolling up SUM.
- testSum0BecomesCoalesce() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testSumFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testSumInvalidArgs() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSumOverPossiblyEmptyWindow() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that sum over possibly empty window is nullable.
- testSumOverUnboundedPreceding() - Method in class org.apache.calcite.test.JdbcTest
-
Tests UNBOUNDED PRECEDING clause.
- testSumTooFewArgs() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSumTooManyArgs() - Method in class org.apache.calcite.test.SqlValidatorTest
- testSurpriseQueue() - Method in class org.apache.calcite.profile.ProfilerTest
-
Tests
ProfilerImpl.SurpriseQueue
. - testSwapJoin() - Method in class org.apache.calcite.test.MaterializationTest
- testSwapOuterJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testSyntaxError() - Method in class org.apache.calcite.test.ExceptionMessageTest
- testSystemUserFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTable() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testTableauQueryExtractMonthDayYear() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTableauQueryExtractMonthDayYear() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTableauQueryMinutesSecondsExtract() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTableauQueryMinutesSecondsExtract() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTableauQuerySubStringHourMinutes() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTableauQuerySubStringHourMinutes() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTableB5() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Check that the "set" conversion table looks like Table B-5 in JDBC 4.1 specification
- testTableB6() - Method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
-
Check that the "get" conversion table looks like Table B-5 in JDBC 4.1 specification
- testTableCount() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- testTableExpression() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testTableExtend() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTableExtend() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testTableExtend() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTableExtendExpression() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testTableExtendSubset() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testTableFieldHasBadType() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests that if a field of a relation has an unrecognized type (in this case a
BitSet
) then it is treated as an object. - testTableFunction() - Method in class org.apache.calcite.test.TableFunctionTest
-
Tests a table function with literal arguments.
- testTableFunctionCursorInputs() - Method in class org.apache.calcite.test.TableFunctionTest
-
Tests a table function that takes cursor input.
- testTableFunctionCursorsInputs() - Method in class org.apache.calcite.test.TableFunctionTest
-
Tests a table function that takes multiple cursor inputs.
- testTableFunctionDynamicStructure() - Method in class org.apache.calcite.test.TableFunctionTest
-
Tests a table function that returns different row type based on actual call arguments.
- testTableFunctionInModel() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains a table function.
- testTableFunctionNonNullableMustBeLiterals() - Method in class org.apache.calcite.test.TableFunctionTest
-
Tests that non-nullable arguments of a table function must be provided as literals.
- testTableMacro() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a relation that is accessed via method syntax.
- testTableMacro() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Finds a table-macro using reflection.
- testTableMacroInModel() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a JDBC connection that provides a model that contains a table macro.
- testTableMacroIsView() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
If a method returns a
ViewTable
.ViewTableMacro
, then it should be expanded. - testTableMacroMap() - Method in class org.apache.calcite.test.JdbcTest
-
Table macro that takes a MAP as a parameter.
- testTableMacroWithNamedParameters() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a table macro with named and optional parameters.
- testTableMapReused() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Test to make sure that the mapping from a Table name to a Table returned from
DruidSchema
is always the same Java object. - testTableMapReused() - Method in class org.apache.calcite.test.DruidAdapterIT2
-
Test to make sure that the mapping from a Table name to a Table returned from
DruidSchema
is always the same Java object. - testTableModify() - Method in class org.apache.calcite.test.MaterializationTest
- testTableModifyDelete() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testTableModifyInsert() - Method in class org.apache.calcite.test.JdbcAdapterTest
-
Test case for [CALCITE-1527] Support DML in the JDBC adapter.
- testTableModifyInsertMultiValues() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testTableModifyInsertWithSubQuery() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testTableModifyUpdate() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testTableNotFoundDidYouMean() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTableQueryExtractYearQuarter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTableQueryExtractYearQuarter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTableReferencesJoinUnknownNode() - Method in class org.apache.calcite.test.RelMetadataTest
- testTableReferencesUnionUnknownNode() - Method in class org.apache.calcite.test.RelMetadataTest
- testTables() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackTest
- testTablesample() - Method in class org.apache.calcite.test.SqlValidatorFeatureTest
- testTableSample() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTablesByType() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackTest
- testTableSubset() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testTableWhere() - Method in class org.apache.calcite.test.LinqFrontJdbcBackTest
- testTabStop() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTake() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeEnumerable() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeEnumerableGreaterThanLength() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeEnumerableZeroOrNegativeSize() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeQueryable() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeQueryableGreaterThanLength() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeQueryableZeroOrNegativeSize() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeWhileEnumerableFunction() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeWhileEnumerablePredicate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeWhileN() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeWhileNNoMatch() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTakeWhileQueryableFunctionExpressionPredicate() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTanFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTarget() - Method in class org.apache.calcite.util.mapping.MappingTest
-
Unit test for
Mappings.target(List, int)
. - testTemplate() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
Template
. - testTenElementMapLiteral() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testTens() - Method in class org.apache.calcite.test.ScannableTableTest
- testTestCustomOptimizer() - Method in class org.apache.calcite.linq4j.test.BlockBuilderTest
- testThetaFullJoin() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testThetaFullJoinBothEmpty() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testThetaFullJoinLeftEmpty() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testThetaFullJoinRightEmpty() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testThetaJoin() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testThetaJoin() - Method in class org.apache.calcite.test.JdbcTest
- testThetaLeftJoin() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testThetaRightJoin() - Method in class org.apache.calcite.runtime.EnumerablesTest
- testThreeQueryUnion() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testThresholdCnf() - Method in class org.apache.calcite.test.RexProgramTest
- testTileAlgorithm() - Method in class org.apache.calcite.test.LatticeTest
-
Tests a model that uses an algorithm to generate an initial set of tiles.
- testTileAlgorithm2() - Method in class org.apache.calcite.test.LatticeTest
-
As
LatticeTest.testTileAlgorithm()
, but uses theLattices.CACHED_SQL
statistics provider. - testTileAlgorithm3() - Method in class org.apache.calcite.test.LatticeTest
-
As
LatticeTest.testTileAlgorithm()
, but uses theLattices.PROFILER
statistics provider. - testTileWithNoMeasures() - Method in class org.apache.calcite.test.LatticeTest
-
A tile with no measures should inherit default measure list from the lattice.
- testTime() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testTimeDate() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTimeExtractThatCannotBePushed() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTimeExtractThatCannotBePushed() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTimeFloorExpressions() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTimeFloorExpressions() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTimeLiteral() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
RexBuilder.makeTimeLiteral(TimeString, int)
. - testTimestamp() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testTimestampAdd() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTimestampAdd() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTimestampAddAndDiff() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTimestampAddAndDiff() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTimestampAddFractionalSeconds() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTimestampAddNullInterval() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTimestampDiff() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTimestampDiff() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTimestampGroupBy() - Method in class org.apache.calcite.test.CsvTest
- testTimestampGroupByAndOrderBy() - Method in class org.apache.calcite.test.CsvTest
-
As
CsvTest.testTimestampGroupBy()
but with ORDER BY as well as GROUP BY. - testTimestampLiteral() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
RexBuilder.makeTimestampLiteral(TimestampString, int)
. - testTimestampOrderBy() - Method in class org.apache.calcite.test.CsvTest
-
As
CsvTest.testTimestampGroupBy()
but with ORDER BY. - testTimestampWithLocalTimeZoneLiteral() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
RexBuilder.makeTimestampWithLocalTimeZoneLiteral(TimestampString, int)
. - testTimeStringHourError() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
TimeString
hour range. - testTimeStringMinuteError() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
TimeString
minute range. - testTimeStringSecondError() - Method in class org.apache.calcite.rex.RexBuilderTest
-
Tests
TimeString
second range. - testTimeWithFilterOnFloorOnTimeAndCastToTimestamp() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTimeWithFilterOnFloorOnTimeAndCastToTimestamp() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTimeWithFilterOnFloorOnTimeWithTimezone() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTimeWithFilterOnFloorOnTimeWithTimezoneConversion() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTimeWithFilterOnFloorOnTimeWithTimezoneConversionCast() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTinyint() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testToArray() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
ImmutableBitSet.toArray()
. - testToCamelCase() - Method in class org.apache.calcite.util.UtilTest
-
Unit test for
AvaticaUtils.toCamelCase(String)
. - testToIterBitSet() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.toIter(java.util.BitSet)
. - testToJavaId() - Method in class org.apache.calcite.util.UtilTest
- testTokenize() - Method in class org.apache.calcite.util.UtilTest
-
Unit-test for
Util.tokenize(String, String)
. - testToList() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
ImmutableBitSet.toList()
. - testToListBitSet() - Method in class org.apache.calcite.util.BitSetsTest
-
Tests the method
BitSets.toList(java.util.BitSet)
. - testToLongArray() - Method in class org.apache.calcite.util.ImmutableBitSetTest
- testToLookup() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testToLookupSelector() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testToLookupSelectorComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testToMap() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testToMap2() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testToMap2WithComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testToMapWithComparer() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTopNDayGranularityFiltered() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTopNDayGranularityFiltered() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTopNMonthGranularity() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTopNMonthGranularity() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTopologicalOrderIterator() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
-
Unit test for
TopologicalOrderIterator
. - testTpcdsAll() - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest
- testTpcdsAllEvolve() - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest
- testTraitConversion() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest
- testTraitPropagation() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
- testTransform() - Method in class org.apache.calcite.util.UtilTest
-
Tests
Util.transform(List, java.util.function.Function)
. - testTransformEnumerator() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testTransformLeaf() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
-
Tests transformation of a leaf from NONE to PHYS.
- testTransformSingleGood() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
-
Tests transformation of a single+leaf from NONE to PHYS.
- testTransformSingleReformed() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
-
Tests transformation of a single+leaf from NONE to PHYS.
- testTransitiveInferenceAggregate() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceComplexPredicate() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceConjunctInPullUp() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceConstantEquiPredicate() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceFullOuterJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceJoin3way() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceJoin3wayAgg() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceLeftOuterJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceNoPullUpExprs() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferencePreventProjectPullUp() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceProject() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferencePullUpThruAlias() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceRightOuterJoin() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceUnion() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceUnion3way() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceUnion3wayOr() - Method in class org.apache.calcite.test.RelOptRulesTest
- testTransitiveInferenceUnionAlwaysTrue() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-443] getPredicates from a union is not correct.
- testTranslate3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTranslate3() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTranslate3Func() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTranslateFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTransposableHavingFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTransposableHavingFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTrigonometryMathFunctions() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTrigonometryMathFunctions() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTrim() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testTrim() - Method in class org.apache.calcite.test.JdbcTest
- testTrim() - Method in class org.apache.calcite.test.SqlFunctionsTest
-
Test for
SqlFunctions.trim(boolean, boolean, java.lang.String, java.lang.String)
. - testTrim() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTrimFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTrimFields() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that field-trimming creates a project near the table scan.
- testTrimFieldsOver() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that field-trimming creates a project near the table scan, in a query with windowed-aggregation.
- testTrimFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTrivialSort() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-1015] OFFSET 0 causes AssertionError.
- testTrivialSort() - Method in class org.apache.calcite.test.RelBuilderTest
-
Test case for [CALCITE-1015] OFFSET 0 causes AssertionError.
- testTrue() - Method in class org.apache.calcite.test.JdbcTest
- testTrueFilter() - Method in class org.apache.calcite.test.DruidAdapterIT
- testTrueFilter() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testTruncateFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testTruncateInt() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testTruncateLong() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testTryThreadLocal() - Method in class org.apache.calcite.util.UtilTest
-
Tests
TryThreadLocal
. - testTumble() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testTumbleTable() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testTumbleTableRowtimeNotFirstColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
As
SqlToRelConverterTest.testTumbleTable()
but on a table where "rowtime" is at position 1 not 0. - testTumbleViaOver() - Method in class org.apache.calcite.test.StreamTest
- testTwo() - Method in class org.apache.calcite.util.PermutationTestCase
- testTwoElementListLiteral() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testTwoElementMapLiteral() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testTwoLattices() - Method in class org.apache.calcite.test.LatticeTest
- testTwoLatticesWithSameNameFails() - Method in class org.apache.calcite.test.LatticeTest
-
Tests that it's an error to have two lattices with the same name in a schema.
- testType() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testTypeDump() - Method in class org.apache.calcite.plan.RelOptUtilTest
- testTypeInferenceValidation() - Method in class org.apache.calcite.test.RelBuilderTest
- testTypeOfAs() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTypesIsSameFamilyWithCharStructTypes() - Method in class org.apache.calcite.sql.type.SqlTypeUtilTest
- testTypesIsSameFamilyWithCharTypes() - Method in class org.apache.calcite.sql.type.SqlTypeUtilTest
- testTypesIsSameFamilyWithInconvertibleStructTypes() - Method in class org.apache.calcite.sql.type.SqlTypeUtilTest
- testTypesIsSameFamilyWithInconvertibleTypes() - Method in class org.apache.calcite.sql.type.SqlTypeUtilTest
- testTypesIsSameFamilyWithNumberStructTypes() - Method in class org.apache.calcite.sql.type.SqlTypeUtilTest
- testTypesIsSameFamilyWithNumberTypes() - Method in class org.apache.calcite.sql.type.SqlTypeUtilTest
- testTypesLiterals() - Method in class org.apache.calcite.test.SqlValidatorTest
- testTypeSystem() - Method in class org.apache.calcite.tools.FrameworksTest
-
Tests that validation (specifically, inferring the result of adding two DECIMAL(19, 0) values together) happens differently with a type system that allows a larger maximum precision for decimals.
- testTypeToClass() - Method in class org.apache.calcite.plan.RelOptPlanReaderTest
- testUdfArgumentName() - Method in class org.apache.calcite.test.UdfTest
-
Tests passing parameters to user-defined function by name.
- testUdfArgumentOptional() - Method in class org.apache.calcite.test.UdfTest
-
Tests calling a user-defined function some of whose parameters are optional.
- testUdfDerivedReturnType() - Method in class org.apache.calcite.test.UdfTest
-
Tests derived return type of user-defined function.
- testUdfOverloaded() - Method in class org.apache.calcite.test.UdfTest
-
Tests a user-defined function that has multiple overloads.
- testUdfOverloadedNullable() - Method in class org.apache.calcite.test.UdfTest
- testUdt() - Method in class org.apache.calcite.test.UdtTest
- testUnboundYearExtractRewrite() - Method in class org.apache.calcite.rel.rules.DateRangeRulesTest
- testUncorrelatedScalarSubQueryInAggregateRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUncorrelatedScalarSubQueryInGroupOrderRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUncorrelatedScalarSubQueryInOrderRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnicode() - Method in class org.apache.calcite.test.JdbcTest
- testUnicodeEscapedLiteral() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUnicodeLiteral() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUnion() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testUnion() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUnion() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testUnion() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testUnion() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Tests UNION.
- testUnion() - Method in class org.apache.calcite.test.JdbcTest
- testUnion() - Method in class org.apache.calcite.test.PigRelBuilderTest
- testUnion() - Method in class org.apache.calcite.test.RelBuilderTest
- testUnion() - Method in class org.apache.calcite.test.RelMetadataTest
- testUnion() - Method in class org.apache.calcite.test.SparkAdapterTest
- testUnion() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnion() - Method in class org.apache.calcite.util.ImmutableBitSetTest
-
Tests the method
ImmutableBitSet.union(ImmutableBitSet)
. - testUnion1() - Method in class org.apache.calcite.test.RelBuilderTest
- testUnion3() - Method in class org.apache.calcite.test.RelBuilderTest
- testUnionAlias() - Method in class org.apache.calcite.test.RelBuilderTest
- testUnionAll() - Method in class org.apache.calcite.test.JdbcTest
- testUnionAll() - Method in class org.apache.calcite.test.MaterializationTest
- testUnionAll() - Method in class org.apache.calcite.test.SparkAdapterTest
- testUnionAll() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnionAllOrderBy() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
-
Simple UNION, plus ORDER BY.
- testUnionCountMismatchFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnionCountMismatcWithValuesFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnionGroupByWithoutGroupKey() - Method in class org.apache.calcite.test.CsvTest
- testUnionInFrom() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnionMergeRule() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Tests to see if the final branch of union is missed
- testUnionNameResolution() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnionOfNonQueryFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUnionOrder() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUnionPlan() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
- testUnionPlan() - Method in class org.apache.calcite.test.DruidAdapterIT
- testUnionPlan() - Method in class org.apache.calcite.test.DruidAdapterIT2
- testUnionPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
- testUnionSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnionToDistinctRule() - Method in class org.apache.calcite.test.RelOptRulesTest
- testUnionTypeMismatchFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnionTypeMismatchWithStarFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnionTypeMismatchWithValuesFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnionValues() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnionWithFilters() - Method in class org.apache.calcite.test.SparkAdapterTest
- testUnionWithFiltersProject() - Method in class org.apache.calcite.test.SparkAdapterTest
- testUnionWithSameColumnNames() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that even though trivial "rename columns" projection is removed, the query still returns proper column names.
- testUnionWrappedInASelect() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testUniquifyCaseSensitive() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- testUniquifyNotCaseSensitive() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- testUniquifyOrderingCaseSensitive() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- testUniquifyOrderingNotCaseSensitive() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- testUniquifyOrderingRepeatedCaseSensitive() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- testUniquifyOrderingRepeatedNotCaseSensitive() - Method in class org.apache.calcite.sql.validate.SqlValidatorUtilTest
- testUnknownInOr() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
CALCITE-2611 unknown on one side of an or may lead to uncompilable code
- testUnmodifiableArrayList() - Method in class org.apache.calcite.util.UtilTest
-
Test for
UnmodifiableArrayList
. - testUnnest() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUnnest() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnest() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnnestArray() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestArray() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnestArray() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnnestArrayAggPlan() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnestArrayColumn() - Method in class org.apache.calcite.test.JdbcTest
-
Per SQL std, UNNEST is implicitly LATERAL.
- testUnnestArrayColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnnestArrayPlan() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnestArrayPlanAs() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnestArrayScalarArray() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestArrayScalarArrayAliased() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestArrayScalarArrayWithOrdinal() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestArrayWithOrdinality() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestItemsInMap() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-1250] UNNEST applied to MAP data type.
- testUnnestItemsInMapWithNoAliasAndAdditionalArgument() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestItemsInMapWithOrdinality() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestMultiset() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestMultiset2() - Method in class org.apache.calcite.test.JdbcTest
- testUnnestSelect() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnestSelectRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnestSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnestWithOrdinality() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUnnestWithOrdinality() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUnnestWithOrdinality() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUnparseableIntervalQualifiers() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUnparseIn1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
Tests that IN can be un-parsed.
- testUnparseIn2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testUnparseInStruct1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testUnparseInStruct2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testUnparseSelectMustUseDialect() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testUnparseSqlIntervalQualifierDb2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testUnparseSqlIntervalQualifierMsSql() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testUnparseSqlIntervalQualifierMySql() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testUnquotedBuiltInFunctionNames() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests matching of built-in operator names.
- testUnquotedCaseSensitiveSubQueryMySql() - Method in class org.apache.calcite.test.JdbcTest
- testUnquotedCaseSensitiveSubQuerySqlServer() - Method in class org.apache.calcite.test.JdbcTest
- testUpdate() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUpdate() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdate() - Method in class org.apache.calcite.tools.FrameworksTest
-
Test case for [CALCITE-2039] AssertionError when pushing project to ProjectableFilterableTable using UPDATE via
Frameworks
. - testUpdateBind() - Method in class org.apache.calcite.test.JdbcTest
- testUpdateBind() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateBind() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateBind2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateBindExtendedColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateBindExtendedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateBindExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateBindExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateCaseSensitiveExtendedColumnList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUpdateExtendedColumn() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateExtendedColumn() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnCaseSensitiveCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateExtendedColumnCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateExtendedColumnCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnFailCaseSensitivity() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnFailCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnFailCollision2() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnFailDuplicate() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnList() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUpdateExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateExtendedColumnModifiableView() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnModifiableViewCaseSensitiveCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateExtendedColumnModifiableViewCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateExtendedColumnModifiableViewCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnModifiableViewExtendedCaseSensitiveCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateExtendedColumnModifiableViewExtendedCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateExtendedColumnModifiableViewFailCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnModifiableViewFailConstraint() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnModifiableViewFailExtendedCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnModifiableViewFailUnderlyingCollision() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateExtendedColumnModifiableViewUnderlyingCollision() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateFailCaseSensitivity() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateFailDataType() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateModifiableView() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateModifiableViewFailConstraint() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateModifiableViewPassConstraint() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpdateSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateWhere() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpdateWithCustomColumnResolving() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUpper() - Method in class org.apache.calcite.test.SqlFunctionsTest
- testUpperFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testUpperLower() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUpsertSelect() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUpsertValues() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testUrlSelect() - Method in class org.apache.calcite.adapter.file.SqlTest
-
Reads from a URL and checks the result.
- testUserDefinedAggregateFunction() - Method in class org.apache.calcite.test.UdfTest
-
Tests user-defined aggregate function.
- testUserDefinedAggregateFunction3() - Method in class org.apache.calcite.test.UdfTest
-
Test for
CalciteResource.firstParameterOfAdd(String)
. - testUserDefinedAggregateFunctionImplementsInterface() - Method in class org.apache.calcite.test.UdfTest
- testUserDefinedAggregateFunctionWithFilter() - Method in class org.apache.calcite.test.UdfTest
-
Tests user-defined aggregate function with FILTER.
- testUserDefinedAggregateFunctionWithMultipleParameters() - Method in class org.apache.calcite.test.UdfTest
-
Tests user-defined aggregate function.
- testUserDefinedConformance() - Method in class org.apache.calcite.test.SqlValidatorTest
- testUserDefinedFunction() - Method in class org.apache.calcite.test.UdfTest
-
Tests a user-defined function that is defined in terms of a class with non-static methods.
- testUserDefinedFunction2() - Method in class org.apache.calcite.test.UdfTest
-
Test for
CalciteResource.requireDefaultConstructor(String)
. - testUserDefinedFunctionB() - Method in class org.apache.calcite.test.UdfTest
- testUserDefinedFunctionInstanceCount() - Method in class org.apache.calcite.test.UdfTest
-
As
UdfTest.testUserDefinedFunction()
, but checks that the class is instantiated exactly once, per [CALCITE-1548] Instantiate function objects once per query. - testUserDefinedFunctionInView() - Method in class org.apache.calcite.test.UdfTest
-
Test case for [CALCITE-937] User-defined function within view.
- testUserDefinedFunctionWithMethodName() - Method in class org.apache.calcite.test.UdfTest
-
Tests user-defined function, with multiple methods per class.
- testUserDefinedOrderByOver() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testUserDefinedTableFunction() - Method in class org.apache.calcite.test.TableFunctionTest
- testUserDefinedTableFunction2() - Method in class org.apache.calcite.test.TableFunctionTest
- testUserDefinedTableFunction3() - Method in class org.apache.calcite.test.TableFunctionTest
- testUserDefinedTableFunction4() - Method in class org.apache.calcite.test.TableFunctionTest
- testUserDefinedTableFunction5() - Method in class org.apache.calcite.test.TableFunctionTest
- testUserDefinedTableFunction6() - Method in class org.apache.calcite.test.TableFunctionTest
- testUserDefinedTableFunction7() - Method in class org.apache.calcite.test.TableFunctionTest
- testUserDefinedTableFunction8() - Method in class org.apache.calcite.test.TableFunctionTest
- testUserFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- TestUtil - Class in org.apache.calcite.util
-
Static utilities for JUnit tests.
- TestUtil() - Constructor for class org.apache.calcite.util.TestUtil
- TestUtilTest - Class in org.apache.calcite.util
-
Tests for TestUtil
- TestUtilTest() - Constructor for class org.apache.calcite.util.TestUtilTest
- testValidateFails() - Method in class org.apache.calcite.tools.PlannerTest
- testValidateUserDefinedAggregate() - Method in class org.apache.calcite.tools.PlannerTest
- testValidatorReportsOriginalQueryUsingReader() - Method in class org.apache.calcite.test.SqlValidatorTest
- testValidQuery() - Method in class org.apache.calcite.test.ExceptionMessageTest
- testValues() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testValues() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testValues() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
-
Validates expected data against retrieved data.
- testValues() - Method in class org.apache.calcite.test.JdbcTest
- testValues() - Method in class org.apache.calcite.test.PigletTest
-
VALUES is an extension to Pig.
- testValues() - Method in class org.apache.calcite.test.RelBuilderTest
- testValues() - Method in class org.apache.calcite.test.SparkAdapterTest
-
Tests a VALUES query evaluated using Spark.
- testValues(List<Object>, List<Object>, int) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.FetchAndCompareCommand
-
Validates
ResultSet
against expected data. - testValuesAlias() - Method in class org.apache.calcite.test.JdbcTest
- testValuesAllNull() - Method in class org.apache.calcite.test.RelBuilderTest
- testValuesBadAllNull() - Method in class org.apache.calcite.test.RelBuilderTest
- testValuesBadNoFields() - Method in class org.apache.calcite.test.RelBuilderTest
- testValuesBadNoValues() - Method in class org.apache.calcite.test.RelBuilderTest
- testValuesBadNullFieldNames() - Method in class org.apache.calcite.test.RelBuilderTest
- testValuesBadOddMultiple() - Method in class org.apache.calcite.test.RelBuilderTest
- testValuesComposite() - Method in class org.apache.calcite.test.JdbcTest
-
Tests a table constructor that has multiple rows and multiple columns.
- testValuesCompositeRenamed() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that even though trivial "rename columns" projection is removed, the query still returns proper column names.
- testValuesCompositeRenamedSameNames() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that even though trivial "rename columns" projection is removed, the query still returns proper column names.
- testValueSetBoolean() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testValueSetInt() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testValueSetZero() - Method in class org.apache.calcite.adapter.clone.ArrayTableTest
- testValuesExplicitRow() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testValuesFilter() - Method in class org.apache.calcite.test.SparkAdapterTest
-
Tests values followed by filter, evaluated by Spark.
- testValuesMinus() - Method in class org.apache.calcite.test.JdbcTest
- testValuesNested() - Method in class org.apache.calcite.test.PigletTest
- testValuesNullable() - Method in class org.apache.calcite.test.RelBuilderTest
-
Tests creating Values with some field names and some values null.
- testValuesOperator() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testValuesPlan() - Method in class org.apache.calcite.test.JdbcAdapterTest
-
VALUES is not pushed down, currently.
- testValuesTypeMismatchFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- testValuesUsing() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testVanityDriver() - Method in class org.apache.calcite.test.CsvTest
-
Tests the vanity driver.
- testVanityDriver() - Method in class org.apache.calcite.test.SplunkAdapterTest
-
Tests the vanity driver.
- testVanityDriverArgsInUrl() - Method in class org.apache.calcite.test.CsvTest
-
Tests the vanity driver with properties in the URL.
- testVanityDriverArgsInUrl() - Method in class org.apache.calcite.test.SplunkAdapterTest
-
Tests the vanity driver with properties in the URL.
- testVarbinary() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testVarchar() - Method in class org.apache.calcite.sql.test.SqlTypeNameTest
- testVarcharEquals() - Method in class org.apache.calcite.test.JdbcTest
- testVarFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testVariableExecution() - Method in class org.apache.calcite.rex.RexExecutorTest
-
Tests an executor that uses variables stored in a
DataContext
. - testVariousOuter() - Method in class org.apache.calcite.test.JdbcTest
-
Various queries against EMP and DEPT, in particular involving composite join conditions in various flavors of outer join.
- testVarPopFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testVarSampFunc() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testVersion() - Method in class org.apache.calcite.test.JdbcTest
-
Make sure that the properties look sane.
- testVertexMustExist() - Method in class org.apache.calcite.util.graph.DirectedGraphTest
- testView() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests a view.
- testView() - Method in class org.apache.calcite.tools.PlannerTest
- testViewMaterialization() - Method in class org.apache.calcite.test.MaterializationTest
- testViewOnView() - Method in class org.apache.calcite.tools.PlannerTest
- testViewPath() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests a view with a path.
- testViewSchemaPath() - Method in class org.apache.calcite.test.MaterializationTest
- testVirtualColumn() - Method in class org.apache.calcite.test.ServerTest
- testVmstat() - Method in class org.apache.calcite.adapter.os.OsAdapterTest
- testWackyColumns() - Method in class org.apache.calcite.test.CsvTest
- testWeek() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testWhere() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testWhere() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWhere() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testWhere() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWhere2() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackLinqMiddleTest
- testWhere2() - Method in class org.apache.calcite.test.JdbcFrontJdbcBackTest
- testWhereBad() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- testWhereEqual() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testWhereExpressionInCorrelated() - Method in class org.apache.calcite.test.RelOptRulesTest
- testWhereExpressionInCorrelated2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testWhereGroupBy() - Method in class org.apache.calcite.test.DruidAdapterIT
-
Tests a query that exposed several bugs in the interpreter.
- testWhereInCorrelated() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-1494] Inefficient plan for correlated sub-queries.
- testWhereInCorrelated() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWhereIndexed() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testWhereInJoinCorrelated() - Method in class org.apache.calcite.test.RelOptRulesTest
- testWhereInOr() - Method in class org.apache.calcite.test.JdbcTest
- testWhereLike() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- testWhereList() - Method in class org.apache.calcite.sql.test.SqlAdvisorTest
- testWhereListItemsOnSeparateLinesAnd() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testWhereListItemsOnSeparateLinesOr() - Method in class org.apache.calcite.sql.test.SqlPrettyWriterTest
- testWhereNot() - Method in class org.apache.calcite.test.JdbcTest
- testWhereNOT() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
-
Tests NOT for nullable columns
- testWhereNotInCorrelated() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-1493] Wrong plan for NOT IN correlated queries.
- testWhereNotInCorrelated2() - Method in class org.apache.calcite.test.RelOptRulesTest
- testWhereNullable() - Method in class org.apache.calcite.test.JdbcTest
-
Tests WHERE comparing a nullable integer with an integer literal.
- testWhereOr() - Method in class org.apache.calcite.test.JdbcFrontLinqBackTest
- testWhereOrAndNullable() - Method in class org.apache.calcite.test.JdbcTest
-
Tests CALCITE-980: Not (C='a' or C='b') causes NPE
- testWhereOrSubQuery() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-1546] Sub-queries connected by OR.
- testWhereReference() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWhereWithAnd() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testWhereWithAndOr() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testWhereWithFieldAccessOnFirstLevelRecordType() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testWhereWithFieldAccessOnFirstLevelRecordTypeArray() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testWhereWithFieldAccessOnSecondLevelRecordType() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testWhereWithFieldAccessOnSecondLevelRecordTypeArray() - Method in class org.apache.calcite.test.ReflectiveSchemaTest
- testWhereWithOr() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testWhereWithOrAnd() - Method in class org.apache.calcite.adapter.geode.rel.GeodeBookstoreTest
- testWhereWithOrForLargeValueList() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testWhereWithOrForNestedNumericField() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testWhereWithOrForNumericField() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testWhereWithOrForStringField() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testWhereWithOrWithEmptyResult() - Method in class org.apache.calcite.adapter.geode.rel.GeodeZipsTest
- testWinAgg() - Method in class org.apache.calcite.test.JdbcTest
-
Tests windowed aggregation.
- testWinAgg2() - Method in class org.apache.calcite.test.JdbcTest
-
Tests windowed aggregation with multiple windows.
- testWinAggConstant() - Method in class org.apache.calcite.test.JdbcTest
-
Tests window aggregate whose argument is a constant.
- testWinAggConstantMultipleConstants() - Method in class org.apache.calcite.test.JdbcTest
-
Tests multiple window aggregates over constants.
- testWinAggDenseRankValues() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for DENSE_RANK with same values
- testWinAggDenseRankValuesDesc() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for DENSE_RANK with same values
- testWinAggFirstValue() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for FIRST_VALUE
- testWinAggFirstValueDesc() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for FIRST_VALUE desc
- testWinAggFirstValueEmptyWindow() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for FIRST_VALUE empty window
- testWinAggOrderByConstant() - Method in class org.apache.calcite.test.JdbcTest
-
Tests window aggregate ORDER BY constant.
- testWinAggPartitionByConstant() - Method in class org.apache.calcite.test.JdbcTest
-
Tests window aggregate PARTITION BY constant.
- testWinAggRank() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for RANK and ORDER BY ...
- testWinAggRankValues() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for RANK with same values
- testWinAggRankValuesDesc() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for RANK with same values
- testWinAggScalarNonNullPhysType() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that window aggregates work when computed over non-nullable
JavaRowFormat.SCALAR
inputs. - testWinAggScalarNonNullPhysTypePlusOne() - Method in class org.apache.calcite.test.JdbcTest
-
Tests that
LogicalCalc
is implemented properly when input isLogicalWindow
and literal. - testWindow() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testWindowAggInSubQueryJoin() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWindowAggWithGroupBy() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWindowAggWithGroupByAndHaving() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-770] variant involving HAVING clause.
- testWindowAggWithGroupByAndJoin() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-770] variant involving joins.
- testWindowAndGroupByWithDynamicStar() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWindowAverageWithGroupBy() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWindowClause() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWindowClause2() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWindowClauseWithSubQuery() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWindowedSum0BecomesCoalesce() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
As
RelToSqlConverterTest.testSum0BecomesCoalesce()
but for windowed aggregates. - testWindowFunctionOnAggregations() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-2078] Aggregate functions in OVER clause.
- testWindowFunctions() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWindowFunctions2() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWindowFunctionsWithoutOver() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWindowInParenthesis() - Method in class org.apache.calcite.test.RelOptRulesTest
-
Test case for [CALCITE-888] Overlay window loses PARTITION BY list.
- testWindowInSubQuery() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWindowNegative() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWindowOnDynamicStar() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWindowPartial() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWindowReference() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWindowSpec() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWindowSpecPartial() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWinIntervalFrame() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for DATE +- INTERVAL window frame
- testWinRowNumber() - Method in class org.apache.calcite.test.JdbcTest
-
Tests for ROW_NUMBER
- testWith() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWith() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWith() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests the
WITH
clause, also called common table expressions. - testWith2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithAlias() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithColumnAlias() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests the
WITH
clause and column aliases. - testWithExists() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithinGroup() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWithinGroup1() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testWithinGroup1() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithinGroup2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testWithinGroup2() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithinGroup3() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testWithinGroup3() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithinGroup4() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
- testWithinGroupClause1() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithinGroupClause1() - Method in class org.apache.calcite.test.JdbcTest
-
Test case for [CALCITE-2224] WITHIN GROUP clause for aggregate functions.
- testWithinGroupClause2() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithinGroupClause2() - Method in class org.apache.calcite.test.JdbcTest
- testWithinGroupClause3() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithinGroupClause3() - Method in class org.apache.calcite.test.JdbcTest
- testWithinGroupClause4() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithinGroupClause4() - Method in class org.apache.calcite.test.JdbcTest
- testWithinGroupClause5() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithinGroupClause5() - Method in class org.apache.calcite.test.JdbcTest
- testWithinGroupClause6() - Method in class org.apache.calcite.test.JdbcTest
- testWithInsideScalarSubQuery() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithInsideScalarSubQueryRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithInsideWhereExists() - Method in class org.apache.calcite.test.JdbcTest
- testWithInsideWhereExists() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithInsideWhereExistsDecorrelate() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithInsideWhereExistsDecorrelateRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithInsideWhereExistsRex() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithLattice() - Method in class org.apache.calcite.test.FoodmartTest
- testWithNestedFails() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithNestedInSubQuery() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithOrder() - Method in class org.apache.calcite.test.SqlToRelConverterTest
-
Test case for [CALCITE-309] WITH ...
- testWithOrder() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Test case for [CALCITE-633] WITH ...
- testWithOrderAgg() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWithOrderBy() - Method in class org.apache.calcite.test.JdbcTest
- testWithOrderInParentheses() - Method in class org.apache.calcite.test.SqlValidatorTest
- testWithoutRemoveTrivialProject() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
- testWithRemoveTrivialProject() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTest
- testWithSubQuery() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests the
WITH
clause in sub-queries. - testWithUnion() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWithUnion() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithUnion() - Method in class org.apache.calcite.test.SqlValidatorTest
-
Tests the
WITH
clause with UNION. - testWithUnionOrder() - Method in class org.apache.calcite.test.SqlToRelConverterTest
- testWithValues() - Method in class org.apache.calcite.sql.parser.SqlParserTest
- testWrite() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testWriteAnonymousClass() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testWriteArray() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testWriteConstant() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testWriter() - Method in class org.apache.calcite.plan.RelWriterTest
-
Unit test for
RelJsonWriter
on a simple tree of relational expressions, consisting of a table, a filter and an aggregate node. - testWriteTryCatch() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testWriteTryCatchFinally() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testWriteTryFinally() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testWriteWhile() - Method in class org.apache.calcite.linq4j.test.ExpressionTest
- testXmlOutput() - Method in class org.apache.calcite.util.UtilTest
- testYamlFileDetection() - Method in class org.apache.calcite.test.ModelTest
- testYamlInlineDetection() - Method in class org.apache.calcite.test.ModelTest
- testYear() - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- testYearIsNotReserved() - Method in class org.apache.calcite.test.BabelParserTest
- testZip() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testZipLengthNotMatch() - Method in class org.apache.calcite.linq4j.test.Linq4jTest
- testZips() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- testZips() - Method in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
Simple query based on the "mongo-zips" model.
- that() - Static method in class org.apache.calcite.test.CalciteAssert
-
Creates an instance of
CalciteAssert
with the empty configuration. - that(CalciteAssert.Config) - Static method in class org.apache.calcite.test.CalciteAssert
-
Creates an instance of
CalciteAssert
with a given configuration. - thereAndBack(byte[]) - Method in class org.apache.calcite.test.SqlFunctionsTest
- THREAD - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- THREAD_ACTUAL - Static variable in class org.apache.calcite.test.Matchers
-
Allows passing the actual result from the
matchesSafely
method to thedescribeMismatchSafely
method that will show the difference. - THREAD_CALL_COUNT - Static variable in class org.apache.calcite.test.catalog.CountingFactory
- THREAD_COLLECTION - Static variable in class org.apache.calcite.test.JdbcTest.EmpDeptTableFactory
- THREAD_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- THREAD_LIST - Static variable in class org.apache.calcite.test.RelMetadataTest.PartialColTypeImpl
- THREAD_STATE - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- threadBufferedWriters - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- threadId - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
The id for this thread.
- threadId - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- threadMap - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Maps Integer thread IDs to a TreeMap.
- threadNameMap - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator
-
Maps Integer thread IDs to thread names.
- threadResultsReaders - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- threadStringWriters - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- THREE - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- thrown - Variable in class org.apache.calcite.test.BabelTest
- thrown - Variable in class org.apache.calcite.test.ServerTest
- throws_(String) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- throws_(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- throws_(String) - Method in class org.apache.calcite.test.CalciteAssert.NopAssertQuery
- time - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrintCommand
- TIME_PATTERN - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Regular expression for a SQL TIME(0) value.
- timeDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- TimedIterator(Collection<E>, long) - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestTimedCommandGenerator.TimedIterator
- timeFun(Time) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- timeLiteral(TimeString) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- timeout - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandGenerator.CommandWithTimeout
- timeout - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandWithTimeout
- TIMEOUT - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- TIMEOUT_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- TIMESTAMP_PATTERN - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
-
Regular expression for a SQL TIMESTAMP(0) value.
- timestampDataType - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- timestamped - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- timestampFun(Timestamp) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- timestampLiteral(TimestampString) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- timestampLocalTzLiteral(TimestampString) - Method in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- timestampType - Variable in class org.apache.calcite.test.catalog.Fixture
- timestampTypeNull - Variable in class org.apache.calcite.test.catalog.Fixture
- tInt() - Method in class org.apache.calcite.test.RexProgramBuilderBase
- tInt(boolean) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- title - Variable in class org.apache.calcite.test.BookstoreSchema.Book
- toDateFun(int) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
-
Overloaded, in a challenging way, with
Smalls.AllTypesFunction.toDateFun(Long)
. - toDateFun(Long) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- TODO - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- TODO - Static variable in class org.apache.calcite.test.SqlValidatorDynamicTest
-
Deprecated.Deprecated so that usages of this constant will show up in yellow in Intellij and maybe someone will fix them.
- TODO - Static variable in class org.apache.calcite.test.SqlValidatorTest
-
Deprecated.Deprecated so that usages of this constant will show up in yellow in Intellij and maybe someone will fix them.
- toDouble(Double) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toDouble(Float) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toDouble(BigDecimal) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
-
for Overloaded user-defined functions that have Double and BigDecimal arguments will goes wrong
- toJavaString(String) - Static method in class org.apache.calcite.util.TestUtil
-
Converts a string (which may contain quotes and newlines) into a java literal.
- toJson(QueryBuilders.QueryBuilder) - Method in class org.apache.calcite.adapter.elasticsearch.QueryBuildersTest
- tokenize(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ShellCommand
- toList(Iterable<E>) - Static method in class org.apache.calcite.util.UtilTest
- toList(ResultSet) - Static method in class org.apache.calcite.test.CalciteAssert
- toLong(Date) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
-
Overloaded functions with DATE, TIMESTAMP and TIME arguments.
- toLong(Time) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toLong(Timestamp) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toModificationRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Method in class org.apache.calcite.test.JdbcTest.AbstractModifiableTable
- toModificationRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Method in class org.apache.calcite.tools.FrameworksTest.TableImpl
- Tool() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- TopN(int) - Constructor for class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest.TopN
- TOPN_SLOWEST - Static variable in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- toRel(String) - Static method in class org.apache.calcite.test.RexTransformerTest
-
Converts a SQL string to a relational expression using mock schema.
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockDynamicTable
-
Recreates an immutable rowType, if the table has Dynamic Record Type, when converts table to Rel.
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- toRel(RelOptTable.ToRelContext) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.calcite.test.TableInRootSchemaTest.SimpleTable
- toSet(ResultSet) - Static method in class org.apache.calcite.test.CalciteAssert
- toSql(RelNode) - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
Converts a relational expression to SQL.
- toSql(RelNode, SqlDialect) - Static method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest
-
Converts a relational expression to SQL in a given dialect.
- toString() - Method in class com.example.Linq4jExample.Employee
- toString() - Method in class org.apache.calcite.linq4j.test.Linq4jTest.Department
- toString() - Method in class org.apache.calcite.linq4j.test.Linq4jTest.Employee
- toString() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.ConvertRelDistributionTraitDef
- toString() - Method in class org.apache.calcite.plan.volcano.TraitConversionTest.SimpleDistribution
- toString() - Method in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- toString() - Method in class org.apache.calcite.runtime.EnumerablesTest.Dept
- toString() - Method in class org.apache.calcite.runtime.EnumerablesTest.Emp
- toString() - Method in class org.apache.calcite.test.JdbcTest.Department
- toString() - Method in class org.apache.calcite.test.JdbcTest.Dependent
- toString() - Method in class org.apache.calcite.test.JdbcTest.Employee
- toString() - Method in class org.apache.calcite.test.JdbcTest.Event
- toString() - Method in class org.apache.calcite.test.JdbcTest.HrSchema
- toString() - Method in class org.apache.calcite.test.JdbcTest.Location
- toString() - Method in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- toString() - Method in class org.apache.calcite.test.MockRelOptCost
- toString() - Method in class org.apache.calcite.tools.TpchSchema.Part
- toString() - Method in class org.apache.calcite.tools.TpchSchema.PartSupp
- toString() - Method in class org.apache.calcite.util.Smalls.IntString
- toString() - Method in class org.apache.calcite.util.Smalls.WideSaleSchema
- toString(byte[]) - Method in class org.apache.calcite.util.UtilTest
-
Converts a byte array to a hex string like "AB, CD".
- toString(ResultSet) - Static method in class org.apache.calcite.adapter.file.SqlTest
- toString(ResultSet) - Static method in class org.apache.calcite.test.CalciteAssert
-
Converts a
ResultSet
to a string. - toString(Collection<T>) - Static method in class org.apache.calcite.sql.test.SqlAdvisorTest
-
Converts a list to a string, one item per line.
- toString(RelNode) - Method in class org.apache.calcite.tools.PlannerTest
- toStringList(Iterable<E>) - Static method in class org.apache.calcite.test.Matchers
- toStringList(ResultSet, Collection<String>) - Method in class org.apache.calcite.test.CalciteAssert.ResultSetFormatter
- toStringList(ResultSet, Collection<String>) - Static method in class org.apache.calcite.test.CalciteAssert
- total - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.PrintCommand
- totaled - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- toTimeFun(Long) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toTimestampFun(Long) - Static method in class org.apache.calcite.util.Smalls.AllTypesFunction
- toTrait - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitConverter
- toTrait - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTraitConverterRule
- tpcds() - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- TPCDS_MODEL - Static variable in class org.apache.calcite.adapter.tpcds.TpcdsTest
- TpcdsLatticeSuggesterTest - Class in org.apache.calcite.materialize
-
Unit tests for
LatticeSuggester
. - TpcdsLatticeSuggesterTest() - Constructor for class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest
- TpcdsLatticeSuggesterTest.Tester - Class in org.apache.calcite.materialize
-
Test helper.
- TpcdsTest - Class in org.apache.calcite.adapter.tpcds
-
Unit test for
TpcdsSchema
. - TpcdsTest() - Constructor for class org.apache.calcite.adapter.tpcds.TpcdsTest
- TPCH_MODEL - Static variable in class org.apache.calcite.adapter.tpch.TpchTest
- TpchSchema - Class in org.apache.calcite.tools
-
TPC-H table schema.
- TpchSchema() - Constructor for class org.apache.calcite.tools.TpchSchema
- TpchSchema.Part - Class in org.apache.calcite.tools
-
Part in TPC-H.
- TpchSchema.PartSupp - Class in org.apache.calcite.tools
-
Part supplier in TPC-H.
- TpchTest - Class in org.apache.calcite.adapter.tpch
-
Unit test for
TpchSchema
. - TpchTest() - Constructor for class org.apache.calcite.adapter.tpch.TpchTest
- trace(String) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- trace(String, Object) - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser
- TraitConversionTest - Class in org.apache.calcite.plan.volcano
-
Unit test for
RelDistributionTraitDef
. - TraitConversionTest() - Constructor for class org.apache.calcite.plan.volcano.TraitConversionTest
- TraitConversionTest.BridgeRel - Class in org.apache.calcite.plan.volcano
-
Bridges the
TraitConversionTest.SimpleDistribution
, difference betweenTraitConversionTest.SingletonLeafRel
andTraitConversionTest.RandomSingleRel
. - TraitConversionTest.ConvertRelDistributionTraitDef - Class in org.apache.calcite.plan.volcano
-
Dummy distribution trait def for test (handles conversion of SimpleDistribution)
- TraitConversionTest.NoneLeafRel - Class in org.apache.calcite.plan.volcano
-
Any distribution and none convention.
- TraitConversionTest.NoneSingleRel - Class in org.apache.calcite.plan.volcano
-
Rel with any distribution and none convention.
- TraitConversionTest.RandomSingleRel - Class in org.apache.calcite.plan.volcano
-
Rel with physical convention and random distribution.
- TraitConversionTest.RandomSingleTraitRule - Class in org.apache.calcite.plan.volcano
-
Converts a
TraitConversionTest.NoneSingleRel
(none convention, distribution any) toTraitConversionTest.RandomSingleRel
(physical convention, distribution random). - TraitConversionTest.SimpleDistribution - Class in org.apache.calcite.plan.volcano
-
Dummy distribution for test (simplified version of RelDistribution).
- TraitConversionTest.SingleLeafTraitRule - Class in org.apache.calcite.plan.volcano
-
Converts
TraitConversionTest.NoneLeafRel
(none convention, any distribution) toTraitConversionTest.SingletonLeafRel
(physical convention, singleton distribution). - TraitConversionTest.SingletonLeafRel - Class in org.apache.calcite.plan.volcano
-
Rel with singleton distribution, physical convention.
- traitDef - Variable in class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest.AltTrait
- TraitPropagationTest - Class in org.apache.calcite.plan.volcano
-
Tests that determine whether trait propagation work in Volcano Planner.
- TraitPropagationTest() - Constructor for class org.apache.calcite.plan.volcano.TraitPropagationTest
- TraitPropagationTest.Phys - Interface in org.apache.calcite.plan.volcano
-
Market interface for Phys nodes
- TraitPropagationTest.PhysAgg - Class in org.apache.calcite.plan.volcano
-
Physical Aggregate RelNode
- TraitPropagationTest.PhysAggRule - Class in org.apache.calcite.plan.volcano
-
Rule for PhysAgg
- TraitPropagationTest.PhysProj - Class in org.apache.calcite.plan.volcano
-
Physical Project RelNode
- TraitPropagationTest.PhysProjRule - Class in org.apache.calcite.plan.volcano
-
Rule for PhysProj
- TraitPropagationTest.PhysSort - Class in org.apache.calcite.plan.volcano
-
Physical Sort RelNode
- TraitPropagationTest.PhysSortRule - Class in org.apache.calcite.plan.volcano
-
Rule for PhysSort
- TraitPropagationTest.PhysTable - Class in org.apache.calcite.plan.volcano
-
Physical Table RelNode
- TraitPropagationTest.PhysTableRule - Class in org.apache.calcite.plan.volcano
-
Rule for PhysTable
- TraitPropagationTest.PropAction - Class in org.apache.calcite.plan.volcano
-
Materialized anonymous class for simplicity
- transformationResult - Variable in class org.apache.calcite.test.MockRelOptPlanner
- transforms - Variable in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- transforms - Variable in class org.apache.calcite.test.RelOptTestBase.Sql
- transformTo(RelNode, Map<RelNode, RelNode>) - Method in class org.apache.calcite.test.MockRelOptPlanner.MockRuleCall
- transitiveInference(RelOptRule...) - Method in class org.apache.calcite.test.RelOptRulesTest
- trim - Variable in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- trim(boolean) - Method in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- trimSpacesBoth(String) - Static method in class org.apache.calcite.test.SqlFunctionsTest
- trimStackTrace(Throwable, int) - Static method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- TRUE - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- TRUE_B - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- trueLiteral - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- trueRex - Variable in class org.apache.calcite.test.RexTransformerTest
- ts - Variable in class org.apache.calcite.test.JdbcTest.Event
- ts - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- ts(int, int, int) - Static method in class org.apache.calcite.test.StreamTest.OrdersStreamTableFactory
- tVarchar() - Method in class org.apache.calcite.test.RexProgramBuilderBase
- tVarchar(boolean) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- TWISSANDRA - Static variable in class org.apache.calcite.test.CassandraAdapterTest
-
Connection factory based on the "mongo-zips" model.
- TWO - Static variable in class org.apache.calcite.linq4j.test.BlockBuilderBase
- type - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueType
- type - Variable in class org.apache.calcite.test.catalog.CompoundNameColumn
- type - Variable in class org.apache.calcite.test.FoodMartQuerySet.FoodmartColumn
- type(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- typeFactory - Variable in class org.apache.calcite.adapter.druid.DruidQueryFilterTest.Fixture
- typeFactory - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.Builder
- typeFactory - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- typeFactory - Variable in class org.apache.calcite.sql.type.SqlTypeFixture
- typeFactory - Variable in class org.apache.calcite.test.MaterializationTest
- typeFactory - Variable in class org.apache.calcite.test.RexImplicationCheckerTest.Fixture
- typeFactory - Variable in class org.apache.calcite.test.RexProgramBuilderBase
- typeFactory - Variable in class org.apache.calcite.test.RexTransformerTest
- typeFactory - Variable in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema
- typeFactory - Variable in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- typeIs(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- typeName - Variable in class org.apache.calcite.sql.test.SqlTests.SqlTypeChecker
- types - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.Builder
- typeString(ResultSetMetaData) - Static method in class org.apache.calcite.test.CalciteAssert
- TypeTest - Class in org.apache.calcite.linq4j.tree
-
Test for
Types.gcd(java.lang.reflect.Type...)
. - TypeTest() - Constructor for class org.apache.calcite.linq4j.tree.TypeTest
U
- u2n(String) - Static method in class org.apache.calcite.test.QuidemTest
-
Converts a path from Unix to native.
- UdfTest - Class in org.apache.calcite.test
-
Tests for user-defined functions; includes user-defined aggregate functions but user-defined table functions are in
TableFunctionTest
. - UdfTest() - Constructor for class org.apache.calcite.test.UdfTest
- UdfTest.ArrayAppendDoubleFunction - Class in org.apache.calcite.test
-
Function with signature "f(ARRAY OF DOUBLE, INTEGER) returns ARRAY OF DOUBLE".
- UdfTest.ArrayAppendIntegerFunction - Class in org.apache.calcite.test
-
Function with signature "f(ARRAY OF INTEGER, INTEGER) returns ARRAY OF INTEGER".
- UdfTest.ArrayAppendScalarFunction - Class in org.apache.calcite.test
-
Base class for functions that append arrays.
- UdtTest - Class in org.apache.calcite.test
-
Tests for user-defined types.
- UdtTest() - Constructor for class org.apache.calcite.test.UdtTest
- UNARY_NUMERIC - Static variable in class org.apache.calcite.test.fuzzer.RexFuzzer
- unaryMinus(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- unaryPlus(RexNode) - Method in class org.apache.calcite.test.RexProgramBuilderBase
- UNION_TREE - Static variable in class org.apache.calcite.test.HepPlannerTest
- unknownAsString(RexUnknownAs) - Method in class org.apache.calcite.test.fuzzer.RexProgramFuzzyTest
- unnestMapMustNameColumnsKeyAndValueWhenNotAliased() - Method in class org.apache.calcite.test.SqlValidatorTest
- unordered(String...) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- UnparsingTesterImpl() - Constructor for class org.apache.calcite.sql.parser.SqlParserTest.UnparsingTesterImpl
- unquotedCasing - Variable in class org.apache.calcite.sql.parser.SqlParserTest
- unwrap(Class<C>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable.ModifiableTable
- unwrap(Class<C>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableView
- unwrap(Class<C>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable.ModifiableViewWithCustomColumnResolving
- unwrap(Class<C>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.WrapperTable
- unwrap(Class<T>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- unwrap(Class<T>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockTable
- unwrap(Class<T>) - Method in class org.apache.calcite.test.catalog.MockCatalogReader.MockViewTable
- unwrap(Class<T>) - Method in class org.apache.calcite.test.SqlToRelTestBase.DelegatingRelOptTable
- unwrap(Class<T>) - Method in class org.apache.calcite.test.SqlToRelTestBase.MockRelOptSchema.MockColumnSet
- update(String, String, String) - Method in class org.apache.calcite.test.DiffRepository
-
Creates a new document with a given resource.
- updates(int) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
- url - Variable in class org.apache.calcite.test.ConnectionSpec
- URL - Static variable in class org.apache.calcite.test.BabelTest
- URL - Static variable in class org.apache.calcite.test.ServerTest
- usage() - Static method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- useFongo() - Static method in class org.apache.calcite.test.MongoAssertions
-
Checks wherever tests should use Fongo instead of Mongo.
- useLockstep() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- useMongo() - Static method in class org.apache.calcite.test.MongoAssertions
-
Whether to run Mongo integration tests.
- user - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- username - Variable in class org.apache.calcite.test.ConnectionSpec
- UTC_DATE_FORMAT - Static variable in class org.apache.calcite.test.CalciteAssert
- UTC_TIME_FORMAT - Static variable in class org.apache.calcite.test.CalciteAssert
- UTC_TIMESTAMP_FORMAT - Static variable in class org.apache.calcite.test.CalciteAssert
- UTC_TZ - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- utilDate - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- UtilTest - Class in org.apache.calcite.util
-
Unit test for
Util
and other classes in this package. - UtilTest() - Constructor for class org.apache.calcite.util.UtilTest
V
- v - Variable in class org.apache.calcite.test.CsvTest.Worker
-
Value returned by the most recent command.
- val - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser.Binding
- VALIDATE - org.apache.calcite.sql.test.SqlTests.Stage
- validateFeature(Feature, SqlParserPos) - Method in class org.apache.calcite.test.SqlValidatorFeatureTest.FeatureValidator
- validatorFactory - Variable in class org.apache.calcite.sql.test.SqlTestFactory
- value - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueType
- value - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.IntAndString
- value - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.IntHolder
- value() - Method in annotation type org.apache.calcite.test.WithLex
- valueOf(String) - Static method in enum org.apache.calcite.linq4j.test.ExpressionTest.MyEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.test.SqlTester.VmName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.sql.test.SqlTests.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.test.CalciteAssert.Config
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
-
Returns the enum constant of this type with the specified name.
- ValueOrExceptionResultChecker(Object, Pattern...) - Constructor for class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueOrExceptionResultChecker
- values - Variable in class org.apache.calcite.rex.RexExecutorTest.TestDataContext
- values - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.Builder
- values - Variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest.OverlapChecker
- values() - Static method in enum org.apache.calcite.linq4j.test.ExpressionTest.MyEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.test.SqlTester.VmName
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.sql.test.SqlTests.Stage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.test.CalciteAssert.Config
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.test.CalciteAssert.DatabaseInstance
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.calcite.test.CalciteAssert.SchemaSpec
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values(Class) - Static method in class org.apache.calcite.jdbc.CalciteRemoteDriverTest
- VALUES0 - Static variable in class org.apache.calcite.test.SparkAdapterTest
- VALUES1 - Static variable in class org.apache.calcite.test.SparkAdapterTest
- VALUES2 - Static variable in class org.apache.calcite.test.SparkAdapterTest
- VALUES3 - Static variable in class org.apache.calcite.test.SparkAdapterTest
- VALUES4 - Static variable in class org.apache.calcite.test.SparkAdapterTest
- ValueType(RelDataType, Object) - Constructor for class org.apache.calcite.sql.test.SqlOperatorBaseTest.ValueType
- var - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.CommandParser.Binding
- VAR - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- VAR_LEN - Static variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- VARCHAR_TYPE - Static variable in class org.apache.calcite.test.DruidAdapterIT
- VARCHAR_TYPE - Static variable in class org.apache.calcite.test.DruidAdapterIT2
- varchar10Type - Variable in class org.apache.calcite.test.catalog.Fixture
- varchar10TypeNull - Variable in class org.apache.calcite.test.catalog.Fixture
- varchar20Type - Variable in class org.apache.calcite.test.catalog.Fixture
- varchar20TypeNull - Variable in class org.apache.calcite.test.catalog.Fixture
- varcharRowType - Variable in class org.apache.calcite.adapter.druid.DruidQueryFilterTest.Fixture
- varcharType - Variable in class org.apache.calcite.adapter.druid.DruidQueryFilterTest.Fixture
- VariableTable() - Constructor for class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.VariableTable
- vars - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- vBool() - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
nullable boolean variable
with index of 0. - vBool(int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
nullable boolean variable
with index ofarg
(0-based). - vBoolNotNull() - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
non-nullable boolean variable
with index of 0. - vBoolNotNull(int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
non-nullable boolean variable
with index ofarg
(0-based). - verbose - Variable in class org.apache.calcite.examples.RelBuilderExample
- verbose - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.Tool
- verbose - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript
- verbose - Variable in class org.apache.calcite.test.DiffTestCase
-
Whether to give verbose message if diff fails.
- versions() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticsearchVersionTest
- view() - Method in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
-
Tests using calcite view
- view(String) - Method in class org.apache.calcite.test.JdbcTest.HrSchema
- view(String) - Method in class org.apache.calcite.test.MaterializationTest.HrFKUKSchema
- view(String) - Static method in class org.apache.calcite.util.Smalls
- VIEW_METHOD - Static variable in class org.apache.calcite.util.Smalls
- viewMacro(CalciteSchema, String, List<String>, List<String>, Boolean) - Static method in class org.apache.calcite.test.catalog.MockCatalogReader.MockModifiableViewRelOptTable
- vInt() - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
nullable int variable
with index of 0. - vInt(int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
nullable int variable
with index ofarg
(0-based). - vIntNotNull() - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
non-nullable int variable
with index of 0. - vIntNotNull(int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
non-nullable int variable
with index ofarg
(0-based). - visit(Integer) - Method in class org.apache.calcite.util.ReflectVisitorTest.CarefulNumberNegater
- visit(Number) - Method in class org.apache.calcite.util.ReflectVisitorTest.CarelessNumberNegater
- visit(Object) - Method in class org.apache.calcite.util.ReflectVisitorTest.CluelessNumberNegater
- visit(Short) - Method in class org.apache.calcite.util.ReflectVisitorTest.CarefulNumberNegater
- visit(Short) - Method in class org.apache.calcite.util.ReflectVisitorTest.CluelessNumberNegater
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.test.MaterializationTest.TableNameVisitor
- visit(RelNode, int, RelNode) - Method in class org.apache.calcite.test.SqlToRelConverterTest.RelValidityChecker
- visit(ReflectVisitorTest.AmbiguousNumber) - Method in class org.apache.calcite.util.ReflectVisitorTest.SomewhatIndecisiveNumberNegater
- visit(ReflectVisitorTest.CrunchableNumber) - Method in class org.apache.calcite.util.ReflectVisitorTest.IndecisiveNumberNegater
- visit(ReflectVisitorTest.FudgeableNumber) - Method in class org.apache.calcite.util.ReflectVisitorTest.IndecisiveNumberNegater
- visit(ReflectVisitorTest.FudgeableNumber) - Method in class org.apache.calcite.util.ReflectVisitorTest.SomewhatIndecisiveNumberNegater
- visitCall(RexCall) - Method in class org.apache.calcite.test.fuzzer.RexToTestCodeShuttle
- visitFieldAccess(RexFieldAccess) - Method in class org.apache.calcite.test.fuzzer.RexToTestCodeShuttle
- visitLiteral(RexLiteral) - Method in class org.apache.calcite.test.fuzzer.RexToTestCodeShuttle
- VM_EXPAND - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- VM_FENNEL - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- VM_JAVA - Static variable in class org.apache.calcite.sql.test.SqlOperatorBaseTest
- VmName() - Constructor for enum org.apache.calcite.sql.test.SqlTester.VmName
- VolcanoPlannerTest - Class in org.apache.calcite.plan.volcano
-
Unit test for
the optimizer
. - VolcanoPlannerTest() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTest
- VolcanoPlannerTest.GoodRemoveSingleRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that successfully removes a
PlannerTests.PhysSingleRel
. - VolcanoPlannerTest.PhysProjectRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that converts a
LogicalProject
to PHYS convention. - VolcanoPlannerTest.PhysToIteratorConverter - Class in org.apache.calcite.plan.volcano
-
Converter from PHYS to ENUMERABLE convention.
- VolcanoPlannerTest.ReformedRemoveSingleRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that removes a
PlannerTests.NoneSingleRel
. - VolcanoPlannerTest.ReformedSingleRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that matches a
PlannerTests.NoneSingleRel
whose input is aPlannerTests.PhysLeafRel
in a different subset. - VolcanoPlannerTest.SubsetRule - Class in org.apache.calcite.plan.volcano
-
Rule that matches a
RelSubset
. - VolcanoPlannerTest.TestListener - Class in org.apache.calcite.plan.volcano
-
Implementation of
RelOptListener
. - VolcanoPlannerTraitTest - Class in org.apache.calcite.plan.volcano
-
Unit test for handling of traits by
VolcanoPlanner
. - VolcanoPlannerTraitTest() - Constructor for class org.apache.calcite.plan.volcano.VolcanoPlannerTraitTest
- VolcanoPlannerTraitTest.AltTrait - Class in org.apache.calcite.plan.volcano
-
Implementation of
RelTrait
for testing. - VolcanoPlannerTraitTest.AltTraitConverter - Class in org.apache.calcite.plan.volcano
-
Relational expression that converts between
VolcanoPlannerTraitTest.AltTrait
values. - VolcanoPlannerTraitTest.AltTraitConverterRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that converts between
VolcanoPlannerTraitTest.AltTrait
s. - VolcanoPlannerTraitTest.AltTraitDef - Class in org.apache.calcite.plan.volcano
-
Definition of
VolcanoPlannerTraitTest.AltTrait
. - VolcanoPlannerTraitTest.FooRel - Interface in org.apache.calcite.plan.volcano
-
A mix-in interface to extend
RelNode
, for testing. - VolcanoPlannerTraitTest.IterMergedRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with no inputs, that implements the
VolcanoPlannerTraitTest.FooRel
mix-in interface. - VolcanoPlannerTraitTest.IterSinglePhysMergeRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that converts an
VolcanoPlannerTraitTest.IterSingleRel
on aVolcanoPlannerTraitTest.PhysToIteratorConverter
into aVolcanoPlannerTraitTest.IterMergedRel
. - VolcanoPlannerTraitTest.IterSingleRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with one input, that implements the
VolcanoPlannerTraitTest.FooRel
mix-in interface. - VolcanoPlannerTraitTest.IterSingleRule - Class in org.apache.calcite.plan.volcano
-
Planner rule to convert a
VolcanoPlannerTraitTest.NoneSingleRel
to ENUMERABLE convention. - VolcanoPlannerTraitTest.IterSingleRule2 - Class in org.apache.calcite.plan.volcano
-
Another planner rule to convert a
VolcanoPlannerTraitTest.NoneSingleRel
to ENUMERABLE convention. - VolcanoPlannerTraitTest.NoneLeafRel - Class in org.apache.calcite.plan.volcano
-
A relational expression with zero inputs, of NONE convention.
- VolcanoPlannerTraitTest.NoneSingleRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with one input, of NONE convention.
- VolcanoPlannerTraitTest.PhysLeafRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with zero inputs, of PHYS convention.
- VolcanoPlannerTraitTest.PhysLeafRule - Class in org.apache.calcite.plan.volcano
-
Relational expression with zero inputs, of the PHYS convention.
- VolcanoPlannerTraitTest.PhysToIteratorConverter - Class in org.apache.calcite.plan.volcano
-
Planner rule that converts PHYS to ENUMERABLE convention.
- VolcanoPlannerTraitTest.PhysToIteratorConverterRule - Class in org.apache.calcite.plan.volcano
-
Planner rule that converts from PHYS to ENUMERABLE convention.
- VolcanoPlannerTraitTest.TestLeafRel - Class in org.apache.calcite.plan.volcano
-
A relational expression with zero inputs.
- VolcanoPlannerTraitTest.TestSingleRel - Class in org.apache.calcite.plan.volcano
-
Relational expression with one input.
- vVarchar() - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
nullable varchar variable
with index of 0. - vVarchar(int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
nullable varchar variable
with index ofarg
(0-based). - vVarcharNotNull() - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
non-nullable varchar variable
with index of 0. - vVarcharNotNull(int) - Method in class org.apache.calcite.test.RexProgramBuilderBase
-
Creates
non-nullable varchar variable
with index ofarg
(0-based).
W
- waitForOthers() - Method in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor.Sync
- when - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandExecutor
-
Location of
ConcurrentTestCommandExecutor.error
. - where(Predicate<Profiler.Statistic>) - Method in class org.apache.calcite.profile.ProfilerTest.Fluid
- WHERE_KEYWORDS - Static variable in class org.apache.calcite.sql.test.SqlAdvisorTest
- WideProductSale(int, double) - Constructor for class org.apache.calcite.util.Smalls.WideProductSale
- WideSaleSchema() - Constructor for class org.apache.calcite.util.Smalls.WideSaleSchema
- widths - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.ResultsReader
- WIKI - Static variable in class org.apache.calcite.test.DruidAdapterIT
-
URL of the "druid-wiki" model and the "wikiticker" data set.
- WIKI_AUTO - Static variable in class org.apache.calcite.test.DruidAdapterIT
-
URL of the "druid-wiki-no-columns" model and the "wikiticker" data set.
- WIKI_AUTO2 - Static variable in class org.apache.calcite.test.DruidAdapterIT
-
URL of the "druid-wiki-no-tables" model and the "wikiticker" data set.
- wikiApprox(String) - Method in class org.apache.calcite.test.DruidAdapterIT
-
Creates a query against WIKI with approximate parameters
- win(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- winExp(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- winExp2(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- winSql(String) - Method in class org.apache.calcite.test.SqlValidatorTestCase
- with() - Method in class org.apache.calcite.adapter.tpcds.TpcdsTest
- with() - Method in class org.apache.calcite.adapter.tpch.TpchTest
- with() - Method in class org.apache.calcite.test.TableFunctionTest
- with(boolean) - Method in class org.apache.calcite.adapter.tpch.TpchTest
- with(String, Object) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- with(String, Object) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- with(String, Object) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(String, Object) - Method in class org.apache.calcite.test.CalciteAssert.ConnectionFactory
- with(String, Object) - Method in class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- with(Map<String, String>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(ConnectionProperty, Object) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(ConnectionProperty, Object) - Method in class org.apache.calcite.test.CalciteAssert.ConnectionFactory
- with(ConnectionProperty, Object) - Method in class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- with(Lex) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Sets Lex property
- with(HepPlanner) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- with(HepProgram) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- with(SqlTestFactory) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- with(SqlTestFactory) - Method in class org.apache.calcite.sql.test.SqlOperatorBaseTest.TesterImpl
- with(SqlTestFactory) - Method in class org.apache.calcite.sql.test.SqlRuntimeTester
- with(SqlTestFactory) - Method in class org.apache.calcite.sql.test.SqlValidatorTester
- with(CalciteAssert.Config) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(CalciteAssert.ConnectionFactory) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a copy of this AssertThat, overriding the connection factory.
- with(CalciteAssert.ConnectionPostProcessor) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- with(CalciteAssert.ConnectionPostProcessor) - Method in class org.apache.calcite.test.CalciteAssert.ConnectionFactory
- with(CalciteAssert.ConnectionPostProcessor) - Method in class org.apache.calcite.test.CalciteAssert.MapConnectionFactory
- with(CalciteAssert.SchemaSpec...) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Creates a copy of this AssertThat, adding more schemas
- with(SqlToRelTestBase.Tester) - Method in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- withBadUdf(Class) - Static method in class org.apache.calcite.test.UdfTest
- withCaseSensitive(boolean) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- withCaseSensitive(boolean) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns a tester that matches identifiers by case-sensitive or case-insensitive.
- withCatalogReader(SqlTestFactory.MockCatalogReaderFactory) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withCatalogReaderFactory(SqlTestFactory.MockCatalogReaderFactory) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
- withCatalogReaderFactory(SqlTestFactory.MockCatalogReaderFactory) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withClusterFactory(Function<RelOptCluster, RelOptCluster>) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
- withClusterFactory(Function<RelOptCluster, RelOptCluster>) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withConfig(SqlToRelConverter.Config) - Method in class org.apache.calcite.test.SqlToRelConverterTest.Sql
- withConfig(SqlToRelConverter.Config) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns a tester that optionally uses a
SqlToRelConverter.Config
. - withConfig(SqlToRelConverter.Config) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withConfig(FrameworkConfig) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- withConfig(FrameworkConfig) - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- withConformance(SqlConformance) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- withConformance(SqlConformance) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns a tester that tests conformance to a particular SQL language version.
- withConformance(SqlConformance) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns a tester with a
SqlConformance
. - withConformance(SqlConformance) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withConnection(Consumer<Connection>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Performs an action using a connection, and closes the connection afterwards.
- withConnectionFactory(CalciteAssert.ConnectionFactory) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- withConnectionFactory(CalciteAssert.ConnectionFactory) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns a tester that gets connections from a given factory.
- withContext(Context) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- withContext(Context) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns a tester that uses a given context.
- withContext(Context) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withDb2() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- withDecorrelation(boolean) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- withDecorrelation(boolean) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns a tester that optionally decorrelates queries.
- withDecorrelation(boolean) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withDefaultSchema(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Sets the default schema of the connection.
- withEmpDept(String) - Method in class org.apache.calcite.test.JdbcTest
- withEvolve(boolean) - Method in class org.apache.calcite.materialize.LatticeSuggesterTest.Tester
- withEvolve(boolean) - Method in class org.apache.calcite.materialize.TpcdsLatticeSuggesterTest.Tester
- withExpand(boolean) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns a tester that optionally expands sub-queries.
- withExpand(boolean) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withExtendedCatalog() - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- withExtendedCatalog2003() - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- withExtendedCatalogLenient() - Method in class org.apache.calcite.test.SqlValidatorTestCase.Sql
- withFoodMartQuery(int) - Method in class org.apache.calcite.test.JdbcTest
- withHive() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- withHook(Hook, Function<T, Void>) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
-
Deprecated.
- withHook(Hook, Consumer<T>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Adds a hook and a handler for that hook.
- withHook(Hook, Consumer<T>) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
-
Adds a hook and a handler for that hook.
- withHook(Hook, Function<T, Void>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Deprecated.
- withHsqldb() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- within(T, double) - Static method in class org.apache.calcite.test.Matchers
-
Creates a matcher that matches when the examined object is within
epsilon
of the specifiedoperand
. - withLateDecorrelation(boolean) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- withLateDecorrelation(boolean) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns a tester that optionally decorrelates queries after planner rules have fired.
- withLateDecorrelation(boolean) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withLex(Lex) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- withLex(Lex) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns a tester that follows a lex policy.
- WithLex - Annotation Type in org.apache.calcite.test
-
Annotation that indicates that test method should be run with given lex configuration.
- withMaterializations(String, boolean, String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Adds materializations to the schema.
- withMaterializations(String, String...) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- withMaterializations(String, Function<JsonBuilder, List<Object>>) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Adds materializations to the schema.
- withModel(String) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- withModel(URL) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
- withMssql() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- withMysql() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- withOperatorTable(SqlOperatorTable) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- withOperatorTable(SqlOperatorTable) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns a tester that uses a given operator table.
- withOracle() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- withPostgresql() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- withPostgresqlModifiedTypeSystem() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- withPre(HepProgram) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- withProperty(Hook, V) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Adds a property hook.
- withProperty(Hook, V) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- withQuotedCasing(Casing) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- withQuotedCasing(Casing) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns a tester that applies a given casing policy to quoted identifiers.
- withQuoting(Quoting) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- withQuoting(Quoting) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns a tester that tests a given SQL quoting style.
- withRel(Function<RelBuilder, RelNode>) - Method in class org.apache.calcite.test.CalciteAssert.AssertQuery
-
Adds a factory to create a
RelNode
query. - withRule(RelOptRule) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- withSchema(String, Schema) - Method in class org.apache.calcite.test.CalciteAssert.AssertThat
-
Sets the default schema to a given schema.
- withTransform(Function<SqlToRelTestBase.Tester, SqlToRelTestBase.Tester>) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
-
Adds a transform that will be applied to
SqlToRelTestBase.tester
just before running the query. - withTrim(boolean) - Method in class org.apache.calcite.test.RelOptTestBase.Sql
- withTrim(boolean) - Method in interface org.apache.calcite.test.SqlToRelTestBase.Tester
-
Returns a tester that optionally trims unused fields.
- withTrim(boolean) - Method in class org.apache.calcite.test.SqlToRelTestBase.TesterImpl
- withUdf() - Method in class org.apache.calcite.test.UdfTest
- withUdt() - Method in class org.apache.calcite.test.UdtTest
- withUnquotedCasing(Casing) - Method in class org.apache.calcite.sql.test.AbstractSqlTester
- withUnquotedCasing(Casing) - Method in interface org.apache.calcite.sql.test.SqlTester
-
Returns a tester that applies a given casing policy to unquoted identifiers.
- withValidator(SqlTestFactory.ValidatorFactory) - Method in class org.apache.calcite.sql.test.SqlTestFactory
- withVertica() - Method in class org.apache.calcite.rel.rel2sql.RelToSqlConverterTest.Sql
- Worker() - Constructor for class org.apache.calcite.test.CsvTest.Worker
- wrapperBoolean - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- wrapperByte - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- wrapperCharacter - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- wrapperDouble - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- wrapperFloat - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- wrapperInteger - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- wrapperLong - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- wrapperShort - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.EveryType
- WrapperTable(MockCatalogReader.MockTable) - Constructor for class org.apache.calcite.test.catalog.MockCatalogReader.WrapperTable
- write(Document, Writer, int) - Static method in class org.apache.calcite.test.DiffRepository
-
Serializes an XML document as text.
- writeLine(PrintWriter, String) - Method in class org.apache.calcite.test.CsvTest
-
Creates a command that appends a line to the CSV file.
- writeNode(Node, XmlOutput) - Static method in class org.apache.calcite.test.DiffRepository
- writer - Variable in class org.apache.calcite.test.CalciteHandler
X
- x - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.StateDatum
- x - Variable in class org.apache.calcite.test.JdbcTest.Location
- x - Variable in class org.apache.calcite.test.ReflectiveSchemaTest.AllPrivate
- x - Variable in class org.apache.calcite.test.RexTransformerTest
- X - org.apache.calcite.linq4j.test.ExpressionTest.MyEnum
- xAndNotX() - Method in class org.apache.calcite.test.RexProgramTest
- XX - Static variable in class org.apache.calcite.plan.RelWriterTest
Y
- y - Variable in class org.apache.calcite.linq4j.test.ExpressionTest.AllType
- y - Variable in class org.apache.calcite.test.concurrent.ConcurrentTestCommandScript.StateDatum
- y - Variable in class org.apache.calcite.test.JdbcTest.Location
- y - Variable in class org.apache.calcite.test.RexTransformerTest
- Y - org.apache.calcite.linq4j.test.ExpressionTest.MyEnum
Z
- z - Variable in class org.apache.calcite.test.RexTransformerTest
- ZIPS - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
-
Default index/type name
- ZIPS_SIZE - Static variable in class org.apache.calcite.adapter.elasticsearch.ElasticSearchAdapterTest
- ZIPS_SIZE - Static variable in class org.apache.calcite.adapter.mongodb.MongoAdapterTest
-
Number of records in local file
_
- _testCharsetAndCollateMismatch() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testConvertAndTranslate() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testDyadicCollateCompare() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testDyadicCollateOperator() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testDyadicCompareCollateFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testGroupExpressionEquivalenceCorrelated() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testGroupExpressionEquivalenceParams() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testJoinUsing() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testLikeAndSimilarFails() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testSimpleCollate() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testValuesWithAggFuncs() - Method in class org.apache.calcite.test.SqlValidatorTest
- _testWinPartClause() - Method in class org.apache.calcite.test.SqlValidatorTest
All Classes All Packages