All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractGeodeTest |
Base class that allows sharing same geode instance across all tests.
|
AbstractPigTest |
Common methods inheritable by all Pig-specific test classes.
|
AbstractSqlTester |
|
AggregationTest |
Testing Elasticsearch aggregation transformations.
|
ArrayTableTest |
Unit test for ArrayTable and ColumnLoader .
|
BabelParserTest |
Tests the "Babel" SQL parser, that understands all dialects of SQL.
|
BabelQuidemTest |
Unit tests for the Babel SQL parser.
|
BabelQuidemTest.BabelCommandHandler |
|
BabelQuidemTest.ExplainValidatedCommand |
Command that prints the validated parse tree of a SQL statement.
|
BabelTest |
Unit tests for Babel framework.
|
BinarySearchTest |
Tests BinarySearch .
|
BitSetsTest |
Unit test for BitSets .
|
BlockBuilderBase |
Base methods and constant for simplified Expression testing
|
BlockBuilderTest |
Tests BlockBuilder.
|
BlockBuilderTest.Identity<I> |
Class with generics to validate if Expressions.call(Method, Expression...) works.
|
BookMasterRegionTest |
|
BookstoreSchema |
A Schema representing a bookstore.
|
BookstoreSchema.Author |
|
BookstoreSchema.Book |
|
BookstoreSchema.Coordinate |
|
BookstoreSchema.Page |
|
BookstoreSchema.Place |
|
BooleanLogicTest |
Test of different boolean expressions (some more complex than others).
|
CalciteAssert |
Fluid DSL for testing Calcite connections and queries.
|
CalciteAssert.AddSchemaPostProcessor |
Adds Schema and sets it as default.
|
CalciteAssert.AddSchemaSpecPostProcessor |
|
CalciteAssert.AssertMetaData |
Fluent interface for building a metadata query to be tested.
|
CalciteAssert.AssertQuery |
Fluent interface for building a query to be tested.
|
CalciteAssert.AssertThat |
|
CalciteAssert.Config |
Connection configuration.
|
CalciteAssert.ConnectionFactory |
Abstract implementation of connection factory whose with
methods throw.
|
CalciteAssert.ConnectionPostProcessor |
Connection post processor
|
CalciteAssert.DatabaseInstance |
Information necessary to create a JDBC connection.
|
CalciteAssert.DefaultSchemaPostProcessor |
Sets a default schema name.
|
CalciteAssert.MapConnectionFactory |
Connection factory that uses a given map of (name, value) pairs and
optionally an initial schema.
|
CalciteAssert.NopAssertQuery |
|
CalciteAssert.PoolingConnectionFactory |
Connection factory that uses the same instance of connections.
|
CalciteAssert.PreparedStatementConsumer |
We want a consumer which can throw SqlException
|
CalciteAssert.PropBuilder |
Builds a Properties containing connection property
settings.
|
CalciteAssert.ResultSetFormatter |
Converts a ResultSet to string.
|
CalciteAssert.SchemaSpec |
Specification for common test schemas.
|
CalciteHandler |
Extension to Handler that can execute
commands using Calcite.
|
CalciteRemoteDriverTest |
Test for Calcite's remote JDBC driver.
|
CalciteRemoteDriverTest.Factory |
Factory that creates a Meta that can see the test databases.
|
CalciteRemoteDriverTest.Factory2 |
Factory that creates a LocalJsonService .
|
CalciteRemoteDriverTest.LocalServiceModifiableFactory |
Factory that creates a Service with connection to a modifiable table.
|
CalciteRemoteDriverTest.LocalServiceMoreFactory |
Service factory that creates a Calcite instance with more data.
|
CalciteResourceTest |
Tests the generated implementation of
CalciteResource (mostly a sanity check for
the resource-generation infrastructure).
|
CalciteSqlOperatorTest |
Embodiment of SqlOperatorBaseTest
that generates SQL statements and executes them using Calcite.
|
CalciteSuite |
Calcite test suite.
|
CassandraAdapterTest |
Tests for the org.apache.calcite.adapter.cassandra package.
|
ChunkListTest |
Unit and performance test for ChunkList .
|
CollationConversionTest |
Unit test for RelCollationTraitDef .
|
CollationConversionTest.NoneSingleRel |
A single-input node with none convention and LEAF_COLLATION trait.
|
CollationConversionTest.PhysicalSort |
Physical sort node (not logical).
|
CollationConversionTest.TestRelCollationImpl |
Dummy collation trait implementation for the test.
|
CollationConversionTest.TestRelCollationTraitDef |
|
CollectionTypeTest |
|
CollectionTypeTest.NestedCollectionTable |
Table that returns columns which include complicated collection type via the ScannableTable
interface.
|
CollectionTypeTest.NestedCollectionWithAnyTypeTable |
Table that returns columns which include complicated collection type via the ScannableTable
interface.
|
ComboRuleTest |
Unit test for VolcanoPlanner
|
ComboRuleTest.AddIntermediateNodeRule |
|
ComboRuleTest.ComboRule |
|
ComboRuleTest.IntermediateNode |
Intermediate node, the cost decreases as it is pushed up the tree
(more inputs it has, cheaper it gets).
|
CompoundNameColumn |
Column having names with multiple parts.
|
CompoundNameColumnResolver |
ColumnResolver implementation that resolves CompoundNameColumn by simulating
Phoenix behaviors.
|
ConcurrentTestCommand |
|
ConcurrentTestCommand.ShouldHaveFailedException |
Indicates that a command should have failed, but instead succeeded, which
is a test error
|
ConcurrentTestCommandExecutor |
ConcurrentTestCommandExecutor is a thread that executes a sequence of
commands on a JDBC connection.
|
ConcurrentTestCommandExecutor.Sync |
Synchronization object that allows multiple
ConcurrentTestCommandExecutors to execute commands in lock-step.
|
ConcurrentTestCommandGenerator |
|
ConcurrentTestCommandGenerator.AbstractCommand |
abstract base to handle SQLExceptions
|
ConcurrentTestCommandGenerator.AutoSynchronizationCommand |
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 |
CloseCommand closes a previously prepared statement.
|
ConcurrentTestCommandGenerator.CommandWithTimeout |
Command that executes statements with a given timeout.
|
ConcurrentTestCommandGenerator.CommitCommand |
CommitCommand commits pending transactions via
Connection.commit() .
|
ConcurrentTestCommandGenerator.DdlCommand |
DdlCommand executes DDL commands.
|
ConcurrentTestCommandGenerator.ExplainCommand |
ExplainCommand executes explain plan commands.
|
ConcurrentTestCommandGenerator.FailedThread |
Describes a thread that failed
|
ConcurrentTestCommandGenerator.FetchAndCompareCommand |
FetchAndCompareCommand executes a previously prepared statement stored in
the ConcurrentTestCommandExecutor and then validates the returned
rows against expected data.
|
ConcurrentTestCommandGenerator.InsertCommand |
InsertCommand exeutes an insert, update or delete SQL statement.
|
ConcurrentTestCommandGenerator.PrepareCommand |
PrepareCommand creates a PreparedStatement .
|
ConcurrentTestCommandGenerator.RollbackCommand |
RollbackCommand rolls back pending transactions via
Connection.rollback() .
|
ConcurrentTestCommandGenerator.SleepCommand |
SleepCommand causes the execution thread to wait for all other threads in
the test before continuing.
|
ConcurrentTestCommandGenerator.SynchronizationCommand |
SynchronizationCommand causes the execution thread to wait for all other
threads in the test before continuing.
|
ConcurrentTestCommandScript |
|
ConcurrentTestCommandScript.CommandWithTimeout |
Command that has a timeout.
|
ConcurrentTestCommandScript.CommandWithTimeoutAndRowLimit |
Command with timeout and row limit.
|
ConcurrentTestCommandScript.StateAction |
State action.
|
ConcurrentTestCommandScript.StateDatum |
State datum.
|
ConcurrentTestCommandScript.Tool |
Standalone client test tool.
|
ConcurrentTestPlugin |
Used to extend functionality of mtsql.
|
ConcurrentTestPluginCommand |
Used to extend functionality of mtsql.
|
ConcurrentTestPluginCommand.TestContext |
Test context.
|
ConcurrentTestTimedCommandGenerator |
ConcurrentTestTimedCommandGenerator extends
ConcurrentTestCommandGenerator and repeats the configured command
sequence until a certain amount of time has elapsed.
|
ConnectionSpec |
Information necessary to create a JDBC connection.
|
CoreQuidemTest |
Test that runs every Quidem file in the "core" module as a test.
|
CorrelateJoinTest |
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>)
|
CountingFactory |
To check whether
InitializerExpressionFactory.newColumnDefaultValue(org.apache.calcite.plan.RelOptTable, int, org.apache.calcite.sql2rel.InitializerContext) is called.
|
CountriesTableFunction |
A table function that returns all countries in the world.
|
CsvTest |
Unit test of the Calcite adapter for CSV.
|
CsvTest.Worker<E> |
Receives commands on a queue and executes them on its own thread.
|
DateRangeRulesTest |
Unit tests for DateRangeRules algorithms.
|
DateRangeRulesTest.Fixture2 |
Common expressions across tests.
|
DeterministicTest |
Tests factoring out deterministic expressions.
|
DeterministicTest.TestClass |
Class to test @Deterministic annotation
|
DeterministicTest.TestDeterministicClass |
Class to test @NonDeterministic annotation
|
DiffRepository |
A collection of resources used by tests.
|
DiffRepository.Filter |
Callback to filter strings before returning them.
|
DiffTestCase |
DiffTestCase is an abstract base for JUnit tests which produce multi-line
output to be verified by diffing against a pre-existing reference file.
|
DirectedGraphTest |
Unit test for DirectedGraph .
|
DirectedGraphTest.DefaultAttributedEdge |
Edge that stores its attributes in a list.
|
DirectedGraphTest.DefaultAttributedEdgeFactory |
|
DruidAdapterIT |
Tests for the org.apache.calcite.adapter.druid package.
|
DruidAdapterIT2 |
Tests for the org.apache.calcite.adapter.druid package.
|
DruidDateRangeRulesTest |
Unit tests for DateRangeRules algorithms.
|
DruidDateRangeRulesTest.Fixture2 |
Common expressions across tests.
|
DruidQueryFilterTest |
Tests generating Druid filters.
|
DruidQueryFilterTest.Fixture |
Everything a test needs for a healthy, active life.
|
ElasticSearchAdapterTest |
Set of tests for ES adapter.
|
ElasticsearchChecker |
Internal util methods for ElasticSearch tests
|
ElasticsearchJsonTest |
Testing correct parsing of JSON (elasticsearch) response.
|
ElasticsearchVersionTest |
Basic tests for parsing ES version in different formats
|
EmbeddedElasticsearchNode |
Represents a single elastic search node which can run embedded in a java application.
|
EmbeddedElasticsearchNode.LocalNode |
Having separate class to expose (protected) constructor which allows to install
different plugins.
|
EmbeddedElasticsearchPolicy |
Used to initialize a single elastic node.
|
EmpInitializerExpressionFactory |
Default values for the "EMPDEFAULTS" table.
|
EndToEndTest |
Entry point for all end-to-end tests based on Chinook data in HSQLDB wrapped
by Calcite schema.
|
EnumerableCorrelateTest |
Unit test for
EnumerableCorrelate .
|
EnumerablesTest |
Unit tests for Enumerables .
|
EnumerablesTest.Dept |
Department record.
|
EnumerablesTest.Emp |
Employee record.
|
ExampleFunctionTest |
Unit tests for example user-defined functions.
|
ExceptionMessageTest |
Test cases to check that necessary information from underlying exceptions
is correctly propagated via SQLException s.
|
ExceptionMessageTest.Entry |
Entries made available in the reflective TestSchema.
|
ExceptionMessageTest.TestSchema |
Simple reflective schema that provides valid and invalid entries.
|
ExpressionTest |
Unit test for Expression
and subclasses.
|
ExpressionTest.AllType |
A class with a field for each type of interest.
|
ExpressionTest.MyEnum |
An enum.
|
FileReaderTest |
Unit tests for FileReader.
|
FileSuite |
Unit test suite for Calcite File adapter.
|
FilteratorTest |
Unit test for Filterator .
|
Fixture |
Types used during initialization.
|
Fluent |
Fluent API to perform Piglet test actions.
|
FoodMartLatticeStatisticProvider |
Implementation of LatticeStatisticProvider
that has hard-coded values for various attributes in the FoodMart lattice.
|
FoodMartQuerySet |
Set of queries against the FoodMart database.
|
FoodMartQuerySet.FoodmartColumn |
JSON column element.
|
FoodMartQuerySet.FoodmartQuery |
JSON query element.
|
FoodMartQuerySet.FoodmartRoot |
JSON root element.
|
FoodmartTest |
Test case that runs the FoodMart reference queries.
|
FrameworksTest |
Unit tests for methods in Frameworks .
|
FrameworksTest.HiveLikeTypeSystem |
Dummy type system, similar to Hive's, accessed via an INSTANCE member.
|
FrameworksTest.HiveLikeTypeSystem2 |
Dummy type system, similar to Hive's, accessed via a public default
constructor.
|
FrameworksTest.TableImpl |
Modifiable, filterable table.
|
FunctionTest |
Test for Functions .
|
GeodeAllDataTypesTest |
Test with different types of data like boolean, time, timestamp
|
GeodeAssertions |
Various validations for geode tests.
|
GeodeBookstoreTest |
Tests using Bookshop schema.
|
GeodeEmbeddedPolicy |
Manages embedded Geode instance using native ServerLauncher .
|
GeodeEmbeddedPolicy.RefCountPolicy |
Calls before() and after() methods only once (for first and last subscriber
respectively).
|
GeodeZipsTest |
Tests based on zips-min.json dataset.
|
HepPlannerTest |
HepPlannerTest is a unit test for HepPlanner .
|
ImmutableBitSetTest |
Unit test for ImmutableBitSet .
|
InduceGroupingTypeTest |
Unit test for
Aggregate.Group.induce(ImmutableBitSet, List) .
|
InlinerTest |
Tests expression inlining in BlockBuilder.
|
InterpreterTest |
Unit tests for Interpreter .
|
JdbcAdapterTest |
Tests for the org.apache.calcite.adapter.jdbc package.
|
JdbcAdapterTest.LockWrapper |
Acquires a lock, and releases it when closed.
|
JdbcExample |
Example of using Calcite via JDBC.
|
JdbcExample.Employee |
Object that will be used via reflection to create the "emps" table.
|
JdbcExample.Foodmart |
Object that will be used via reflection to create the "foodmart"
schema.
|
JdbcExample.Hr |
Object that will be used via reflection to create the "hr" schema.
|
JdbcExample.SalesFact |
Object that will be used via reflection to create the
"sales_fact_1997" fact table.
|
JdbcFrontJdbcBackLinqMiddleTest |
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.
|
JdbcFrontJdbcBackTest |
Tests for a JDBC front-end and JDBC back-end.
|
JdbcFrontLinqBackTest |
Tests for a JDBC front-end (with some quite complex SQL) and Linq4j back-end
(based on in-memory collections).
|
JdbcTest |
Tests for using Calcite via JDBC.
|
JdbcTest.AbstractModifiableTable |
Abstract base class for implementations of ModifiableTable .
|
JdbcTest.AbstractModifiableView |
Abstract base class for implementations of ModifiableView .
|
JdbcTest.AutoTempDriver |
Mock driver that has a handler that stores the results of each query in
a temporary table.
|
JdbcTest.Customer |
|
JdbcTest.Department |
|
JdbcTest.Dependent |
|
JdbcTest.EmpDeptTableFactory |
Factory for EMP and DEPT tables.
|
JdbcTest.Employee |
|
JdbcTest.Event |
|
JdbcTest.FoodmartJdbcSchema |
|
JdbcTest.FoodmartSchema |
|
JdbcTest.HandlerDriver |
Mock driver that a given Handler .
|
JdbcTest.HrSchema |
|
JdbcTest.LingualEmp |
|
JdbcTest.LingualSchema |
|
JdbcTest.Location |
|
JdbcTest.MockDdlDriver |
Mock driver that can execute a trivial DDL statement.
|
JdbcTest.MySchema |
Schema containing dummy tables.
|
JdbcTest.MySchemaFactory |
|
JdbcTest.MyTable |
Dummy table.
|
JdbcTest.MyTable2 |
Another dummy table.
|
JdbcTest.SalesFact |
|
JsonLoader |
Populates a geode region from a file having JSON entries (line by line).
|
LatticeSuggesterTest |
Unit tests for LatticeSuggester .
|
LatticeSuggesterTest.Tester |
Test helper.
|
LatticeTest |
Unit test for lattices.
|
LexCaseSensitiveTest |
Testing SqlValidator and Lex .
|
Linq4jExample |
Example using linq4j to query in-memory collections.
|
Linq4jExample.Employee |
Employee.
|
Linq4jSuite |
Suite of all Linq4j tests.
|
Linq4jTest |
Tests for LINQ4J.
|
Linq4jTest.Department |
Department.
|
Linq4jTest.Employee |
Employee.
|
LinqFrontJdbcBackTest |
Tests for a linq4j front-end and JDBC back-end.
|
LookupImplTest |
Unit tests for LookupImpl.java
|
LookupOperatorOverloadsTest |
Test for lookupOperatorOverloads() in CalciteCatalogReader .
|
MappingTest |
Unit test for mappings.
|
Matchers |
Matchers for testing SQL queries.
|
Matchers.ComposingMatcher<F,T> |
Matcher that transforms the input value using a function before
passing to another matcher.
|
Matchers.IsWithin<T extends java.lang.Number> |
Is the numeric value within a given difference another value?
|
MaterializationTest |
Unit test for the materialized view rewrite mechanism.
|
MaterializationTest.HrFKUKSchema |
Hr schema with FK-UK relationship.
|
MaterializationTest.TableNameVisitor |
Implementation of RelVisitor to extract substituted table names.
|
MockCatalogReader |
Mock implementation of SqlValidatorCatalogReader which returns tables
"EMP", "DEPT", "BONUS", "SALGRADE" (same as Oracle's SCOTT schema).
|
MockCatalogReader.ColumnResolver |
Column resolver
|
MockCatalogReader.DelegateStructType |
Struct type based on another struct type.
|
MockCatalogReader.MockDynamicTable |
Mock implementation of
Prepare.PreparingTable with dynamic record type.
|
MockCatalogReader.MockModifiableViewRelOptTable |
Alternative to MockViewTable that exercises code paths in ModifiableViewTable
and ModifiableViewTableInitializerExpressionFactory.
|
MockCatalogReader.MockModifiableViewRelOptTable.MockModifiableViewTable |
A mock of ModifiableViewTable that can unwrap a mock RelOptTable.
|
MockCatalogReader.MockModifiableViewRelOptTable.MockViewTableMacro |
A TableMacro that creates mock ModifiableViewTable.
|
MockCatalogReader.MockSchema |
Mock schema.
|
MockCatalogReader.MockTable |
Mock implementation of
Prepare.PreparingTable .
|
MockCatalogReader.MockViewTable |
Mock implementation of
Prepare.PreparingTable for views.
|
MockCatalogReader.StreamableWrapperTable |
|
MockCatalogReader.WrapperTable |
|
MockCatalogReaderDynamic |
Registers dynamic tables.
|
MockCatalogReaderExtended |
Adds some extra tables to the mock catalog.
|
MockCatalogReaderSimple |
Simple catalog reader for testing.
|
MockRelOptCost |
MockRelOptCost is a mock implementation of the RelOptCost interface.
|
MockRelOptPlanner |
MockRelOptPlanner is a mock implementation of the RelOptPlanner
interface.
|
MockSqlOperatorTable |
Mock operator table for testing purposes.
|
MockSqlOperatorTable.DedupFunction |
"DEDUP" user-defined function.
|
MockSqlOperatorTable.RampFunction |
"RAMP" user-defined function.
|
ModelTest |
Unit test for data models.
|
MongoAdapterIT |
Used to trigger integration tests from maven (thus class name is suffixed with IT ).
|
MongoAdapterTest |
Testing mongo adapter functionality.
|
MongoAssertions |
Util class which needs to be in the same package as CalciteAssert
due to package-private visibility.
|
MongoDatabasePolicy |
Instantiates a new connection to Fongo (or Mongo) database depending on the
current profile (unit or integration tests).
|
MultiJdbcSchemaJoinTest |
Test case for joining tables from two different JDBC databases.
|
MultiJdbcSchemaJoinTest.TempDb |
Pool of temporary databases.
|
MutableRelTest |
Tests for MutableRel sub-classes.
|
OptimizerTest |
Unit test for BlockBuilder
optimization capabilities.
|
OsAdapterTest |
Unit tests for the OS (operating system) adapter.
|
PartiallyOrderedSetTest |
Unit test for PartiallyOrderedSet .
|
PermutationTestCase |
Unit test for Permutation .
|
PigAdapterTest |
Tests for the org.apache.calcite.adapter.pig package.
|
PigletTest |
Unit tests for Piglet.
|
PigRelBuilderStyleTest |
Tests for the org.apache.calcite.adapter.pig package that tests the
building of PigRel relational expressions using RelBuilder and
associated factories in PigRelFactories .
|
PigRelBuilderTest |
Unit test for PigRelBuilder .
|
PlannerTest |
Unit tests for Planner .
|
PlannerTest.MyCountAggFunction |
User-defined aggregate function.
|
PlannerTests |
Common classes and utility methods for Volcano planner tests.
|
PlannerTests.GoodSingleRule |
|
PlannerTests.NoneLeafRel |
Relational expression with zero inputs and convention NONE.
|
PlannerTests.NoneSingleRel |
Relational expression with one input and convention NONE.
|
PlannerTests.PhysLeafRel |
Relational expression with zero inputs and convention PHYS.
|
PlannerTests.PhysLeafRule |
|
PlannerTests.PhysSingleRel |
Relational expression with one input and convention PHYS.
|
PlannerTests.TestLeafRel |
Leaf relational expression.
|
PlannerTests.TestSingleRel |
Relational expression with one input.
|
PlusSuite |
Suite consisting of all tests in the calcite-plus module.
|
PrecedenceClimbingParserTest |
Unit test for PrecedenceClimbingParser .
|
PrimitiveTest |
Unit test for Primitive .
|
ProfilerTest |
Unit tests for Profiler .
|
ProfilerTest.Fluid |
Fluid interface for writing profiler test cases.
|
Projection2Test |
Checks renaming of fields (also upper, lower cases) during projections
|
ProjectionTest |
Checks renaming of fields (also upper, lower cases) during projections
|
QueryBuildersTest |
Check that internal queries are correctly converted to ES search query (as JSON)
|
QuidemTest |
Test that runs every Quidem file as a test.
|
QuidemTest.QuidemConnectionFactory |
Quidem connection factory for Calcite's built-in test schemas.
|
RangeTable |
Table that returns a range of integers.
|
RangeTable.Factory |
Implementation of TableFactory that
allows a RangeTable to be included as a custom table in a Calcite
model file.
|
ReflectiveSchemaTest |
Unit tests for ReflectiveSchema .
|
ReflectiveSchemaTest.AllPrivate |
All field are private, therefore the resulting record has no fields.
|
ReflectiveSchemaTest.BadType |
Table that has a field that cannot be recognized as a SQL type.
|
ReflectiveSchemaTest.CatchallSchema |
Object whose fields are relations.
|
ReflectiveSchemaTest.DateColumnSchema |
Schema that contains a table with a date column.
|
ReflectiveSchemaTest.EmployeeWithHireDate |
|
ReflectiveSchemaTest.EveryType |
Record that has a field of every interesting type.
|
ReflectiveSchemaTest.IntAndString |
Table that has integer and string fields
|
ReflectiveSchemaTest.IntHolder |
Custom java class that holds just a single field.
|
ReflectVisitorTest |
ReflectVisitorTest tests ReflectUtil.invokeVisitor(org.apache.calcite.util.ReflectiveVisitor, java.lang.Object, java.lang.Class, java.lang.String) and
ReflectiveVisitor and provides a contrived example of how to use
them.
|
ReflectVisitorTest.CrunchableNumber |
An interface for introducing ambiguity into the class hierarchy.
|
ReflectVisitorTest.DiceyNumber |
|
ReflectVisitorTest.FudgeableNumber |
An interface for introducing ambiguity into the class hierarchy.
|
RelationalJdbcExample |
Example of using Geode via JDBC.
|
RelBuilderExample |
Example that uses RelBuilder
to create various relational expressions.
|
RelBuilderTest |
Unit test for RelBuilder .
|
RelCollationTest |
Tests for RelCollation and RelFieldCollation .
|
RelDistributionTest |
Tests for RelDistribution .
|
RelMdColumnOriginsTest |
Test case for CALCITE-542.
|
RelMetadataTest |
Unit test for DefaultRelMetadataProvider .
|
RelMetadataTest.BrokenColTypeImpl |
|
RelMetadataTest.ColType |
Custom metadata interface.
|
RelMetadataTest.ColType.Handler |
Handler API.
|
RelMetadataTest.ColTypeImpl |
|
RelMetadataTest.MyRelMetadataQuery |
|
RelMetadataTest.PartialColTypeImpl |
|
RelOptPlanReaderTest |
Unit test for RelJson .
|
RelOptPlanReaderTest.MyRel |
Dummy relational expression.
|
RelOptRulesTest |
Unit test for rules in org.apache.calcite.rel and subpackages.
|
RelOptTestBase |
RelOptTestBase is an abstract base for tests which exercise a planner and/or
rules via DiffRepository .
|
RelOptUtilTest |
Unit test for RelOptUtil and other classes in this package.
|
RelToSqlConverterStructsTest |
Tests for RelToSqlConverter on a schema that has nested structures of multiple
levels.
|
RelToSqlConverterTest |
Tests for RelToSqlConverter .
|
RelToSqlConverterTest.Sql |
Fluid interface to run tests.
|
RelTraitTest |
Test to verify RelCompositeTrait .
|
RelWriterTest |
Unit test for RelJson .
|
RemotePreparedStatementParametersTest |
Tests against parameters in prepared statement when using underlying jdbc subschema
|
RexBuilderTest |
Test for RexBuilder .
|
RexExecutorTest |
Unit test for RexExecutorImpl .
|
RexExecutorTest.Action |
|
RexExecutorTest.TestDataContext |
ArrayList-based DataContext to check Rex execution.
|
RexFuzzer |
Generates random RexNode instances for tests.
|
RexImplicationCheckerTest |
Unit tests for RexImplicationChecker .
|
RexImplicationCheckerTest.Fixture |
Contains all the nourishment a test case could possibly need.
|
RexProgramBuilderBase |
This class provides helper methods to build rex expressions.
|
RexProgramBuilderBase.DummyTestDataContext |
Dummy data context for test.
|
RexProgramFuzzyTest |
Validates that RexSimplify is able to deal with
randomized RexNode .
|
RexProgramFuzzyTest.TopN<E extends java.lang.Comparable<E>> |
A bounded variation of PriorityQueue
|
RexProgramTest |
Unit tests for RexProgram and
RexProgramBuilder .
|
RexToTestCodeShuttle |
|
RexTransformerTest |
Tests transformations on rex nodes.
|
RootEmployee |
|
RootHr |
Equivalent to
JdbcExample.Hr , but
belongs to the unnamed (root) package.
|
SamplePlugin |
Sample mtsql plugin.
|
SamplePlugin.DescribeResultSet |
Command that describes a result set.
|
ScannableTableTest |
Unit test for ScannableTable .
|
ScannableTableTest.BeatlesFilterableTable |
Table that returns two columns via the FilterableTable
interface.
|
ScannableTableTest.BeatlesProjectableFilterableTable |
Table that returns two columns via the FilterableTable
interface.
|
ScannableTableTest.BeatlesTable |
Table that returns two columns via the ScannableTable interface.
|
ScannableTableTest.SimpleTable |
Table that returns one column via the ScannableTable interface.
|
ScrollingTest |
Tests usage of scrolling API like correct results and resource cleanup
(delete scroll after scan).
|
ServerParserTest |
Tests SQL parser extensions for DDL.
|
ServerQuidemTest |
Unit tests for server and DDL.
|
ServerTest |
Unit tests for server and DDL.
|
ServerUnParserTest |
Extension to ServerParserTest that ensures that every expression can
un-parse successfully.
|
SimpleJdbcExample |
Example of using Geode via JDBC.
|
SimplifyTask |
Tracks rex nodes used in RexProgramFuzzyTest to identify the ones
which take most time to simplify.
|
Smalls |
Holder for various classes and functions used in tests as user-defined
functions and so forth.
|
Smalls.AllTypesFunction |
UDF class that provides user-defined functions for each data type.
|
Smalls.AwkwardFunction |
Example of a UDF class that needs to be instantiated but cannot be.
|
Smalls.CountArgs0Function |
Example of a UDF that has overloaded UDFs (same name, different args).
|
Smalls.CountArgs1Function |
|
Smalls.CountArgs1NullableFunction |
|
Smalls.CountArgs2Function |
|
Smalls.IntString |
Class with int and String fields.
|
Smalls.MazeTable |
The real MazeTable may be found in example/function.
|
Smalls.MultipleFunction |
UDF class that has multiple methods, some overloaded.
|
Smalls.MyAbcdeFunction |
Example of a UDF with named parameters, some of them optional.
|
Smalls.MyDeterministicPlusFunction |
|
Smalls.MyDoubleFunction |
Example of a UDF with a static eval method.
|
Smalls.MyGenericAggFunction<A,V,R> |
A generic interface for defining user defined aggregate functions
|
Smalls.MyIncrement |
User-defined function with two arguments.
|
Smalls.MyLeftFunction |
Example of a UDF with named parameters.
|
Smalls.MyPlusFunction |
Example of a UDF with a non-static eval method,
and named parameters.
|
Smalls.MyStaticSumFunction |
Example of a user-defined aggregate function (UDAF), whose methods are
static.
|
Smalls.MySum3 |
Example of a user-defined aggregate function that implements a generic
interface.
|
Smalls.MySumFunction |
Example of a user-defined aggregate function (UDAF).
|
Smalls.MyTableFunction |
A table function that returns a QueryableTable .
|
Smalls.MyThreeParamsSumFunctionWithFilter1 |
Example of a user-defined aggregate function (UDAF), whose methods are
static.
|
Smalls.MyThreeParamsSumFunctionWithFilter2 |
Example of a user-defined aggregate function (UDAF), whose methods are
static.
|
Smalls.MyToStringFunction |
Example of a non-strict UDF.
|
Smalls.MyTwoParamsSumFunctionFilter1 |
Example of a user-defined aggregate function (UDAF).
|
Smalls.MyTwoParamsSumFunctionFilter2 |
Example of a user-defined aggregate function (UDAF).
|
Smalls.Null4Function |
Example of a semi-strict UDF.
|
Smalls.Null8Function |
Example of a picky, semi-strict UDF.
|
Smalls.SimpleTableFunction |
A table function that returns a QueryableTable .
|
Smalls.StaticTableMacroFunction |
User-defined table-macro function whose eval method is static.
|
Smalls.SumFunctionBadIAdd |
User-defined function.
|
Smalls.TableMacroFunction |
User-defined table-macro function.
|
Smalls.TableMacroFunctionWithNamedParameters |
User-defined table-macro function with named and optional parameters.
|
Smalls.TestStaticTableFunction |
A table function that returns a QueryableTable via a
static method.
|
Smalls.WideProductSale |
Table with a lot of columns.
|
Smalls.WideSaleSchema |
Schema containing a prod table with a lot of columns.
|
SourceTest |
Tests for Source .
|
SparkAdapterTest |
Tests for using Calcite with Spark as an internal engine, as implemented by
the org.apache.calcite.adapter.spark package.
|
SplunkAdapterTest |
Unit test of the Calcite adapter for Splunk.
|
SqlAdvisorJdbcTest |
Tests for SqlAdvisor .
|
SqlAdvisorTest |
|
SqlFunctionsTest |
Unit test for the methods in SqlFunctions that implement SQL
functions.
|
SqlJsonFunctionsTest |
Unit test for the methods in SqlFunctions that implement JSON processing functions.
|
SqlLimitsTest |
Unit test for SQL limits.
|
SqlLineTest |
Tests that we can invoke SqlLine on a Calcite connection.
|
SqlOperatorBaseTest |
Contains unit tests for all operators.
|
SqlOperatorBaseTest.Builder |
Builds lists of types and sample values.
|
SqlOperatorBaseTest.ExceptionResultChecker |
Result checker that considers a test to have succeeded if it throws an
exception that matches one of a list of patterns.
|
SqlOperatorBaseTest.TesterImpl |
Implementation of SqlTester based on a
JDBC connection.
|
SqlOperatorBaseTest.ValueOrExceptionResultChecker |
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 |
A type, a value, and its SqlNode representation.
|
SqlOperatorBindingTest |
Unit tests for RexProgram and
RexProgramBuilder .
|
SqlOperatorTest |
|
SqlParserTest |
A SqlParserTest is a unit-test for
the SQL parser .
|
SqlParserTest.Tester |
Callback to control how test actions are performed.
|
SqlPrettyWriterTest |
Unit test for SqlPrettyWriter .
|
SqlRuntimeTester |
Tester of SqlValidator and runtime execution of the input SQL.
|
SqlSetOptionOperatorTest |
Test for SqlSetOption .
|
SqlTest |
System test of the Calcite file adapter, which can also read and parse
HTML tables over HTTP.
|
SqlTester |
SqlTester defines a callback for testing SQL queries and expressions.
|
SqlTester.ParameterChecker |
Parameter checker.
|
SqlTester.ResultChecker |
Result checker.
|
SqlTester.TypeChecker |
Type checker.
|
SqlTester.VmName |
Name of a virtual machine that can potentially implement an operator.
|
SqlTestFactory |
|
SqlTestFactory.MockCatalogReaderFactory |
|
SqlTestFactory.ValidatorFactory |
Creates SqlValidator for tests.
|
SqlTestGen |
Utility to generate a SQL script from validator test.
|
SqlTestGen.SqlValidatorSpooler |
Subversive subclass, which spools results to a writer rather than running
tests.
|
SqlTestGen.SqlValidatorSpooler.MyInvocationHandler |
Handles the methods in
SqlValidator that are called
from validator tests.
|
SqlTests |
Utility methods.
|
SqlTests.ApproximateResultChecker |
Result checker that checks a result against an expected value.
|
SqlTests.PatternResultChecker |
Result checker that checks a result against a regular expression.
|
SqlTests.RefSetResultChecker |
Result checker that checks a result against a list of expected strings.
|
SqlTests.SqlTypeChecker |
Checks that a type matches a given SQL type.
|
SqlTests.Stage |
Stage of query processing
|
SqlTests.StringTypeChecker |
Type checker which compares types to a specified string.
|
SqlToRelConverterExtendedTest |
|
SqlToRelConverterTest |
Unit test for SqlToRelConverter .
|
SqlToRelConverterTest.RelValidityChecker |
Visitor that checks that every RelNode in a tree is valid.
|
SqlToRelTestBase |
SqlToRelTestBase is an abstract base for tests which involve conversion from
SQL to relational algebra.
|
SqlToRelTestBase.DelegatingRelOptTable |
Table that delegates to a given table.
|
SqlToRelTestBase.FarragoTestValidator |
Validator for testing.
|
SqlToRelTestBase.MockRelOptSchema |
Mock implementation of RelOptSchema .
|
SqlToRelTestBase.Tester |
Helper class which contains default implementations of methods used for
running sql-to-rel conversion tests.
|
SqlToRelTestBase.TesterImpl |
|
SqlTypeFactoryTest |
Test for SqlTypeFactoryImpl .
|
SqlTypeFixture |
Reusable RelDataType fixtures for tests.
|
SqlTypeNameTest |
Tests types supported by SqlTypeName .
|
SqlTypeUtilTest |
Test of SqlTypeUtil .
|
SqlUnParserTest |
Extension to SqlParserTest which ensures that every expression can
un-parse successfully.
|
SqlValidatorDynamicTest |
|
SqlValidatorFeatureTest |
SqlValidatorFeatureTest verifies that features can be independently enabled
or disabled.
|
SqlValidatorMatchTest |
Validation tests for the MATCH_RECOGNIZE clause.
|
SqlValidatorTest |
|
SqlValidatorTestCase |
An abstract base class for implementing tests against SqlValidator .
|
SqlValidatorTestCase.Sql |
Fluent testing API.
|
SqlValidatorTestCase.Tester |
Encapsulates differences between test environments, for example, which
SQL parser or validator to use.
|
SqlValidatorTestCase.TesterConfigurationRule |
|
SqlValidatorTester |
Tester of SqlValidator .
|
SqlValidatorUtilTest |
Tests for SqlValidatorUtil .
|
StreamTest |
Tests for streaming queries.
|
StreamTest.BaseOrderStreamTable |
Base table for the Orders table.
|
StreamTest.InfiniteOrdersStreamTableFactory |
Mock table that returns a stream of orders from a fixed array.
|
StreamTest.InfiniteOrdersTable |
Table representing an infinitely larger ORDERS stream.
|
StreamTest.OrdersHistoryTable |
Table representing the history of the ORDERS stream.
|
StreamTest.OrdersStreamTableFactory |
Mock table that returns a stream of orders from a fixed array.
|
StreamTest.OrdersTable |
Table representing the ORDERS stream.
|
StreamTest.ProductsTable |
Table representing the PRODUCTS relation.
|
StreamTest.ProductsTableFactory |
Mocks a simple relation to use for stream joining test.
|
TableFunctionTest |
Tests for user-defined table functions.
|
TableInRootSchemaTest |
Test case for issue 85.
|
TableInRootSchemaTest.SimpleTable |
Table with columns (A, B).
|
TestUtil |
Static utilities for JUnit tests.
|
TestUtilTest |
Tests for TestUtil
|
TpcdsLatticeSuggesterTest |
Unit tests for LatticeSuggester .
|
TpcdsLatticeSuggesterTest.Tester |
Test helper.
|
TpcdsTest |
Unit test for TpcdsSchema .
|
TpchSchema |
TPC-H table schema.
|
TpchSchema.Part |
Part in TPC-H.
|
TpchSchema.PartSupp |
Part supplier in TPC-H.
|
TpchTest |
Unit test for TpchSchema .
|
TraitConversionTest |
Unit test for RelDistributionTraitDef .
|
TraitConversionTest.BridgeRel |
|
TraitConversionTest.ConvertRelDistributionTraitDef |
Dummy distribution trait def for test (handles conversion of SimpleDistribution)
|
TraitConversionTest.NoneLeafRel |
Any distribution and none convention.
|
TraitConversionTest.NoneSingleRel |
Rel with any distribution and none convention.
|
TraitConversionTest.RandomSingleRel |
Rel with physical convention and random distribution.
|
TraitConversionTest.RandomSingleTraitRule |
|
TraitConversionTest.SimpleDistribution |
Dummy distribution for test (simplified version of RelDistribution).
|
TraitConversionTest.SingleLeafTraitRule |
|
TraitConversionTest.SingletonLeafRel |
Rel with singleton distribution, physical convention.
|
TraitPropagationTest |
Tests that determine whether trait propagation work in Volcano Planner.
|
TraitPropagationTest.Phys |
Market interface for Phys nodes
|
TraitPropagationTest.PhysAgg |
Physical Aggregate RelNode
|
TraitPropagationTest.PhysAggRule |
Rule for PhysAgg
|
TraitPropagationTest.PhysProj |
Physical Project RelNode
|
TraitPropagationTest.PhysProjRule |
Rule for PhysProj
|
TraitPropagationTest.PhysSort |
Physical Sort RelNode
|
TraitPropagationTest.PhysSortRule |
Rule for PhysSort
|
TraitPropagationTest.PhysTable |
Physical Table RelNode
|
TraitPropagationTest.PhysTableRule |
Rule for PhysTable
|
TraitPropagationTest.PropAction |
Materialized anonymous class for simplicity
|
TypeTest |
Test for Types.gcd(java.lang.reflect.Type...) .
|
UdfTest |
Tests for user-defined functions;
includes user-defined aggregate functions
but user-defined table functions are in TableFunctionTest .
|
UdfTest.ArrayAppendScalarFunction |
Base class for functions that append arrays.
|
UdtTest |
Tests for user-defined types.
|
UtilTest |
Unit test for Util and other classes in this package.
|
VolcanoPlannerTest |
Unit test for the optimizer .
|
VolcanoPlannerTest.GoodRemoveSingleRule |
|
VolcanoPlannerTest.PhysProjectRule |
Planner rule that converts a LogicalProject to PHYS convention.
|
VolcanoPlannerTest.ReformedRemoveSingleRule |
|
VolcanoPlannerTest.ReformedSingleRule |
|
VolcanoPlannerTest.SubsetRule |
Rule that matches a RelSubset .
|
VolcanoPlannerTest.TestListener |
Implementation of RelOptListener .
|
VolcanoPlannerTraitTest |
Unit test for handling of traits by VolcanoPlanner .
|
VolcanoPlannerTraitTest.AltTrait |
Implementation of RelTrait for testing.
|
VolcanoPlannerTraitTest.AltTraitConverter |
|
VolcanoPlannerTraitTest.AltTraitConverterRule |
|
VolcanoPlannerTraitTest.AltTraitDef |
|
VolcanoPlannerTraitTest.FooRel |
A mix-in interface to extend RelNode , for testing.
|
VolcanoPlannerTraitTest.IterMergedRel |
|
VolcanoPlannerTraitTest.IterSinglePhysMergeRule |
|
VolcanoPlannerTraitTest.IterSingleRel |
|
VolcanoPlannerTraitTest.IterSingleRule |
|
VolcanoPlannerTraitTest.IterSingleRule2 |
|
VolcanoPlannerTraitTest.NoneLeafRel |
A relational expression with zero inputs, of NONE convention.
|
VolcanoPlannerTraitTest.NoneSingleRel |
Relational expression with one input, of NONE convention.
|
VolcanoPlannerTraitTest.PhysLeafRel |
Relational expression with zero inputs, of PHYS convention.
|
VolcanoPlannerTraitTest.PhysLeafRule |
Relational expression with zero inputs, of the PHYS convention.
|
VolcanoPlannerTraitTest.PhysToIteratorConverter |
Planner rule that converts PHYS to ENUMERABLE convention.
|
VolcanoPlannerTraitTest.PhysToIteratorConverterRule |
Planner rule that converts from PHYS to ENUMERABLE convention.
|
VolcanoPlannerTraitTest.TestLeafRel |
A relational expression with zero inputs.
|
VolcanoPlannerTraitTest.TestSingleRel |
Relational expression with one input.
|
WithLex |
Annotation that indicates that test method should be run with given lex configuration.
|