All Classes Interface Summary Class Summary Enum Summary Exception Summary Error Summary Annotation Types Summary
Class |
Description |
AbstractCaseExpression |
|
AbstractCompareCriteria |
|
AbstractNavigator |
|
AbstractSetCriteria |
This is an abstract class to define some common functionality in the two varieties of
IN criteria: SetCriteria (where values are specified) and SubquerySetCriteria
(where a subquery is defined and will supply the values for the IN set).
|
AbstractSymbolMappingVisitor |
This class is used to update LanguageObjects by replacing one set of symbols with
another.
|
AbstractTupleSource |
|
AbstractValidationVisitor |
|
AbstractWorkItem |
Represents a task that performs work that may take more than one processing pass to complete.
|
AccessInfo |
Tracks what views were used and what tables are accessed
|
AccessNode |
|
AccessPattern |
This class represents both virtual and physical access patterns.
|
ActivityReport<R extends ReportItem> |
A report holds the output of some activity.
|
AggregateFunction |
This represents the interface for an aggregate function.
|
AggregateSymbol |
An aggregate symbol represents an aggregate function.
|
AggregateSymbol.Type |
|
AggregateSymbolCollectorVisitor |
|
AggregateSymbolCollectorVisitor.AggregateStopNavigator |
|
AliasGenerator |
Adds safe (generated) aliases to the source command
The structure is a little convoluted:
AliasGenerator - structure navigator, alters the command by adding alias symbols
NamingVisitor - changes the output names of Element and Group symbols
SQLNamingContext - a hierarchical context for tracking Element and Group names
|
AliasSymbol |
An AliasSymbol wraps a SingleElementSymbol and changes it's name.
|
Alter<T extends Command> |
|
AlterProcedure |
|
AlterResolver |
|
AlterTrigger |
|
AlterView |
|
AnalysisRecord |
The AnalysisRecord holds all debug/analysis information for
a particular query as it is executed.
|
Array |
|
ArrayAgg |
|
ArrayTable |
Represents the ArrayTable table function.
|
ArrayTableNode |
Handles array table processing.
|
AssignmentInstruction |
This instruction updates the current variable context with a value for the Variable
defined using a DeclareInstruction, the variable value is obtained by either processing
a expression or a command(stored as a processplan).
|
AssignmentStatement |
This class represents an assignment statement in the storedprocedure language.
|
AtomicCriteria |
This abstract class represents an atomic logical criteria.
|
AtomicRequestID |
This class uniquely identifies a AtomicRequestMessage
|
AtomicRequestMessage |
This class defines a request message for the Connector layer.
|
AtomicResultsMessage |
|
AuthorizationValidationVisitor |
|
AuthorizationValidator |
Defines a validator that checks for proper authorization.
|
AuthorizationValidator.CommandType |
|
AutoCleanupUtil |
|
AutoCleanupUtil.Removable |
|
Avg |
Accumulates (per tuple) and calculates the average of the values
of a column.
|
BaseCacheEntry |
|
BaseIndexInfo<T extends SearchableTable> |
Accumulates information about index usage.
|
BasicQueryMetadata |
This is an abstract implementation of the metadata interface.
|
BasicQueryMetadataWrapper |
|
BasicSourceCapabilities |
|
BatchCollector |
|
BatchCollector.BatchProducer |
|
BatchCollector.BatchProducerTupleSource |
|
BatchedUpdateCommand |
Represents a batch of INSERT, UPDATE, DELETE, and SELECT INTO commands
|
BatchedUpdateNode |
Node that batches commands sent to the DataManager.
|
BatchedUpdatePlan |
Plan for execution for a batched update command.
|
BatchedUpdatePlanner |
Planner for BatchedUpdateCommands
|
BatchedUpdateResolver |
Resolver for BatchedUpdateCommands
|
BatchIterator |
|
BatchManager |
Acts as a combination serializer/cachemanager
|
BetweenCriteria |
Represents criteria such as: "<expression> [NOT] BETWEEN <lowerExpression> AND <upperExpression>".
|
BinaryComparison |
An adapter interface so that several binary operators can be treated similarly
|
Block |
This class represents a group of Statement objects.
|
BlockByteBuffer |
Provides buffer slices or blocks off of a central
set of buffers.
|
BlockedException |
This exception is thrown if the buffer manager blocks waiting on input during
processing.
|
BlockInstruction |
|
BlockManager |
Represents an INode
|
BranchingInstruction |
|
BranchingStatement |
This class represents a break statement in the storedprocedure language.
|
BranchingStatement.BranchingMode |
|
BufferFrontedFileStoreCache |
Implements storage against a FileStore abstraction using a fronting
memory buffer with a filesystem paradigm.
|
BufferManager |
The buffer manager controls how memory is used and how data flows through
the system.
|
BufferManager.BufferReserveMode |
|
BufferManager.TupleSourceType |
|
BufferManagerImpl |
Default implementation of BufferManager.
|
BufferService |
|
ByteLobChunkStream |
A wrapper class, given a InputStream object can convert a underlying
stream into sequence of ByteLobChunk objects of given chunk size.
|
Cachable |
|
Cache<K,V> |
Abstraction over cache providers
|
Cache<T> |
|
CacheConfiguration |
|
CacheConfiguration.Policy |
|
CachedFinder |
|
CachedResults |
|
CacheEntry |
|
CacheFactory |
|
CacheHint |
|
CacheKey |
|
CapabilitiesConverter |
Utility to convert a ConnectorCapabilities class into a Map of
capabilities information that can be passed through the system.
|
CapabilitiesFinder |
This interface describes how to find connector capabilities.
|
CapabilitiesUtil |
|
CaseExpression |
|
ChainingMetadataRepository |
|
CollectionTupleSource |
|
CollectionValueIterator |
|
ColumnMaskingHelper |
|
Command |
A Command is an interface for all the language objects that are at the root
of a language object tree representing a SQL statement.
|
CommandCollectorVisitor |
This visitor class will traverse a language object tree and collect all sub-commands
it finds.
|
CommandContext |
Defines the context that a command is processing in.
|
CommandPlanner |
The common interface of all planners which take a user's command
object and produce a
ProcessorPlan
object, which is a plan for executing the query.
|
CommandResolver |
This is the interface that is implemented for each type of command, telling how
to resolve that command.
|
CommandStatement |
This class represents a variable assignment statement in the storedprocedure language.
|
CompareCriteria |
A criteria which represents a simple operator relationship between two expressions.
|
CompositeMetadataStore |
Aggregates the metadata from multiple stores.
|
CompositeMetadataStore.RecordHolder |
|
CompoundCriteria |
This class represents a compound criteria for logical expressions.
|
ConcurrentBitSet |
A segmented BitSet that supports greater concurrency
and faster finding of clear bits.
|
ConnectorManager |
The ConnectorManager manages an ExecutionFactory
and its associated workers' state.
|
ConnectorManagerRepository |
|
ConnectorManagerRepository.ConnectorManagerException |
|
ConnectorManagerRepository.ExecutionFactoryProvider |
|
ConnectorWork |
Represents a connector execution in batched form.
|
ConnectorWorkItem |
|
Constant |
This class represents a literal value in a SQL string.
|
ConstantFunction |
|
ContentHandler |
A simplified and stoppable SAX-like content handler for stream processing of JSON text.
|
ContextReference |
|
CorrelatedReferenceCollectorVisitor |
This visitor class will traverse a language object tree and collect references that
correspond to correlated subquery references.
|
Count |
Just a simple COUNT() implementation that counts every non-null row it sees.
|
CountBig |
Just a simple COUNT() implementation that counts every non-null row it sees.
|
Create |
|
Create.CommitAction |
|
CreateCursorResultSetInstruction |
|
CreateCursorResultSetInstruction.Mode |
|
CreateProcedureCommand |
This class represents a update procedure in the storedprocedure language.
|
Credentials |
|
Criteria |
This class represents the criteria clause for a query, which defines
constraints on the data values to be retrieved for each parameter in the
select clause.
|
CriteriaCapabilityValidatorVisitor |
|
CriteriaCapabilityValidatorVisitor.ValidatorOptions |
|
DatabaseStore |
This holds the local state of all Database instances.
|
DatabaseStore.Mode |
|
DatabaseUtil |
|
DataRolePolicyDecider |
|
DataTierManagerImpl |
|
DataTierTupleSource |
This tuple source impl can only be used once; once it is closed, it
cannot be reopened and reused.
|
DDLConstants |
|
DDLFileMetadataRepository |
|
DDLMetadataRepository |
|
DdlPlan |
|
DdlPlan.SetPropertyProcessor |
|
DdlPlanner |
|
DDLStringVisitor |
|
DeclareStatement |
This class represents a statement used to declare variables in the
storedprocedure language.
|
DeepPostOrderNavigator |
|
DeepPreOrderNavigator |
|
DefaultAuthorizationValidator |
The default Teiid authorization validator
|
Delete |
This class represents a SQL Delete statement of the form:
"DELETE FROM <group> [WHERE <criteria>]".
|
DeleteResolver |
This class knows how to expand and resolve DELETE commands.
|
DependentAccessNode |
Takes a query with 1 or more dependent sets from 1 or more sources and creates a series of commands.
|
DependentCriteriaProcessor |
|
DependentCriteriaProcessor.SetState |
|
DependentProcedureAccessNode |
|
DependentProcedureCriteriaProcessor |
|
DependentProcedureExecutionNode |
|
DependentSetCriteria |
The DependentSetCriteria is missing the value set until it is filled during
processing.
|
DependentSetCriteria.AttributeComparison |
|
DependentValueSource |
|
DerivedColumn |
|
DerivedExpression |
|
DirectQueryMetadataRepository |
This Metadata repository adds the "native" procedure to all the execution factories that support them.
|
DQPConfiguration |
|
DQPCore |
Implements the core DQP processing.
|
DQPCore.CompletionListener<T> |
|
DQPCore.ResultsListener |
|
DQPWorkContext |
|
DQPWorkContext.Version |
|
Drop |
|
DupRemoveNode |
|
DynamicCommand |
|
DynamicCommandResolver |
|
ElementCollectorVisitor |
This visitor class will traverse a language object tree and collect all element
symbol references it finds.
|
ElementSymbol |
This is a subclass of Symbol representing a single element.
|
ElementSymbol.DisplayMode |
|
EncryptedStorageManager |
Implements a block AES cipher over a regular filestore.
|
EnhancedSortMergeJoinStrategy |
Extends the basic fully sorted merge join to check for conditions necessary
to not fully sort one of the sides.
|
ErrorInstruction |
This instruction updates the current variable context with the Variable defined using
the declare statement that is used in constructing this instruction.
|
EvaluatableVisitor |
This visitor class will traverse a language object tree, and determine
if the current expression can be evaluated
|
EvaluatableVisitor.EvaluationLevel |
|
Evaluator |
|
Evaluator.NameValuePair<T> |
|
ExceptionExpression |
|
ExecDynamicSqlInstruction |
Executes a SQL statement, and remove its results from the buffer manager.
|
ExecResolver |
|
ExecutionContextImpl |
|
ExistsCriteria |
This predicate criteria implements the "exists" predicate, which has
a subquery in it.
|
ExistsCriteria.SubqueryHint |
|
ExplainCommand |
|
ExplainCommand.Format |
|
ExplainProcessPlan |
|
ExposedStateUserDefinedAggregate<T> |
Internal extension of the user defined aggregate interface so that we can expose the internal
state.
|
Expression |
This is the interface for an expression in a SQL string.
|
ExpressionCriteria |
|
ExpressionEvaluationException |
This exception is thrown when an error occurs while evaluating a SQL expression.
|
ExpressionMappingVisitor |
It is important to use a Post Navigator with this class,
otherwise a replacement containing itself will not work
|
ExpressionStatement |
|
ExpressionSymbol |
|
ExtensibleBufferedInputStream |
|
ExtensibleBufferedOutputStream |
|
FileStorageManager |
Implements file storage that automatically splits large files and limits the number of open files.
|
FileStore |
|
FileStoreInputStreamFactory |
|
FilteredCommand |
|
FirstLastValue |
Just a simple First/Last_value() implementation
|
ForEachRowPlan |
|
FrameUtil |
|
From |
Represents a FROM clause in a SELECT query.
|
FromClause |
A FromClause is an interface for subparts held in a FROM clause.
|
Function |
Represents a function in a sql statement.
|
FunctionCategoryConstants |
This interface defines the default set of function category constants.
|
FunctionCollectorVisitor |
This visitor class will traverse a language object tree and collect all Function
references it finds.
|
FunctionDescriptor |
The FunctionDescriptor describes a particular function instance enough
to invoke the function.
|
FunctionExecutionException |
During processing, an invalid function was detected.
|
FunctionLibrary |
The function library is the primary way for the system to find out what
functions are available, resolve function signatures, and invoke system
and user-defined functions.
|
FunctionLibrary.ConversionResult |
|
FunctionMetadataException |
Detected invalid function metadata during validation.
|
FunctionMetadataSource |
A FunctionMetadataSource represents a source of function metadata for
the function library.
|
FunctionMetadataValidator |
The validator encodes business logic with respect to what a valid function
description is.
|
FunctionMethods |
Static method hooks for most of the function library.
|
FunctionTree |
Data structure used to store function signature information.
|
FutureWork<T> |
|
GeneratedKeysImpl |
|
GeographyFunctionMethods |
|
GeometryFunctionMethods |
|
GeometryHelper |
|
GeometryUtils |
Utility methods for geometry
TODO: determine if we should use buffermanager to minimize memory footprint
|
GeometryUtils.Extent |
|
GeometryUtils.Ordinate |
|
GlobalTableStore |
|
GlobalTableStoreImpl |
|
GlobalTableStoreImpl.MatState |
|
GroupBy |
This class represents the GROUP BY clause of a query, which defines the expressions
that should be used for grouping the results of the query.
|
GroupCollectorVisitor |
This visitor class will traverse a language object tree and collect all group
symbol references it finds.
|
GroupContext |
A GroupContext represents a set of groups in a hierarchy that determines
resolving order.
|
GroupInfo |
|
GroupingNode |
|
GroupsUsedByElementsVisitor |
|
GroupSymbol |
This is the server's representation of a metadata group symbol.
|
GSSResult |
|
IDGenerator |
IDGenerator
|
IfInstruction |
This instruction an holds an if block and an else block and a criteria that determines
which block will be executed.
|
IfStatement |
This class represents an if-else statement in the storedprocedure language.
|
ImmutableCompareCriteria |
|
IndexedTupleSource |
|
Insert |
Represents a SQL Insert statement of the form:
"INSERT INTO <group> (<variables>) VALUES <values>".
|
InsertPlanExecutionNode |
|
InsertResolver |
This class knows how to expand and resolve INSERT commands.
|
Into |
Rpresent INTO clause in SELECT ...
|
InvalidFunctionException |
During processing, an invalid function was detected.
|
InvalidFunctionItem |
This is a specialized report item for reporting invalid function methods during
function metadata validation.
|
IsDistinctCriteria |
Represents criteria such as: "<expression> IS DISTINCT FROM <expression>".
|
IsNullCriteria |
Represents criteria such as: "<expression> IS NULL".
|
JavaCharStream |
An implementation of interface CharStream, where the stream is assumed to
contain only ASCII characters (with java-like unicode escape processing).
|
JoinNode |
|
JoinNode.JoinStrategyType |
|
JoinPredicate |
Represents a subpart of the FROM clause specifying a join within the FROM.
|
JoinStrategy |
|
JoinType |
This class represents a join type.
|
JoinUtil |
Utility methods for query planning related to joins.
|
JSONArrayAgg |
Aggregates Json entries
|
JSONFunctionMethods |
|
JSONFunctionMethods.JSONBuilder |
|
JSONObject |
|
JSONParser |
Parser for JSON text.
|
JsonTable |
Represents the JSONTABLE table function.
|
JsonTable.JsonColumn |
|
LanguageBridgeFactory |
|
LanguageObject |
This is the primary interface for all language objects.
|
LanguageObject.Util |
|
LanguageVisitor |
The LanguageVisitor can be used to visit a LanguageObject as if it were a tree
and perform some action on some or all of the language objects that are visited.
|
LeadLagValue |
We store up to three values related to the lead/lag per row
|
LightWeightCopyOnWriteList<T> |
Creates a copy of a reference list when modified.
|
Limit |
|
LimitNode |
|
ListNestedSortComparator<T extends Comparable<? super T>> |
This class can be used for comparing lists of elements, when the fields to
be sorted on and the comparison mechanism are dynamically specified.
|
LobManager |
Tracks lob references so they are not lost during serialization.
|
LobManager.ReferenceMode |
|
LobWorkItem |
|
LogicalCriteria |
This class represents a criteria that works by logically combining other
criteria.
|
LoopInstruction |
|
LoopStatement |
This class represents a loop statement in the storedprocedure language
to cursor through a result set.
|
LrfuEvictionQueue<V extends BaseCacheEntry> |
A Concurrent LRFU eviction queue.
|
MatchCriteria |
This class represents a criteria involving a string expression to be matched
against a string expression match value.
|
MatchCriteria.PatternTranslator |
Utility to convert the pattern into a different match syntax
|
MaterializationMetadataRepository |
This Metadata Repository adds/corrects metadata for materialization
|
MaterializationMetadataRepository.ErrorAction |
|
MaterializationMetadataRepository.LoadStates |
|
MaterializationMetadataRepository.Scope |
|
Max |
|
MemoryStorageManager |
|
MergeJoinStrategy |
MergeJoinStrategy supports generalized Full, Left Outer, and Inner Joins (containing non-equi join criteria) as long as there
is at least one equi-join criteria
Additionally supports Semi and Anti-Semi Joins.
|
MergeJoinStrategy.SortOption |
|
MetaDataProcessor |
Handles MetaDataMessages on behalf of DQPCore.
|
MetadataValidator |
|
Min |
|
MultipleElementSymbol |
This is a subclass of Symbol representing multiple output columns.
|
MultiSourceElement |
TODO: introduce a real (non group context) pseudo column
|
MultiSourceElementReplacementVisitor |
|
MultiSourceMetadataWrapper |
This class is a proxy to QueryMetadataInterface.
|
NamedExpression |
An expression with a simple name, such as a function or aggregate function
|
NativeMetadataRepository |
|
NestedLoopJoinStrategy |
Nested loop is currently implemented as a degenerate case of merge join.
|
NestedTableJoinStrategy |
Variation of a nested loop join that handles nested tables
|
NewCalculateCostUtil |
|
NewCalculateCostUtil.DependentCostAnalysis |
|
NioVirtualFile |
|
NioZipFileSystem |
|
NodeConstants |
|
NodeConstants.Info |
Property names for type-specific node properties
|
NodeConstants.Types |
Types of nodes
|
NodeEditor |
This class is no longer really an editor.
|
NodeFactory |
|
NotCriteria |
A logical criteria that takes the logical NOT of the contained criteria.
|
NthValue |
|
Ntile |
Captures the row number and number of tiles for a given row
post processing logic uses the row count over the window
to calculate the final output
|
NullNode |
|
ObjectReplicator |
|
ObjectTable |
|
ObjectTable.ObjectColumn |
|
ObjectTableNode |
Handles object table processing.
|
OptimizerRule |
|
Option |
Represents MetaMatrix extension options to normal SQL.
|
Option.MakeDep |
|
Options |
A holder for options
|
OptionsUtil |
|
OrderBy |
Represents the ORDER BY clause of a query.
|
OrderByItem |
|
OutOfDiskException |
|
ParseException |
ParseException explains why and where the error occurs in source JSON text.
|
ParseException |
This exception is thrown when parse errors are encountered.
|
ParseInfo |
|
PartitionAnalyzer |
TODO: support recursive detection of partitions
Extracts a map of partitioning information from a union
|
Permutation |
|
PlanExecutionNode |
|
PlanHints |
|
PlanNode |
|
PlanToProcessConverter |
|
PlanToProcessConverter.SharedStateKey |
|
PostOrderNavigator |
|
PredicateCollectorVisitor |
Walk a tree of language objects and collect any predicate criteria that are found.
|
PredicateCriteria |
This abstract class represents a predicate criteria, which involves some
statement involving expressions and can be evaluated in the context of
a single row of data to be either true or false.
|
PredicateCriteria.Negatable |
|
PreOrderNavigator |
|
PreOrPostOrderNavigator |
|
PreparedPlan |
|
PreparedStatementRequest |
Specific request for handling prepared statement calls.
|
ProcedureContainer |
|
ProcedureContainerResolver |
|
ProcedurePlan |
|
ProcedurePlanner |
|
ProcedureReservedWords |
Special variable names in stored procedure language.
|
ProcessorDataManager |
|
ProcessorPlan |
This class represents a processor plan.
|
Program |
|
ProgramInstruction |
Abstract superclass of all program instructions.
|
ProjectIntoNode |
|
ProjectIntoNode.Mode |
|
ProjectNode |
|
Query |
A representation of a data query.
|
QueryCommand |
This is a common super class for the two types of query commands: Query and SetQuery.
|
QueryMetadataException |
This exception is thrown when an error occurs while retrieving metadata
from a query component metadata facade.
|
QueryMetadataInterface |
This interface defines the way that query components access metadata.
|
QueryNode |
The QueryNode represents a virtual or temporary group in the modeler.
|
QueryOptimizer |
This Class produces a ProcessorPlan object (a plan for query execution) from a
user's command and a source of metadata.
|
QueryParser |
Converts a SQL-string to an object version of a query.
|
QueryParserException |
Thrown when a query cannot be parsed.
|
QueryPlannerException |
This exception is thrown when an error occurs while planning the query.
|
QueryPlugin |
QueryPlugin
|
QueryPlugin.Event |
|
QueryProcessingException |
This exception is thrown when an error occurs while retrieving metadata
from a query component metadata facade.
|
QueryProcessor |
Driver for plan processing.
|
QueryProcessor.ExpiredTimeSliceException |
|
QueryProcessor.ProcessorFactory |
|
QueryProcessorFactoryImpl |
|
QueryResolver |
The QueryResolver is used between Parsing and QueryValidation.
|
QueryResolverException |
This exception represents the case where the query submitted could not resolved
when it is checked against the metadata
|
QueryRewriter |
Rewrites commands and command fragments to a form that is better for planning and execution.
|
QueryString |
Represents query string name value pairs
|
QueryValidatorException |
This exception is thrown if an error is discovered while validating the query.
|
RaiseStatement |
This class represents a error assignment statement in the storedprocedure language.
|
RankingFunction |
computes rank/dense_rank
|
RankingFunctionBig |
computes rank/dense_rank
|
Reference |
This class represents a reference (positional from the user query, or
to an element from another scope).
|
Reference.Constraint |
|
ReferenceCollectorVisitor |
This visitor class will traverse a language object tree and collect all
references it finds.
|
RegisterRequestParameter |
|
RegisterRequestParameter.SharedAccessInfo |
|
RelationalNode |
|
RelationalNodeStatistics |
|
RelationalNodeUtil |
|
RelationalPlan |
|
RelationalPlanner |
This class generates a relational plan for query execution.
|
RepeatedInstruction |
|
ReplicatedObject<K extends Serializable> |
Optional interface to be implemented by a replicated object to support full and partial state transfer.
|
ReportItem |
Represents a single item on a report
|
Request |
Server side representation of the RequestMessage.
|
RequestID |
This class represents an identifier for a request.
|
RequestWorkItem |
Compiles results and other information for the client.
|
RequestWorkItem.MoreWorkTask |
|
ResolverUtil |
Utilities used during resolution
|
ResolverUtil.ResolvedLookup |
|
ResolverVisitor |
|
ReturnInstruction |
|
ReturnStatement |
This class represents a return statement
|
RowBasedSecurityHelper |
|
RuleAccessPatternValidation |
Validates that the access pattern(s) of a source are satisfied.
|
RuleApplySecurity |
Applies row/column security to a non-update plan
Should be run after rule assign output elements
|
RuleAssignOutputElements |
This rule is responsible for assigning the output elements to every node in the
plan.
|
RuleCalculateCost |
|
RuleChooseDependent |
Finds nodes that can be turned into dependent joins
|
RuleChooseJoinStrategy |
Marks join as a candidate merge join if conditions are met
|
RuleCleanCriteria |
Removes phantom and TRUE or FALSE criteria
|
RuleCollapseSource |
|
RuleConstants |
|
RuleCopyCriteria |
For each join node this rule will find the set of criteria allowed to influence the join (the join criteria, and inner
side criteria on non full outer joins) and builds new criteria based upon the equality relationships found.
|
RuleDecomposeJoin |
Perform the optimization:
|
RuleImplementJoinStrategy |
Inserts sort nodes for specific join strategies.
|
RuleMergeCriteria |
|
RuleMergeVirtual |
|
RulePlaceAccess |
This rule finds all SOURCE nodes and associates ACCESS patterns, ACCESS nodes, and aliases.
|
RulePlanJoins |
Determines join orderings based upon dependency and cost information
The algorithm works as follows:
Stage 1.
|
RulePlanOuterJoins |
|
RulePlanProcedures |
|
RulePlanSorts |
Attempts to minimize the cost of sorting operations across the plan.
|
RulePlanSubqueries |
|
RulePlanSubqueries.PlannedResult |
|
RulePlanSubqueries.ReferenceReplacementVisitor |
Used to replace correlated references
|
RulePlanUnions |
Organizes union branches so that push down is possible.
|
RulePushAggregates |
|
RulePushLargeIn |
Look for large in predicates that were not pushed and push them as dependent set criteria
|
RulePushLimit |
Pushes limit nodes to their lowest points.
|
RulePushNonJoinCriteria |
Pushes on criteria out of the on clause if possible.
|
RulePushSelectCriteria |
|
RuleRaiseAccess |
|
RuleRaiseNull |
Will attempt to raise null nodes to their highest points
|
RuleRemoveOptionalJoins |
Removes optional join nodes if elements originating from that join are not used in the
top level project symbols.
|
RuleStack |
|
RuleSubstituteExpressions |
Substitutes column references for expressions
|
RuleValidateWhereAll |
Validates that the any atomic query being sent to a model where the model
requires a criteria actually has a criteria.
|
RuntimeMetadataImpl |
|
SaveOnReadInputStream |
|
ScalarSubquery |
This is an Expression implementation that can be used in a SELECT clause.
|
SearchableTable |
|
SearchedCaseExpression |
|
SecurityHelper |
|
SecuritySystemFunctions |
|
Select |
This class represents the SELECT clause of a query, which defines what elements
or expressions are returned from the query.
|
SelectNode |
|
Serializer<T> |
|
SessionAwareCache<T> |
This class is used to cache session aware objects
|
SessionAwareCache.CacheID |
|
SessionAwareCache.Type |
|
SessionKiller |
|
SessionService |
The session service deals with managing sessions; this involves creating
sessions, closing sessions, terminating sessions, and updating session
state.
|
SessionServiceException |
|
SetClause |
|
SetClauseList |
|
SetCriteria |
A criteria which is true is the expression's value is a member in a list
of values.
|
SetQuery |
This object acts as a Set operator on multiple Queries - UNION,
INTERSECT, and EXCEPT can be implemented with this Class
|
SetQuery.Operation |
|
SetQueryResolver |
|
SimpleContentHandler |
|
SimpleQueryResolver |
|
SimpleQueryResolver.QueryResolverVisitor |
|
SingleArgumentAggregateFunction |
|
SizeUtility |
Utility methods to determine the size of Java objects, particularly with
respect to the Teiid runtime types.
|
SortingFilter |
|
SortNode |
|
SortUtility |
Implements several modes of a multi-pass sort.
|
SortUtility.Mode |
|
SourceCapabilities |
|
SourceCapabilities.Capability |
|
SourceHint |
|
SourceHint.SpecificHint |
|
SourceTriggerActionPlanner |
Handles the planning of triggers from source events
|
SourceTriggerActionPlanner.CompositeProcessorPlan |
TODO: elevate the transaction handling?
|
SourceTriggerActionPlanner.SourceEventCommand |
Represents a source event as a Command - is localized here
as it's not directly callable by a user
|
SplittableStorageManager |
A storage manager that combines smaller files into a larger
logical file.
|
SPParameter |
Represents a StoredProcedure's parameter for encapsulation in the Query framework
This is basically a holder object set from the Server's implementation of
a stored procedure.
|
SQLParser |
The SQLParser is a JavaCC-generated parser that reads a SQL string and produces a
Query object.
|
SQLParserConstants |
Token literal values and constants.
|
SQLParserTokenManager |
Token Manager.
|
SQLParserUtil |
|
SQLParserUtil.ParsedDataType |
|
SQLStringVisitor |
The SQLStringVisitor will visit a set of language objects and return the corresponding SQL string representation.
|
Statement |
This class represents the a statement in the stored procedure language.
|
Statement.Labeled |
|
StaticSymbolMappingVisitor |
This class is used to update LanguageObjects by replacing the virtual elements/
groups present in them with their physical counterparts.
|
StatsFunction |
|
StorageManager |
|
StoredProcedure |
Represents a StoredProcedure statement of the form:
|
StoredProcedureInfo |
This class encapsulates everything needed to pass between runtime metadata
and the QueryResolver via the facades
|
STree |
Self balancing search tree using skip list like logic
This has similar performance similar to a B+/-Tree,
but with fewer updates.
|
STree.InsertMode |
|
StringAgg |
Aggregates binary and character strings
|
SubqueryAwareEvaluator |
This utility handles the work of processing a subquery; certain types
of processor nodes will use an instance of this class to do that work.
|
SubqueryAwareEvaluator.SubqueryState |
|
SubqueryAwareRelationalNode |
|
SubqueryCompareCriteria |
This class implements a quantified comparison predicate.
|
SubqueryContainer<T extends Command> |
This interface defines a common interface for all SQL objects
that contain subqueries.
|
SubqueryContainer.Evaluatable<T extends Command> |
|
SubqueryFromClause |
A FROM subpart that represents a subquery.
|
SubquerySetCriteria |
A criteria which is true is the expression's value is a member in a list
of values returned from a subquery.
|
Sum |
Accumulates (per tuple) and calculates the sum of the values
of a column.
|
SupportConstants |
|
SupportConstants.Element |
|
SupportConstants.Group |
|
SupportConstants.Model |
|
Symbol |
This is the server's representation of a metadata symbol.
|
SymbolMap |
|
SystemFunctionManager |
|
SystemFunctionMethods |
|
SystemMetadata |
|
SystemSource |
This metadata source has metadata for the hard-coded system functions.
|
TableFunctionReference |
|
TableFunctionReference.ProjectedColumn |
|
TargetedCommand |
|
TeiidExecutor |
|
TeiidFunction |
|
TeiidFunctions |
|
TeiidScriptEngine |
A simplistic script engine that supports root variable access and 0-ary methods on the subsequent objects.
|
TeiidTracingUtil |
|
TempCapabilitiesFinder |
|
TempMetadataAdapter |
This is an adapter class, it contains another instance of
QueryMetadataInterface as well as a TempMetadataStore.
|
TempMetadataID |
This class represents a temporary metadata ID.
|
TempMetadataID.TableData |
|
TempMetadataID.Type |
|
TempMetadataStore |
Store for temporary metadata discovering while resolving a query.
|
TempTable |
A Teiid Temp Table
TODO: in this implementation blocked exceptions will not happen
allowing for subquery evaluation though would cause pauses
|
TempTableDataManager |
This proxy ProcessorDataManager is used to handle temporary tables.
|
TempTableDataManager.RequestExecutor |
|
TempTableResolver |
|
TempTableStore |
TempTableStores are transactional, but do not act as full resource manager.
|
TempTableStore.RecursiveTableProcessor |
|
TempTableStore.TableProcessor |
|
TempTableStore.TransactionCallback |
|
TempTableStore.TransactionMode |
|
TextAgg |
Aggregates Text entries
|
TextLine |
Represents the only allowable expression for the textagg aggregate.
|
TextLine.ValueExtractor<T> |
|
TextTable |
Represents the TEXTTABLE table function.
|
TextTable.TextColumn |
|
TextTableNode |
Handles text file processing.
|
ThreadCpuTimer |
Timer class that uses the ThreadMXBean for CPU timing
|
ThreadReuseExecutor |
An Executor that:
minimizes thread creation
allows for proper timeout of idle threads
allows for queuing
A non-fifo (lifo) SynchronousQueue based ThreadPoolExecutor satisfies 1 and 2, but not 3.
|
ThreadReuseExecutor.PrioritizedRunnable |
|
ThreadReuseExecutor.RunnableWrapper |
|
Token |
Describes the input token stream.
|
TokenMgrError |
Token Manager Error.
|
TransactionContext |
|
TransactionContext.Scope |
|
TransactionServerImpl |
Note that the begin methods do not leave the transaction associated with the
calling thread.
|
TransactionServerImpl.TransactionMapping |
|
TransactionService |
|
TransformationMetadata |
Teiid's implementation of the QueryMetadataInterface that reads columns, groups, models etc.
|
TranslatorRepository |
|
TriggerAction |
|
TriggerActionPlanner |
|
TupleBatch |
Represents a set of indexed tuples.
|
TupleBrowser |
Implements intelligent browsing over a STree
TODO: this is not as efficient as it should be over partial matches
|
TupleBuffer |
|
TupleBufferCache |
|
TupleSource |
A cursored source of tuples.
|
TupleSourceCache |
|
TupleSourceCache.CopyOnReadTupleSource |
|
UDFMetadataRepository |
Simple metadata loader for functions
TODO: make the TeiidFunction annotation public
|
UDFSource |
|
UnaryFromClause |
A FROM subpart that represents a single group.
|
UnionAllNode |
|
UnresolvedSymbolDescription |
This helper object describes an unresolved symbol found during
query resolution.
|
Update |
Represents a SQL Update statement of the form:
"UPDATE <group> SET <element> = <expression>, ...
|
UpdateProcedureResolver |
|
UpdateResolver |
This class knows how to expand and resolve UDPATE commands.
|
UpdateValidator |
This visitor is used to validate updates through virtual groups.
|
UpdateValidator.UpdateInfo |
|
UpdateValidator.UpdateMapping |
|
UpdateValidator.UpdateType |
|
UserDefined |
|
ValidationVisitor |
|
Validator |
|
ValidatorFailure |
|
ValidatorFailure.Status |
|
ValidatorReport |
|
ValueIterator |
Interface for interating through Expressions or values.
|
ValueIteratorProviderCollectorVisitor |
This visitor class will traverse a language object tree and collect all language
objects that implement SubqueryContainer .
|
ValueIteratorSource |
The ValueIteratorSource lets a language object that needs a ValueIterator hold this
reference to the source of the ValueIterator as a reference until the ValueIterator
can be ready.
|
VariableContext |
|
VariableResolver |
|
VDBKey |
Encapsulates the name/versioning rules for VDBs
|
VDBResources |
|
VDBResources.Resource |
|
VirtualFile |
Represents a VDB File
|
WhileInstruction |
|
WhileStatement |
This class represents a while statement in the storedprocedure language.
|
WindowFrame |
Defines with window frame for a window function
|
WindowFrame.FrameBound |
|
WindowFunction |
|
WindowFunctionProjectNode |
|
WindowSpecification |
|
WithQueryCommand |
|
XMLAgg |
Aggregates XML entries
|
XMLAttributes |
Represents XMLATTRIBUTES name value pairs
|
XMLCast |
|
XMLElement |
Represents XMLElement
|
XMLExists |
|
XMLForest |
|
XMLHelper |
|
XMLNamespaces |
|
XMLNamespaces.NamespaceItem |
|
XMLParse |
|
XMLQuery |
|
XMLSerialize |
|
XMLSystemFunctions |
This class contains scalar system functions supporting for XML manipulation.
|
XMLSystemFunctions.ExtendedWriter |
An extension to the standard writer to allow for
direct inclusion of large values by reference rather than by copy
|
XMLSystemFunctions.XmlConcat |
|
XMLTable |
|
XMLTable.XMLColumn |
|
XQueryExpression |
|
Yytoken |
|