• Search by APIs
  • Search by Words
  • Search Projects
  • Java
  • Python
  • JavaScript
  • TypeScript
  • C++
  • Scala
  • Blog
Project: tajo (GitHub Link)
  • tajo-master
    • tajo-dist
      • src
        • main
          • resources
            • assemblies
              • tajo-src.xml
          • bin
            • stop-tajo.sh
            • tajo-daemons.sh
            • start-catalog.sh
            • tajo.cmd
            • tajo-config.cmd
            • tajo-dump
            • tajo-daemon.cmd
            • stop-tajo.cmd
            • tajo-config.sh
            • start-tajo.cmd
            • tajo
            • start-tajo.sh
            • tsql.cmd
            • tajo-daemon.sh
            • tsql
          • conf
            • catalog-site.xml.template
            • log4j.properties
            • workers
            • storage-site.json.template
            • tajo-env.sh
            • tajo-env.cmd
            • configuration.xsl
            • tajo-site.xml.template
      • pom.xml
    • tajo-common
      • src
        • main
          • proto
            • PrimitiveProtos.proto
            • yarn_protos.proto
            • tajo_protos.proto
            • errors.proto
            • stacktrace.proto
            • DataTypes.proto
            • Security.proto
            • TajoIdProtos.proto
            • TestProtos.proto
          • resources
            • tajo-version-info.properties
            • META-INF
              • services
                • org.apache.tajo.rule.SelfDiagnosisRuleProvider
          • java
            • log4j.properties
            • org
              • apache
                • tajo
                  • BuiltinStorages.java
                  • SessionVars.java
                  • storage
                    • Tuple.java
                    • VTuple.java
                    • NullTuple.java
                    • BufferPool.java
                    • EmptyTuple.java
                    • StorageConstants.java
                  • Assert.java
                  • OverridableConf.java
                  • TaskId.java
                  • TaskAttemptId.java
                  • QueryVars.java
                  • common
                    • Sleeper.java
                    • type
                      • TajoTypeUtil.java
                      • IPv4.java
                      • TimeRange.java
                    • ProtoObject.java
                  • util
                    • ReflectionUtil.java
                    • UnsafeUtil.java
                    • graph
                      • DirectedGraphCursor.java
                      • DirectedGraphVisitor.java
                      • DirectedGraph.java
                      • SimpleUndirectedGraph.java
                      • Graph.java
                      • SimpleDirectedGraph.java
                      • UndirectedGraph.java
                    • BitArray.java
                    • UriUtil.java
                    • BytesUtils.java
                    • JavaResourceUtil.java
                    • BasicFuture.java
                    • TajoIdUtils.java
                    • JarUtil.java
                    • NetUtils.java
                    • Bytes.java
                    • ClassUtil.java
                    • ProtoUtil.java
                    • KeyValueSet.java
                    • CompressionUtil.java
                    • NumberUtil.java
                    • datetime
                      • DateTimeUtil.java
                      • DateTimeFormat.java
                      • DateTimeConstants.java
                      • TimeMeta.java
                    • FileUtil.java
                    • TUtil.java
                    • PlatformUtil.java
                    • CommonTestingUtil.java
                    • UnsafeComparer.java
                    • VersionInfo.java
                    • ClassSize.java
                    • MurmurHash.java
                    • SizeOf.java
                    • Pair.java
                    • ShutdownHookManager.java
                    • StringUtils.java
                    • Deallocatable.java
                  • type
                    • Float4.java
                    • Bit.java
                    • Array.java
                    • ValueParamterizedType.java
                    • Protobuf.java
                    • TypeVisitor.java
                    • Any.java
                    • Numeric.java
                    • Int4.java
                    • Varchar.java
                    • Map.java
                    • Bool.java
                    • Int1.java
                    • Char.java
                    • TypeFactory.java
                    • Time.java
                    • Record.java
                    • Interval.java
                    • Int8.java
                    • package-info.java
                    • Date.java
                    • Null.java
                    • Float8.java
                    • Timestamp.java
                    • Type.java
                    • Text.java
                    • TypeStringEncoder.java
                    • TypeParamterizedType.java
                    • Int2.java
                    • TypeProtobufEncoder.java
                    • Blob.java
                  • datum
                    • Int4Datum.java
                    • BooleanDatum.java
                    • BlobDatum.java
                    • NullDatum.java
                    • Float4Datum.java
                    • protobuf
                      • AbstractCharBasedFormatter.java
                      • ProtobufFormatter.java
                      • TextUtils.java
                      • ProtobufJsonFormat.java
                    • AnyDatum.java
                    • TextDatum.java
                    • TimestampDatum.java
                    • ProtobufDatum.java
                    • DatumFactory.java
                    • Int2Datum.java
                    • Float8Datum.java
                    • DateDatum.java
                    • BitDatum.java
                    • NumericDatum.java
                    • TimeDatum.java
                    • CharDatum.java
                    • IntervalDatum.java
                    • Datum.java
                    • Int8Datum.java
                    • ProtobufDatumFactory.java
                  • service
                    • ServiceTrackerException.java
                    • TajoMasterInfo.java
                    • HAServiceTracker.java
                    • BaseServiceTracker.java
                    • ServiceTrackerFactory.java
                    • ServiceTracker.java
                  • exception
                    • TajoInternalError.java
                    • ValueTooLongForTypeCharactersException.java
                    • UndefinedFunctionException.java
                    • UndefinedIndexException.java
                    • MissingTablePropertyException.java
                    • ReturnStateUtil.java
                    • MetadataConnectionException.java
                    • SQLExceptionUtil.java
                    • InvalidOperationException.java
                    • CatalogUpgradeRequiredException.java
                    • TajoRuntimeException.java
                    • InvalidDataTypeException.java
                    • UndefinedOperatorException.java
                    • DuplicateTablespaceException.java
                    • QueryFailedException.java
                    • AmbiguousFunctionException.java
                    • SQLSyntaxError.java
                    • DuplicateDatabaseException.java
                    • DataTypeMismatchException.java
                    • UndefinedTableException.java
                    • QueryNotFoundException.java
                    • ErrorUtil.java
                    • ErrorMessages.java
                    • NotImplementedException.java
                    • UnsupportedCatalogStore.java
                    • InvalidSessionVariableException.java
                    • InvalidAddressException.java
                    • UndefinedPartitionKeyException.java
                    • DuplicateIndexException.java
                    • DuplicateFunctionException.java
                    • UnremovableTablePropertyException.java
                    • TajoException.java
                    • UndefinedPartitionMethodException.java
                    • InvalidURLException.java
                    • TajoError.java
                    • CannotDropCurrentDatabaseException.java
                    • UndefinedTablespaceHandlerException.java
                    • DuplicateColumnException.java
                    • DuplicatePartitionException.java
                    • DefaultTajoException.java
                    • UndefinedPartitionException.java
                    • InsufficientPrivilegeException.java
                    • UndefinedTablespaceException.java
                    • NoSuchSessionVariableException.java
                    • ValueOutOfRangeException.java
                    • InvalidNameException.java
                    • DividedByZeroException.java
                    • TooLargeInputForCrossJoinException.java
                    • InvalidTablePropertyException.java
                    • UndefinedDatabaseException.java
                    • ExceptionUtil.java
                    • UnsupportedException.java
                    • DuplicateTableException.java
                    • UndefinedColumnException.java
                    • AmbiguousPartitionDirectoryExistException.java
                    • UnknownDataFormatException.java
                    • InvalidValueForCastException.java
                    • UnsupportedDataTypeException.java
                    • AmbiguousTableException.java
                    • AmbiguousColumnException.java
                    • LMDNoMatchedDatatypeException.java
                    • InvalidSessionException.java
                    • InvalidInputsForCrossJoin.java
                    • QueryKilledException.java
                    • UnavailableTableLocationException.java
                  • QueryIdFactory.java
                  • ExecutionBlockId.java
                  • tuple
                    • TupleBuilder.java
                    • RowBlockReader.java
                    • BaseTupleBuilder.java
                    • memory
                      • DirectBufTuple.java
                      • FixedSizeLimitSpec.java
                      • UnSafeTupleBytesComparator.java
                      • UnSafeTuple.java
                      • ZeroCopyTuple.java
                      • UnSafeTupleList.java
                      • MemoryRowBlock.java
                      • ResizableMemoryBlock.java
                      • HeapRowBlockReader.java
                      • RowWriter.java
                      • OffHeapRowBlockReader.java
                      • RowBlock.java
                      • OffHeapRowBlockWriter.java
                      • HeapTuple.java
                      • OffHeapRowWriter.java
                      • MemoryBlock.java
                      • ResizableLimitSpec.java
                      • CompactRowBlockWriter.java
                      • OffHeapRowBlockUtils.java
                  • ha
                    • HAConstants.java
                  • validation
                    • MaxValidator.java
                    • Validators.java
                    • Validator.java
                    • NetworkAddressValidator.java
                    • LengthValidator.java
                    • MinValidator.java
                    • ConstraintViolation.java
                    • BooleanValidator.java
                    • AbstractValidator.java
                    • GroupValidator.java
                    • PathValidator.java
                    • PatternValidator.java
                    • ClassValidator.java
                    • ConstraintViolationException.java
                    • ShellVariableValidator.java
                    • PathListValidator.java
                    • RangeValidator.java
                    • JavaStringValidator.java
                    • NotNullValidator.java
                  • TajoConstants.java
                  • annotation
                    • NotNull.java
                    • NotThreadSafe.java
                    • ThreadSafe.java
                    • Nullable.java
                  • ConfigKey.java
                  • json
                    • GsonSerDerAdapter.java
                    • ClassNameSerializer.java
                    • DataTypeAdapter.java
                    • GsonHelper.java
                    • TimeZoneGsonSerdeAdapter.java
                    • CommonGsonHelper.java
                    • TypeAdapter.java
                    • DatumAdapter.java
                    • GsonObject.java
                    • PathSerializer.java
                  • auth
                    • UserRoleInfo.java
                  • schema
                    • Identifier.java
                    • Schema.java
                    • IdentifierUtil.java
                    • Field.java
                    • QualifiedIdentifier.java
                    • ANSISQLIdentifierPolicy.java
                    • package-info.java
                    • IdentifierPolicy.java
                    • TajoIdentifierPolicy.java
                    • PgSQLIdentifierPolicy.java
                  • rule
                    • SelfDiagnosisRuleSession.java
                    • EvaluationResult.java
                    • base
                      • BaseRuleProvider.java
                      • TajoConfValidationRule.java
                      • CheckHadoopRuntimeVersionRule.java
                    • EvaluationContext.java
                    • EvaluationFailedException.java
                    • SelfDiagnosisRuleDefinition.java
                    • SelfDiagnosisRuleEngine.java
                    • SelfDiagnosisRuleProvider.java
                    • SelfDiagnosisRule.java
                    • SelfDiagnosisRuleVisibility.java
                  • conf
                    • TajoConf.java
                  • unit
                    • StorageUnit.java
                    • TimeUnit.java
                  • QueryId.java
        • test
          • java
            • log4j.properties
            • org
              • apache
                • tajo
                  • common
                    • type
                      • TestIPv4.java
                      • TestTimeRange.java
                  • util
                    • TestStringUtil.java
                    • graph
                      • TestSimpleUndirectedGraph.java
                      • TestSimpleDirectedGraph.java
                    • TestBitArrayTest.java
                    • TestUriUtil.java
                    • TestDateTimeUtil.java
                    • TestDateTimeFormat.java
                    • TestNumberUtil.java
                  • type
                    • TestTypeStringEncoder.java
                    • TestTypeEncoder.java
                    • TestTypeProtobufEncoder.java
                    • TestType.java
                  • datum
                    • TestInt2Datum.java
                    • TestArithmeticOperator.java
                    • TestBitDatum.java
                    • TestFloatDatum.java
                    • TestDateDatum.java
                    • TestBoolDatum.java
                    • TestFloat8Datum.java
                    • TestTimeDatum.java
                    • protobuf
                      • TestProtobufDatum.java
                      • TestTextUtils.java
                    • TestDatumFactory.java
                    • TestTimestampDatum.java
                    • TestInt4Datum.java
                    • TestTextDatum.java
                    • TestDatum.java
                    • TestIntervalDatum.java
                    • TestBytesDatum.java
                    • TestCharDatum.java
                    • TestInt8Datum.java
                  • tuple
                    • TestBaseTupleBuilder.java
                    • memory
                      • TestUnSafeTupleBytesComparator.java
                      • TestHeapTuple.java
                      • TestMemoryRowBlock.java
                      • TestResizableSpec.java
                  • validation
                    • TestValidators.java
                  • schema
                    • TestANSISQLIdentifierPolicy.java
                    • TestSchema.java
                    • TestIdentifier.java
                    • TestTajoIdentifierPolicy.java
                  • rule
                    • TestRuleEngine.java
                    • TestRuleSession.java
      • pom.xml
    • doap_Tajo.rdf
    • tajo-project
      • src
        • site
          • resources
            • images
            • releases
              • 0.8.0
                • relnotes.html
              • 0.11.1
                • relnotes.html
              • 0.11.2
                • relnotes.html
              • 0.9.0
                • relnotes.html
              • 0.11.3
                • relnotes.html
              • 0.10.0
                • relnotes.html
              • 0.11.0
                • relnotes.html
              • 0.10.1
                • relnotes.html
          • markdown
            • source-code.md
            • mailing-lists.md
            • irc.md
            • tajo-0.8.0-doc.md
            • releases
              • 0.8.0
                • announcement.md
              • 0.11.1
                • announcement.md
              • 0.11.2
                • announcement.md
              • 0.9.0
                • announcement.md
              • 0.11.3
                • announcement.md
              • 0.10.0
                • announcement.md
              • 0.11.0
                • announcement.md
              • 0.10.1
                • announcement.md
            • review-request-tool.md
            • tajo-0.2.0-doc.md
            • downloads.md
          • site.xml
          • apt
            • index.apt
          • fml
            • faq.fml
      • pom.xml
    • BUILDING
    • tajo-plan
      • src
        • main
          • proto
            • Plan.proto
          • java
            • org
              • apache
                • tajo
                  • plan
                    • expr
                      • WindowFunctionEval.java
                      • NotEval.java
                      • CaseWhenEval.java
                      • BetweenPredicateEval.java
                      • EvalNodeVisitor.java
                      • SimilarToPredicateEval.java
                      • ValueSetEval.java
                      • AlgebraicUtil.java
                      • EvalNode.java
                      • EvalTreeUtil.java
                      • GeneralFunctionEval.java
                      • LikePredicateEval.java
                      • AggregationFunctionCallEval.java
                      • CastEval.java
                      • SignedEval.java
                      • AlgebraicException.java
                      • EvalType.java
                      • PatternMatchPredicateEval.java
                      • IsNullEval.java
                      • EvalContext.java
                      • EvalNodeVisitor2.java
                      • ConstEval.java
                      • PartialBinaryExpr.java
                      • InvalidEvalException.java
                      • BasicEvalNodeVisitor.java
                      • FieldEval.java
                      • SubqueryEval.java
                      • EvalTreeFactory.java
                      • BinaryEval.java
                      • SimpleEvalNodeVisitor.java
                      • RowConstantEval.java
                      • RegexPredicateEval.java
                      • FunctionEval.java
                      • UnaryEval.java
                      • InEval.java
                    • algebra
                      • AlgebraVisitor.java
                      • BaseAlgebraVisitor.java
                    • NamedExprsManager.java
                    • joinorder
                      • JoinVertex.java
                      • JoinOrderAlgorithm.java
                      • JoinGraphContext.java
                      • RelationVertex.java
                      • Edge.java
                      • JoinGraph.java
                      • FoundJoinOrder.java
                      • JoinedRelationsVertex.java
                      • GreedyHeuristicJoinOrderAlgorithm.java
                      • JoinOrderingUtil.java
                      • JoinEdge.java
                    • rewrite
                      • LogicalPlanPreprocessPhaseProvider.java
                      • LogicalPlanTestRuleProvider.java
                      • LogicalPlanRewriteRule.java
                      • BaseLogicalPlanPreprocessEngine.java
                      • LogicalPlanPreprocessEngine.java
                      • BaseLogicalPlanRewriteRuleProvider.java
                      • BaseLogicalPlanPreprocessPhaseProvider.java
                      • SelfDescSchemaBuildPhase.java
                      • TableStatUpdateRewriter.java
                      • LogicalPlanRewriteRuleContext.java
                      • rules
                        • CommonConditionReduceRule.java
                        • AccessPathRewriter.java
                        • FilterPushDownRule.java
                        • SeqScanInfo.java
                        • LogicalPlanEqualityTester.java
                        • IndexScanInfo.java
                        • InSubqueryRewriteRule.java
                        • AccessPathInfo.java
                        • PartitionedTableRewriter.java
                        • ProjectionPushDownRule.java
                      • LogicalPlanRewriteEngine.java
                      • LogicalPlanPreprocessPhase.java
                      • LogicalPlanRewriteRuleProvider.java
                      • BaseLogicalPlanRewriteEngine.java
                      • BaseSchemaBuildPhase.java
                    • ExprNormalizer.java
                    • StorageService.java
                    • serder
                      • EvalNodeAdapter.java
                      • PlanGsonHelper.java
                      • LogicalNodeDeserializer.java
                      • LogicalNodeAdapter.java
                      • EvalNodeSerializer.java
                      • package-info.java
                      • LogicalNodeSerializer.java
                      • EvalNodeDeserializer.java
                    • function
                      • PythonAggFunctionInvoke.java
                      • ClassBasedAggFunctionInvoke.java
                      • stream
                        • InputHandler.java
                        • TextFieldSerializerDeserializer.java
                        • TextLineSerDe.java
                        • StreamingUtil.java
                        • CSVLineDeserializer.java
                        • ByteBufLineReader.java
                        • OutputHandler.java
                        • CSVLineSerDe.java
                        • ByteBufInputChannel.java
                        • CSVLineSerializer.java
                        • TextLineDeserializer.java
                        • BufferPool.java
                        • FieldSerializerDeserializer.java
                        • TextLineParsingError.java
                        • TextLineSerializer.java
                        • LineSplitProcessor.java
                        • FieldSplitProcessor.java
                      • AggFunctionInvoke.java
                      • HiveFunctionInvoke.java
                      • FunctionInvokeContext.java
                      • python
                        • TajoScriptEngine.java
                        • PythonScriptEngine.java
                      • AggFunction.java
                      • PythonFunctionInvoke.java
                      • WindowAggFunc.java
                      • FunctionInvoke.java
                      • ClassBasedScalarFunctionInvoke.java
                      • FunctionContext.java
                      • GeneralFunction.java
                    • exprrewrite
                      • EvalTreeOptimizer.java
                      • EvalTreeOptimizationRule.java
                      • rules
                        • ConstantFolding.java
                        • ConstantPropagation.java
                    • visitor
                      • ExplainLogicalPlanVisitor.java
                      • LogicalPlanVisitor.java
                      • BasicLogicalPlanVisitor.java
                      • SimpleAlgebraVisitor.java
                    • annotator
                      • Prioritized.java
                    • LogicalPlan.java
                    • util
                      • PartitionFilterAlgebraVisitor.java
                      • WritableTypeConverter.java
                      • ExprFinder.java
                      • EvalNodeToExprConverter.java
                      • PlannerUtil.java
                    • LogicalPlanner.java
                    • Target.java
                    • verifier
                      • SyntaxErrorException.java
                      • SyntaxErrorUtil.java
                      • ExprsVerifier.java
                      • PostLogicalPlanVerifier.java
                      • PreLogicalPlanVerifier.java
                      • LogicalPlanVerifier.java
                      • VerificationState.java
                    • PlanString.java
                    • logical
                      • PartitionedTableScanNode.java
                      • LogicalNodeVisitor.java
                      • SetOperationNode.java
                      • SetSessionNode.java
                      • JoinNode.java
                      • GroupbyNode.java
                      • BinaryNode.java
                      • TableSubQueryNode.java
                      • CreateIndexNode.java
                      • LimitNode.java
                      • ShuffleFileWriteNode.java
                      • EvalExprNode.java
                      • ScanNode.java
                      • DistinctGroupbyNode.java
                      • AlterTableNode.java
                      • TruncateTableNode.java
                      • CreateTableNode.java
                      • WindowSpec.java
                      • WindowAggNode.java
                      • ExceptNode.java
                      • UnaryNode.java
                      • JoinSpec.java
                      • RelationNode.java
                      • GroupElement.java
                      • DropIndexNode.java
                      • DropDatabaseNode.java
                      • PersistentStoreNode.java
                      • UnionNode.java
                      • SelectionNode.java
                      • ProjectionNode.java
                      • SortNode.java
                      • DropTableNode.java
                      • HavingNode.java
                      • LogicalRootNode.java
                      • StoreTableNode.java
                      • LogicalNode.java
                      • CreateDatabaseNode.java
                      • IntersectNode.java
                      • Projectable.java
                      • AlterTablespaceNode.java
                      • NodeType.java
                      • IndexScanNode.java
                      • SelectableNode.java
                      • InsertNode.java
                    • ExprAnnotator.java
                    • LogicalOptimizer.java
                    • TypeDeterminant.java
                    • nameresolver
                      • NameResolvingMode.java
                      • ResolverByLegacy.java
                      • ResolverByRels.java
                      • ResolverBySubExprsAndRels.java
                      • NameResolver.java
                      • ResolverByRelsAndSubExprs.java
                    • TablePropertyUtil.java
                    • LogicalPlanPreprocessor.java
        • test
          • java
            • org
              • apache
                • tajo
                  • plan
                    • TestLogicalNode.java
                    • TestExprAnnotator.java
                    • util
                      • TestWritableTypeConverter.java
      • pom.xml
    • tajo-client-example
      • src
        • main
          • java
            • org
              • apache
                • tajo
                  • client
                    • v2
                      • example
                        • TajoClientAsyncExample.java
                        • TajoClientExample.java
                    • v1
                      • example
                        • TableExample.java
      • pom.xml
    • CHANGES
    • pom.xml
    • tajo-maven-plugins
      • src
        • main
          • java
            • org
              • apache
                • tajo
                  • maven
                    • plugin
                      • protoc
                        • ProtocMojo.java
                      • util
                        • Exec.java
                        • FileSetUtils.java
                      • versioninfo
                        • VersionInfoMojo.java
      • pom.xml
    • tajo-cli
      • src
        • main
          • java
            • org
              • apache
                • tajo
                  • cli
                    • tools
                      • TajoDump.java
                      • TajoAdmin.java
                      • TajoGetConf.java
                      • TajoHAAdmin.java
                    • tsql
                      • DefaultTajoCliOutputFormatter.java
                      • TajoCliOutputFormatter.java
                      • CliClientParamsFactory.java
                      • InvalidStatementException.java
                      • commands
                        • HelpCommand.java
                        • SetCommand.java
                        • CopyrightCommand.java
                        • TajoGetConfCommand.java
                        • ListDatabaseCommand.java
                        • ExitCommand.java
                        • HdfsCommand.java
                        • ExecExternalShellCommand.java
                        • TajoShellCommand.java
                        • TajoAdminCommand.java
                        • UnsetCommand.java
                        • TajoHAAdminCommand.java
                        • DescFunctionCommand.java
                        • ConnectDatabaseCommand.java
                        • VersionCommand.java
                        • DescTableCommand.java
                      • TajoCli.java
                      • TajoFileHistory.java
                      • ParsedResult.java
                      • SimpleParser.java
      • pom.xml
    • tajo-core
      • src
        • main
          • proto
            • ResourceTrackerProtocol.proto
            • QueryCoordinatorProtocol.proto
            • InternalTypes.proto
            • ResourceProtos.proto
            • QueryMasterProtocol.proto
            • TajoWorkerProtocol.proto
          • resources
            • log4j.properties
            • catalog-default.xml
            • webapps
              • admin
                • query_executor.jsp
                • querytasks.jsp
                • query.jsp
                • header.jsp
                • task.jsp
                • getCSV.jsp
                • catalogview.jsp
                • thread.jsp
                • functions.jsp
                • env.jsp
                • index.jsp
                • querydetail.jsp
                • WEB-INF
                  • jetty-web.xml
                  • web.xml
                • conf.jsp
                • cluster.jsp
              • worker
                • querytasks.jsp
                • header.jsp
                • task.jsp
                • thread.jsp
                • env.jsp
                • index.jsp
                • querydetail.jsp
                • taskhistory.jsp
                • WEB-INF
                  • web.xml
                • conf.jsp
                • queryplan.jsp
                • taskdetail.jsp
              • static
                • img
                  • logo_tajo.gif
                  • tajochar_queries_small.jpg
                  • tajochar_worker_small.jpg
                  • tajochar_catalog_small.jpg
                  • tajochar_title_small.jpg
                  • tajochar_small.jpg
                  • tajochar_title.jpg
                  • on.jpg
                  • tajochar_middle.jpg
                  • tajochar_little.jpg
                • style.css
                • queryplan.css
                • js
                  • jquery.js
                  • jquery.jsPlumb-1.3.16-all-min.js
                  • jquery-ui.min.js
            • python
              • tajo_util.py
              • controller.py
              • __init__.py
            • META-INF
              • services
                • org.apache.tajo.rule.SelfDiagnosisRuleProvider
            • tajo-default.xml
            • tajo-metrics.properties
          • java
            • log4j.properties
            • org
              • apache
                • tajo
                  • resource
                    • ResourceCalculator.java
                    • DefaultResourceCalculator.java
                    • NodeResources.java
                    • NodeResource.java
                  • master
                    • QueryInfo.java
                    • QueryManager.java
                    • TajoMasterClientService.java
                    • scheduler
                      • SchedulingAlgorithms.java
                      • QuerySchedulingInfo.java
                      • TajoResourceScheduler.java
                      • event
                        • SchedulerEvent.java
                        • SchedulerEventType.java
                        • ResourceReserveSchedulerEvent.java
                      • QueueState.java
                      • QueueInfo.java
                      • SimpleScheduler.java
                      • AbstractQueryScheduler.java
                      • Scheduler.java
                    • rm
                      • NodeReconnectEvent.java
                      • TajoResourceTracker.java
                      • TajoRMContext.java
                      • NodeStatusEvent.java
                      • NodeState.java
                      • NodeStatus.java
                      • NodeEventType.java
                      • TajoResourceManager.java
                      • WorkerResource.java
                      • NodeEvent.java
                      • NodeLivelinessMonitor.java
                    • event
                      • TaskRequestEvent.java
                      • TaskAttemptToSchedulerEvent.java
                      • QueryEventType.java
                      • QueryEvent.java
                      • FragmentScheduleEvent.java
                      • TaskAttemptEvent.java
                      • StageDiagnosticsUpdateEvent.java
                      • TaskEvent.java
                      • TaskSchedulerEvent.java
                      • TaskAttemptScheduleEvent.java
                      • TaskAttemptAssignedEvent.java
                      • QueryMasterQueryCompletedEvent.java
                      • QueryStopEvent.java
                      • QueryCompletedEvent.java
                      • QueryDiagnosticsUpdateEvent.java
                      • StageShuffleReportEvent.java
                      • QueryStartEvent.java
                      • TaskEventType.java
                      • StageEventType.java
                      • TaskAttemptEventType.java
                      • TaskAttemptStatusUpdateEvent.java
                      • StageCompletedEvent.java
                      • TaskTAttemptFailedEvent.java
                      • TaskTAttemptEvent.java
                      • TaskFatalErrorEvent.java
                      • StageEvent.java
                      • LocalTaskEventType.java
                      • StageTaskEvent.java
                      • TaskCompletionEvent.java
                      • LocalTaskEvent.java
                      • StageTaskFailedEvent.java
                    • QueryCoordinatorService.java
                    • GlobalEngine.java
                    • TaskState.java
                    • cluster
                      • WorkerConnectionInfo.java
                    • rule
                      • FileSystemRule.java
                      • MasterRuleProvider.java
                    • QueryInProgress.java
                    • TajoMaster.java
                    • exec
                      • ExplainGlobalPlanPreprocessorForTest.java
                      • NonForwardQueryResultSystemScanner.java
                      • CreateTableExecutor.java
                      • prehook
                        • CreateTableHook.java
                        • InsertIntoHook.java
                        • DistributedQueryHookManager.java
                        • DistributedQueryHook.java
                      • NonForwardQueryResultFileScanner.java
                      • NonForwardQueryResultScanner.java
                      • DDLExecutor.java
                      • QueryExecutor.java
                      • ExplainPlanPreprocessorForTest.java
                  • util
                    • JSPUtil.java
                    • TimeZoneUtil.java
                    • JvmPauseMonitor.java
                    • GeoIPUtil.java
                    • RpcParameterFactory.java
                    • IPconvertUtil.java
                    • ApplicationIdUtils.java
                    • TajoUncaughtExceptionHandler.java
                    • history
                      • HistoryReader.java
                      • HistoryCleaner.java
                      • HistoryWriter.java
                      • StageHistory.java
                      • TaskHistory.java
                      • QueryHistory.java
                      • History.java
                    • SplitUtil.java
                    • metrics
                      • LogEventGaugeSet.java
                      • RegexpMetricsFilter.java
                      • TajoJMXObjectNameFactory.java
                      • TajoMetrics.java
                      • GroupNameMetricsFilter.java
                      • TajoSystemMetrics.java
                      • MetricsFilterList.java
                      • TajoLogEventCounter.java
                      • reporter
                        • TajoMetricsScheduledReporter.java
                        • MetricsConsoleScheduledReporter.java
                        • NullReporter.java
                        • TajoMetricsReporter.java
                        • MetricsFileScheduledReporter.java
                        • GangliaReporter.java
                        • MetricsStreamScheduledReporter.java
                        • MetricsConsoleReporter.java
                  • engine
                    • utils
                      • CacheHolder.java
                      • TableCacheKey.java
                      • test
                        • ErrorInjectionRewriter.java
                      • TupleUtil.java
                      • TableCache.java
                    • function
                      • builtin
                        • SumLong.java
                        • SumFloatDistinct.java
                        • LastValueString.java
                        • SumFloat.java
                        • SumIntDistinct.java
                        • StdDevPopLong.java
                        • CoalesceTimestamp.java
                        • LeadDouble.java
                        • LeadLong.java
                        • MinTime.java
                        • LastValueLong.java
                        • RandomInt.java
                        • Min.java
                        • StdDevSamp.java
                        • StdDevPop.java
                        • StdDevSampInt.java
                        • LastValueTimestamp.java
                        • VarSampDouble.java
                        • CoalesceLong.java
                        • LeadTime.java
                        • LastValue.java
                        • LeadString.java
                        • SumLongDistinct.java
                        • LeadTimestamp.java
                        • LastValueDate.java
                        • MaxTimestamp.java
                        • MaxString.java
                        • SumInt.java
                        • StdDevSampLong.java
                        • CoalesceDouble.java
                        • MinString.java
                        • MaxLong.java
                        • StdDevSampFloat.java
                        • Variance.java
                        • StdDevPopFloat.java
                        • CountRows.java
                        • Max.java
                        • CoalesceDate.java
                        • MinDouble.java
                        • VarPopDouble.java
                        • SumDouble.java
                        • LeadDate.java
                        • LastValueInt.java
                        • MinInt.java
                        • StringAgg.java
                        • CoalesceTime.java
                        • VarPopLong.java
                        • VarPop.java
                        • Date.java
                        • VarSamp.java
                        • VarPopInt.java
                        • LeadInt.java
                        • LastValueDouble.java
                        • CountValue.java
                        • Coalesce.java
                        • Corr.java
                        • LeadFloat.java
                        • AvgLong.java
                        • CoalesceBoolean.java
                        • VarSampFloat.java
                        • LastValueFloat.java
                        • MaxDouble.java
                        • Sleep.java
                        • MaxFloat.java
                        • VarPopFloat.java
                        • MaxTime.java
                        • StdDevSampDouble.java
                        • Lead.java
                        • StdDevPopDouble.java
                        • AvgInt.java
                        • MinDate.java
                        • AvgDouble.java
                        • StdDevPopInt.java
                        • MinLong.java
                        • SumDoubleDistinct.java
                        • MaxInt.java
                        • MinFloat.java
                        • MinTimestamp.java
                        • AvgFloat.java
                        • CountValueDistinct.java
                        • MaxDate.java
                        • VarSampLong.java
                        • LastValueTime.java
                        • VarSampInt.java
                        • CoalesceString.java
                      • window
                        • Lag.java
                        • LagTimestamp.java
                        • FirstValueDate.java
                        • Rank.java
                        • LagString.java
                        • LagTime.java
                        • FirstValueInt.java
                        • LagLong.java
                        • FirstValueLong.java
                        • FirstValueString.java
                        • LagFloat.java
                        • LagInt.java
                        • FirstValueTime.java
                        • LagDate.java
                        • LagDouble.java
                        • FirstValue.java
                        • FirstValueFloat.java
                        • FirstValueTimestamp.java
                        • RowNumber.java
                        • FirstValueDouble.java
                      • geoip
                        • GeoIPCountryText.java
                        • GeoIPCountryInt.java
                        • IPstrToInt.java
                        • GeoIPInCountryBlob.java
                        • GeoIPInCountryText.java
                        • BlobToIPstr.java
                        • GeoIPInCountryInt.java
                        • GeoIPCountryBlob.java
                        • IntToIPstr.java
                        • IPstrToBlob.java
                      • FailFunction.java
                      • datetime
                        • ToCharTimestamp.java
                        • AddMonths.java
                        • CurrentTime.java
                        • ToTimestampInt.java
                        • ToTimestampText.java
                        • DatePartFromTimestamp.java
                        • CurrentDate.java
                        • DatePartFromTime.java
                        • AddDays.java
                        • NowTimestamp.java
                        • DatePartFromDate.java
                        • ToDate.java
                        • DateTimePartFromUnixTimestamp.java
                      • hiveudf
                        • HiveFunctionLoader.java
                      • math
                        • Asin.java
                        • Round.java
                        • AbsFloat.java
                        • Atan.java
                        • Cos.java
                        • RoundFloat8.java
                        • Cbrt.java
                        • Ceil.java
                        • MathFunctions.java
                        • Tan.java
                        • Floor.java
                        • Atan2.java
                        • Sign.java
                        • Mod.java
                        • AbsLong.java
                        • Radians.java
                        • Acos.java
                        • Sqrt.java
                        • Div.java
                        • Sin.java
                        • Pow.java
                        • AbsInt.java
                        • Pi.java
                        • Exp.java
                        • AbsDouble.java
                        • Degrees.java
                      • annotation
                        • ParamOptionTypes.java
                        • ParamTypes.java
                        • Description.java
                      • json
                        • ScalarJsonFunction.java
                        • JsonArrayLength.java
                        • JsonArrayGet.java
                        • JsonArrayContains.java
                        • JsonExtractPathText.java
                      • FunctionLoader.java
                      • string
                        • Reverse.java
                        • Left.java
                        • Locate.java
                        • Concat.java
                        • InitCap.java
                        • SplitPart.java
                        • BitLength.java
                        • Digest.java
                        • Right.java
                        • Encode.java
                        • Lower.java
                        • CharLength.java
                        • FindInSet.java
                        • ToBin.java
                        • Chr.java
                        • Rpad.java
                        • Lpad.java
                        • QuoteIdent.java
                        • Substr.java
                        • HexStringConverter.java
                        • StrPos.java
                        • ToCharLong.java
                        • BTrim.java
                        • Ascii.java
                        • LTrim.java
                        • RegexpReplace.java
                        • Repeat.java
                        • Upper.java
                        • Decode.java
                        • StrPosb.java
                        • Concat_ws.java
                        • Length.java
                        • OctetLength.java
                        • RTrim.java
                        • Md5.java
                        • ToHex.java
                    • planner
                      • global
                        • ExecutionBlockCursor.java
                        • ExecutionBlock.java
                        • GlobalPlanner.java
                        • rewriter
                          • GlobalPlanRewriteRule.java
                          • GlobalPlanRewriteEngine.java
                          • GlobalPlanRewriteRuleProvider.java
                          • GlobalPlanTestRuleProvider.java
                          • rules
                            • GlobalPlanRewriteUtil.java
                            • BroadcastJoinRule.java
                            • GlobalPlanEqualityTester.java
                          • BaseGlobalPlanRewriteRuleProvider.java
                        • builder
                          • DistinctGroupbyBuilder.java
                        • MasterPlan.java
                        • DataChannel.java
                        • ExecutionQueue.java
                        • ParallelExecutionQueue.java
                      • UniformRangePartition.java
                      • RangePartitionAlgorithm.java
                      • enforce
                        • Enforcer.java
                      • Projector.java
                      • KeyProjector.java
                      • PhysicalPlannerImpl.java
                      • PhysicalPlanner.java
                      • PhysicalPlanningException.java
                      • physical
                        • PhysicalExecutorVisitor.java
                        • PhysicalPlanUtil.java
                        • ScanExec.java
                        • DistinctGroupbyFirstAggregationExec.java
                        • MergeFullOuterJoinExec.java
                        • BasicPhysicalExecutorVisitor.java
                        • EmptyScanIterator.java
                        • HavingExec.java
                        • HashLeftAntiJoinExec.java
                        • HashAggregateExec.java
                        • KeyTuple.java
                        • LimitExec.java
                        • MergeJoinExec.java
                        • EvalExprExec.java
                        • TupleMap.java
                        • PartitionMergeScanExec.java
                        • ProjectionExec.java
                        • WindowAggExec.java
                        • StoreIndexExec.java
                        • DistinctGroupbySecondAggregationExec.java
                        • TunnelExec.java
                        • TupleSorter.java
                        • SelectionExec.java
                        • SortExec.java
                        • BinaryPhysicalExec.java
                        • ColPartitionStoreExec.java
                        • HashFullOuterJoinExec.java
                        • TupleList.java
                        • VectorizedSorter.java
                        • RadixSort.java
                        • BSTIndexScanExec.java
                        • FullScanIterator.java
                        • UnionExec.java
                        • HashPartitioner.java
                        • ExternalSortExec.java
                        • TupleSet.java
                        • RangeShuffleFileWriteExec.java
                        • JoinTupleComparator.java
                        • FilterScanIterator.java
                        • CommonHashJoinExec.java
                        • DistinctGroupbyThirdAggregationExec.java
                        • DistinctGroupbyHashAggregationExec.java
                        • HashJoinExec.java
                        • HashLeftOuterJoinExec.java
                        • DistinctGroupbySortAggregationExec.java
                        • HashLeftSemiJoinExec.java
                        • InsertRowsExec.java
                        • ScanIterator.java
                        • CommonJoinExec.java
                        • ComparableVector.java
                        • PhysicalExec.java
                        • SortAggregateExec.java
                        • SeqScanExec.java
                        • RightOuterMergeJoinExec.java
                        • SortBasedColPartitionStoreExec.java
                        • UnaryPhysicalExec.java
                        • HashShuffleFileWriteExec.java
                        • Partitioner.java
                        • SortIntersectExec.java
                        • SetTupleComparator.java
                        • HashBasedColPartitionStoreExec.java
                        • StoreTableExec.java
                        • AggregationExec.java
                        • IndexExecutorUtil.java
                    • query
                      • TaskRequestImpl.java
                      • QueryContext.java
                      • TaskRequest.java
                    • exception
                      • RangeOverflowException.java
                    • codegen
                      • EvalCodeGenerator.java
                      • ExecutorPreCompiler.java
                      • LegacyFunctionBindingEmitter.java
                      • EvalCodeGenContext.java
                      • ScalarFunctionBindingEmitter.java
                      • TajoGeneratorAdapter.java
                      • TajoClassLoader.java
                      • CompilationError.java
                      • CaseWhenSwitchGenerator.java
                      • VariablesPreBuilder.java
                      • CaseWhenEmitter.java
                      • CodeGenUtils.java
                      • EvalCodeEmitter.java
                    • json
                      • CoreGsonHelper.java
                  • io
                    • AsyncTaskService.java
                  • ha
                    • HdfsServiceTracker.java
                  • metrics
                    • ClusterResourceMetricSet.java
                  • webapp
                    • HttpServer.java
                    • QueryExecutorServlet.java
                    • StaticHttpServer.java
                  • worker
                    • TaskImpl.java
                    • TaskAttemptContext.java
                    • Task.java
                    • TajoWorker.java
                    • RemoteFetcher.java
                    • DeletionService.java
                    • TajoQueryEngine.java
                    • FetchImpl.java
                    • TaskHistory.java
                    • TaskContainer.java
                    • event
                      • QMResourceAllocateEvent.java
                      • NodeResourceAllocateEvent.java
                      • TaskManagerEvent.java
                      • NodeStatusEvent.java
                      • QueryStopEvent.java
                      • TaskStartEvent.java
                      • NodeResourceDeallocateEvent.java
                      • NodeResourceEvent.java
                      • ExecutionBlockStopEvent.java
                      • ExecutionBlockErrorEvent.java
                    • TajoWorkerClientService.java
                    • ExecutionBlockSharedResource.java
                    • NodeResourceManager.java
                    • TaskManager.java
                    • TajoWorkerManagerService.java
                    • LocalFetcher.java
                    • AbstractFetcher.java
                    • rule
                      • WorkerRuleProvider.java
                      • ConnectivityCheckerRuleForTajoWorker.java
                    • TaskExecutor.java
                    • ExecutionBlockContext.java
                    • NodeStatusUpdater.java
                  • session
                    • SessionEvent.java
                    • SessionConstants.java
                    • SessionManager.java
                    • Session.java
                    • SessionEventType.java
                    • SessionLivelinessMonitor.java
                    • NoSuchSessionVariableException.java
                  • ws
                    • rs
                      • JerseyResourceDelegate.java
                      • JerseyResourceDelegateUtil.java
                      • resources
                        • FunctionsResource.java
                        • SessionsResource.java
                        • QueryResource.java
                        • TablesResource.java
                        • DatabasesResource.java
                        • outputs
                          • CSVStreamingOutput.java
                          • AbstractStreamingOutput.java
                          • RestOutputFactory.java
                          • BinaryStreamingOutput.java
                        • ClusterResource.java
                        • QueryResultResource.java
                      • TajoRestService.java
                      • JerseyResourceDelegateContextKey.java
                      • JerseyResourceDelegateContext.java
                      • responses
                        • ExceptionResponse.java
                        • GetQueryResultDataResponse.java
                        • NewSessionResponse.java
                        • DatabaseInfoResponse.java
                        • WorkerConnectionInfoResponse.java
                        • WorkerResponse.java
                        • ResultSetInfoResponse.java
                        • GetSubmitQueryResponse.java
                      • annotation
                        • RestReturnType.java
                      • ClientApplication.java
                      • ResourcesUtil.java
                      • requests
                        • NewSessionRequest.java
                        • SubmitQueryRequest.java
                        • NewDatabaseRequest.java
                  • benchmark
                    • Driver.java
                    • SimpleQuery.java
                    • TPCH.java
                    • BenchmarkSet.java
                  • parser
                    • sql
                      • SQLErrorListener.java
                      • SQLAnalyzer.java
                      • SQLParseError.java
                  • querymaster
                    • QueryMaster.java
                    • AbstractTaskScheduler.java
                    • StageState.java
                    • Repartitioner.java
                    • TaskSchedulerContext.java
                    • Task.java
                    • TaskSchedulerFactory.java
                    • FetchScheduleEvent.java
                    • Query.java
                    • DefaultTaskScheduler.java
                    • QueryMasterTask.java
                    • QueryJobEvent.java
                    • TaskAttempt.java
                    • Stage.java
                    • QueryMasterManagerService.java
      • pom.xml
      • benchmark
        • simple
          • groupby2.sql
          • groupby1.sql
          • selection2.sql
          • selection1.sql
          • selection3.sql
        • tpch
          • q12.sql
          • q3.sql
          • q13.sql
          • lineitem.schema
          • partsupp.schema
          • q20.sql
          • q6.sql
          • q19.sql
          • q11.sql
          • nation.schema
          • region.schema
          • q4.sql
          • q5.sql
          • q18.sql
          • part.schema
          • q8.sql
          • q22.sql
          • q21.sql
          • q10.sql
          • supplier.schema
          • q9.sql
          • q14.sql
          • customer.schema
          • q7.sql
          • q16.sql
          • q15.sql
          • orders.schema
          • q2.sql
          • q1.sql
          • q17.sql
    • tajo-metrics
      • src
        • main
          • proto
            • node_metrics.proto
            • master_metrics.proto
          • java
            • org
              • apache
                • tajo
                  • metrics
                    • MetricsUtil.java
        • test
          • java
            • org
              • apache
                • tajo
                  • metrics
                    • TestMetricsUtil.java
      • pom.xml
    • LICENSE
    • tajo-docs
      • src
        • main
          • sphinx
            • functions.rst
            • sql_language
              • ddl.rst
              • insert.rst
              • joins.rst
              • alter_table.rst
              • predicates.rst
              • queries.rst
              • data_model.rst
              • explain.rst
              • sql_expression.rst
            • configuration
              • tajo-site-xml.rst
              • worker_configuration.rst
              • catalog_configuration.rst
              • preliminary.rst
              • service_config_defaults.rst
              • pullserver_configuration.rst
              • ha_configuration.rst
              • catalog-site-xml.rst
              • storage-site-json.rst
              • tajo_master_configuration.rst
              • cluster_setup.rst
            • functions
              • window_func.rst
              • python.rst
              • hivefunc.rst
              • datetime_func_and_operators.rst
              • json_func.rst
              • network_func_and_operators.rst
              • string_func_and_operators.rst
              • math_func_and_operators.rst
              • agg_func.rst
              • data_type_func_and_operators.rst
            • table_partitioning.rst
            • jdbc_driver.rst
            • index
              • types.rst
              • how_to_use.rst
              • future_work.rst
            • faq.rst
            • table_management.rst
            • index_overview.rst
            • themes
              • sphinx_rtd_theme
                • versions.html
                • theme.conf
                • breadcrumbs.html
                • footer.html
                • layout.html
                • __init__.py
                • searchbox.html
                • search.html
                • layout_old.html
                • static
                  • fonts
                    • fontawesome-webfont.svg
                  • js
                    • theme.js
                  • css
                    • badge_only.css
                    • theme.css
            • sql_language.rst
            • table_management
              • orc.rst
              • data_formats.rst
              • parquet.rst
              • rcfile.rst
              • table_overview.rst
              • json.rst
              • tablespaces.rst
              • sequencefile.rst
              • text.rst
              • compression.rst
            • storage_plugins.rst
            • introduction.rst
            • time_zone.rst
            • backup_and_restore.rst
            • getting_started.rst
            • tajo_client_api.rst
            • hbase_integration.rst
            • storage_plugins
              • overview.rst
              • postgresql.rst
            • tsql.rst
            • swift_integration.rst
            • hive_integration.rst
            • partitioning
              • range_partitioning.rst
              • intro_to_partitioning.rst
              • hash_partitioning.rst
              • column_partitioning.rst
            • index.rst
            • conf.py
            • backup_and_restore
              • catalog.rst
            • configuration.rst
            • tsql
              • dfs_command.rst
              • admin_command.rst
              • variables.rst
              • intro.rst
              • execute_file.rst
              • single_command.rst
              • meta_command.rst
              • background_command.rst
      • Makefile
      • BUILDING
      • pom.xml
    • tajo-pullserver
      • src
        • main
          • java
            • org
              • apache
                • tajo
                  • pullserver
                    • retriever
                      • FileChunkMeta.java
                      • DataRetriever.java
                      • FileChunk.java
                      • DirectoryRetriever.java
                      • AdvancedDataRetriever.java
                      • IndexCacheKey.java
                      • RetrieverHandler.java
                    • TajoPullServer.java
                    • FadvisedChunkedFile.java
                    • PullServerUtil.java
                    • FileCloseListener.java
                    • FileAccessForbiddenException.java
                    • HttpDataServerHandler.java
                    • PullServerConstants.java
                    • TajoPullServerService.java
                    • FadvisedFileRegion.java
                    • HttpDataServerChannelInitializer.java
                    • HttpUtil.java
      • pom.xml
    • tajo-algebra
      • src
        • main
          • java
            • org
              • apache
                • tajo
                  • algebra
                    • CastExpr.java
                    • Limit.java
                    • PatternMatchPredicate.java
                    • AlterTablespaceSetType.java
                    • UnaryOperator.java
                    • ExprVisitor.java
                    • Expr.java
                    • AlterTable.java
                    • ColumnDefinition.java
                    • JsonSerializable.java
                    • SignedExpr.java
                    • CreateIndex.java
                    • NullLiteral.java
                    • SetSession.java
                    • WindowSpec.java
                    • JoinType.java
                    • ColumnReferenceExpr.java
                    • SetOperation.java
                    • TimestampLiteral.java
                    • FunctionExpr.java
                    • NotExpr.java
                    • Sort.java
                    • ScalarSubQuery.java
                    • Relation.java
                    • DropTable.java
                    • AlterTablespace.java
                    • CaseWhenPredicate.java
                    • IntervalLiteral.java
                    • TablePrimarySubQuery.java
                    • LiteralValue.java
                    • QualifiedAsteriskExpr.java
                    • DateLiteral.java
                    • Having.java
                    • InPredicate.java
                    • CountRowsFunctionExpr.java
                    • NamedExpr.java
                    • DataTypeExpr.java
                    • Explain.java
                    • AlterTableOpType.java
                    • DropDatabase.java
                    • CreateTable.java
                    • BooleanLiteral.java
                    • ValueListExpr.java
                    • DropIndex.java
                    • Projection.java
                    • Join.java
                    • TimeValue.java
                    • CommonSubquery.java
                    • WindowFunctionExpr.java
                    • RelationList.java
                    • Insert.java
                    • TruncateTable.java
                    • JsonHelper.java
                    • BetweenPredicate.java
                    • Aggregation.java
                    • GeneralSetFunctionExpr.java
                    • ExistsPredicate.java
                    • Window.java
                    • BinaryOperator.java
                    • CreateDatabase.java
                    • OpType.java
                    • TimeLiteral.java
                    • SimpleTableSubquery.java
                    • Selection.java
                    • IsNullPredicate.java
                    • DateValue.java
        • test
          • java
            • org
              • apache
                • tajo
                  • algebra
                    • AlgebraTestingUtil.java
                    • TestExpr.java
      • pom.xml
    • tajo-cluster-tests
      • src
        • test
          • resources
            • tpch
              • orders.tbl
              • supplier.tbl
              • small_supplier.tbl
              • region.tbl
              • lineitem.tbl
              • empty_orders.tbl
              • nation.tbl
              • partsupp.tbl
              • part.tbl
              • customer.tbl
          • java
            • org
              • apache
                • tajo
                  • LocalTajoTestingUtility.java
                  • IntegrationTest.java
                  • HBaseTestClusterUtil.java
                  • CatalogTestingUtil.java
                  • TpchTestBase.java
                  • NamedTest.java
                  • QueryTestCaseBase.java
                  • TajoTestingCluster.java
                  • BackendTestingUtil.java
      • pom.xml
    • tajo-sql-parser
      • src
        • main
          • antlr4
            • org
              • apache
                • tajo
                  • parser
                    • sql
                      • SQLLexer.g4
                      • SQLParser.g4
      • pom.xml
    • .travis.yml
    • README.md
    • tajo-catalog
      • pom.xml
      • tajo-catalog-drivers
        • pom.xml
        • tajo-hive
          • src
            • main
              • java
                • org
                  • apache
                    • tajo
                      • catalog
                        • store
                          • HiveCatalogStoreClientPool.java
                          • HiveCatalogStore.java
                          • HiveCatalogUtil.java
                          • HCatalogStore.java
            • test
              • java
                • org
                  • apache
                    • tajo
                      • catalog
                        • store
                          • TestHiveCatalogStore.java
          • pom.xml
      • tajo-catalog-common
        • src
          • main
            • proto
              • CatalogProtos.proto
            • java
              • org
                • apache
                  • tajo
                    • catalog
                      • SchemaBuilder.java
                      • SortSpec.java
                      • SetSchemaBuilder.java
                      • ListSchemaBuilder.java
                      • statistics
                        • TableStats.java
                        • ColumnStats.java
                        • StatisticsUtil.java
                        • Stat.java
                        • StatSet.java
                      • SchemaLegacy.java
                      • AttributeType.java
                      • TypeConverter.java
                      • CatalogConstants.java
                      • DDLBuilder.java
                      • TableDesc.java
                      • CatalogUtil.java
                      • partition
                        • PartitionDesc.java
                        • PartitionMethodDesc.java
                      • NestedPathUtil.java
                      • Schema.java
                      • TableMeta.java
                      • TypeDesc.java
                      • CatalogService.java
                      • FunctionDescBuilder.java
                      • IndexDesc.java
                      • SchemaUtil.java
                      • SchemaFactory.java
                      • SchemaObject.java
                      • MetadataProvider.java
                      • FieldConverter.java
                      • FunctionDesc.java
                      • AlterTableDesc.java
                      • Column.java
                      • AlterTableType.java
                      • json
                        • CatalogGsonHelper.java
                        • TableMetaAdapter.java
                        • FunctionAdapter.java
                        • SchemaAdapter.java
                      • AlreadyRegisteredURIException.java
                      • IndexMeta.java
                    • function
                      • ScalarFunction.java
                      • ClassBaseInvocationDesc.java
                      • FunctionUtil.java
                      • FunctionInvocation.java
                      • Function.java
                      • FunctionSupplement.java
                      • FunctionCollection.java
                      • UDFInvocationDesc.java
                      • FunctionSignature.java
                      • StaticMethodInvocationDesc.java
                    • DataTypeUtil.java
          • test
            • java
              • org
                • apache
                  • tajo
                    • catalog
                      • statistics
                        • TestStatSet.java
                        • TestTableStat.java
                        • TestStatisticsUtil.java
                        • TestColumnStat.java
                      • TestTableDesc.java
                      • TestColumn.java
                      • TestSchema.java
                      • TestFunctionDesc.java
                      • TestTableMeta.java
                      • TestCatalogUtil.java
                      • TestKeyValueSet.java
                      • TestIndexDesc.java
        • pom.xml
      • tajo-catalog-server
        • src
          • main
            • resources
              • schemas
                • DBMSSchemaDefinition.xsd
                • derby
                  • derby.xml
                • oracle
                  • oracle.xml
                • mysql
                  • mysql.xml
                • postgresql
                  • postgresql.xml
                • mariadb
                  • mariadb.xml
            • java
              • org
                • apache
                  • tajo
                    • catalog
                      • LinkedMetadataManager.java
                      • dictionary
                        • DatabasesTableDescriptor.java
                        • IndexesTableDescriptor.java
                        • TableStatsTableDescriptor.java
                        • TablesTableDescriptor.java
                        • SessionTableDescriptor.java
                        • TableDescriptor.java
                        • TableOptionsTableDescriptor.java
                        • ColumnDescriptor.java
                        • ColumnsTableDescriptor.java
                        • PartitionsTableDescriptor.java
                        • InfoSchemaMetadataDictionary.java
                        • ClusterTableDescriptor.java
                        • TablespacesTableDescriptor.java
                        • PartitionKeysTableDescriptor.java
                        • AbstractTableDescriptor.java
                      • LocalCatalogWrapper.java
                      • CatalogServer.java
                      • store
                        • object
                          • BaseSchema.java
                          • SQLObject.java
                          • StoreObject.java
                          • DatabaseObject.java
                          • SchemaPatch.java
                          • DatabaseObjectType.java
                        • XMLCatalogSchemaManager.java
                        • MariaDBStore.java
                        • CatalogStore.java
                        • AbstractDBStore.java
                        • MySQLStore.java
                        • DerbyStore.java
                        • PostgreSQLStore.java
                        • OracleStore.java
          • test
            • resources
              • log4j.properties
              • schemas
                • derbytest
                  • upgradetest
                    • base_version_2.xml
                  • querytest
                    • derby.xml
                  • loadtest
                    • derby.xml
                  • mergetest
                    • base_version_2.xml
                    • base_version_1.xml
            • java
              • org
                • apache
                  • tajo
                    • catalog
                      • TestLinkedMetadataManager.java
                      • TestCatalogAgainstCaseSensitivity.java
                      • CatalogTestingUtil.java
                      • store
                        • TestXMLCatalogSchemaManager.java
                      • TestCatalog.java
                      • MiniCatalogServer.java
                      • TestCatalogExceptions.java
        • pom.xml
      • tajo-catalog-client
        • src
          • main
            • proto
              • CatalogProtocol.proto
            • java
              • org
                • apache
                  • tajo
                    • catalog
                      • AbstractCatalogClient.java
                      • CatalogClient.java
        • pom.xml
    • tajo-core-tests
      • src
        • test
          • resources
            • results
              • testDDLBuilder
                • testBuildDDLForBaseTable.result
                • testBuildDDLQuotedTableName2.result
                • testBuildDDLQuotedTableName1.result
                • testBuildDDLForExternalTable.result
              • TestTajoDump
                • testDump2.result
                • testPartitionsDump.result
                • testDump3.result
                • testDump1.result
              • TestCreateTable
                • quoted_identifier_mixed_chars_3.result
                • quoted_identifier_non_ascii_3.result
                • quoted_identifier_mixed_chars_1.result
                • quoted_identifier_non_ascii_2.result
                • quoted_identifier_non_ascii_1.result
                • quoted_identifier_mixed_chars_2.result
              • TestUnionQuery
                • testAllUnionWithJoin.result
                • testComplexUnion2.result
                • testUnion7.result
                • testRightUnionWithJoin.result
                • testUnion13.result
                • testUnionAllWithDifferentAliasAndFunction.result
                • testThreeJoinInUnion.result
                • testUnionAll7.result
                • testUnionAll2.result
                • testUnion1.result
                • testUnion5.result
                • testUnionWithSameAliasNames.result
                • testTajo1368Case1.result
                • testUnionAndFilter.result
                • testTajo1368Case2.result
                • testUnion14.result
                • testUnionWithCrossJoin.result
                • testUnionWithDifferentAlias.result
                • testUnionAll3.result
                • testUnionAllWithDifferentAlias.result
                • testUnionAll10.result
                • testUnionAndFilter.plan
                • testUnion10.result
                • testUnion15.result
                • testUnion2.result
                • testUnion6.result
                • testComplexUnion1.plan
                • testUnion9.result
                • testComplexUnion1.result
                • testUnionCaseOfFirstEmptyAndJoin.result
                • testUnion4.result
                • testUnionAll8.result
                • testComplexUnion2.plan
                • testUnionAll12.result
                • testUnion8.result
                • testUnionAllWithSameAliasNames.result
                • testUnion3.result
                • testUnionWithDifferentAliasAndFunction.result
                • testUnionAll11.result
                • testUnionAll16.result
                • testUnionAll4.result
                • testUnionAll6.result
                • testLeftUnionWithJoin.result
                • testUnionAll14.result
                • testUnionAll1.result
                • testUnion12.result
                • testUnionAll5.result
                • testUnion16.result
                • testUnion11.result
                • testUnionAll15.result
                • testUnionAll9.result
                • testUnionAll13.result
              • TestOuterJoinQuery
                • testLeftOuterJoinLeftSideSmallTable.1.Hash.plan
                • testLeftOuterJoinWithEmptyTable4.result
                • testLeftOuterJoinWithEmptyTable3.result
                • testMultipleBroadcastDataFileWithZeroLength2.result
                • testRightOuterJoinPredicationCaseByCase2.1.result
                • testRightOuterJoin1.Sort_NoBroadcast.plan
                • testRightOuterJoinPredicationCaseByCase2.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable4.Sort.plan
                • testLeftOuterJoinWithNull2.Sort.plan
                • testLeftOuterJoinWithThetaJoinConditionInWhere.Hash.plan
                • testRightOuterJoin1.Hash_NoBroadcast.plan
                • testRightOuterJoinPredicationCaseByCase3.1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithConstantExpr4.result
                • testLeftOuterJoinWithThetaJoinConditionInWhere.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase3.1.Sort_NoBroadcast.plan
                • testRightOuterJoinPredicationCaseByCase1.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase4.1.Sort.plan
                • testFullOuterJoin1.Hash.plan
                • testLeftOuterJoinWithEmptyTable2.Sort_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase1.1.Hash.plan
                • testLeftOuterJoinPredicationCaseByCase4.1.Sort_NoBroadcast.plan
                • testRightOuterJoinWithEmptyTable1.Hash.plan
                • testLeftOuterJoinWithNull1.Hash.plan
                • testJoinFilterOfRowPreservedTable1.Sort.plan
                • testFullOuterJoinPredicationCaseByCase1.1.Sort_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase2.1.result
                • testLeftOuterJoinPredicationCaseByCase2_1.1.Hash.plan
                • testLeftOuterJoinPredicationCaseByCase1.1.Sort.plan
                • testLeftOuterJoinPredicationCaseByCase2.1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable2.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithConstantExpr4.Sort.plan
                • testLeftOuterJoinWithConstantExpr1.result
                • testFullOuterJoinWithEmptyTable1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithThetaJoinConditionInWhere.Sort.plan
                • testJoinFilterOfRowPreservedTable1.Hash.plan
                • testRightOuterJoinPredicationCaseByCase3.1.Hash.plan
                • testRightOuterJoinWithEmptyTable1.Sort.plan
                • testLeftOuterJoinWithEmptyTable5.Hash.plan
                • testLeftOuterJoinWithNull1.result
                • testLeftOuterJoinWithEmptyTable1.Sort.plan
                • testLeftOuterJoinWithEmptyTable5.Sort_NoBroadcast.plan
                • testRightOuterJoinPredicationCaseByCase2.1.Hash.plan
                • testLeftOuterJoinWithConstantExpr4.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase2_1.1.Sort.plan
                • testJoinFilterOfRowPreservedTable1.result
                • testLeftOuterJoinPredicationCaseByCase1.1.result
                • testLeftOuterJoin1.Sort_NoBroadcast.plan
                • testLeftOuterJoin1.Sort.plan
                • testLeftOuterJoin2.Sort_NoBroadcast.plan
                • testMultipleBroadcastDataFileWithZeroLength.Sort.plan
                • testLeftOuterJoinWithNull1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithConstantExpr1.Sort.plan
                • testRightOuterJoinWithThetaJoinConditionInWhere.result
                • testLeftOuterJoinWithEmptyTable5.Hash_NoBroadcast.plan
                • testOuterJoinAndCaseWhen1.Hash.plan
                • testLeftOuterJoin1.result
                • testFullOuterJoinWithEmptyTable1.Sort.plan
                • testLeftOuterJoinPredicationCaseByCase4.1.Hash.plan
                • testLeftOuterJoin3.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable3.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithNull2.Hash_NoBroadcast.plan
                • testLeftOuterJoin2.Hash.plan
                • testLeftOuterJoinWithNull2.result
                • testLeftOuterJoinPredicationCaseByCase2_1.1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithNull3.Hash_NoBroadcast.plan
                • testRightOuterJoinWithEmptyTable1.result
                • testLeftOuterJoinWithNull3.Sort_NoBroadcast.plan
                • testLeftOuterJoin2.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithNull3.Sort.plan
                • testLeftOuterJoinPredicationCaseByCase1.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable2.Sort.plan
                • testLeftOuterJoin2.result
                • testLeftOuterJoinWithEmptyTable4.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable1.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase2.1.Sort.plan
                • testMultipleBroadcastDataFileWithZeroLength.result
                • testOuterJoinAndCaseWhen1.Sort.plan
                • testLeftOuterJoinWithConstantExpr1.Sort_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase6.1.Sort.plan
                • testRightOuterJoinWithThetaJoinConditionInWhere.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithNull2.Sort_NoBroadcast.plan
                • testRightOuterJoinWithThetaJoinConditionInWhere.Hash.plan
                • testLeftOuterJoinWithConstantExpr5.Hash.plan
                • testLeftOuterJoinWithEmptyTable2.Hash.plan
                • testLeftOuterJoinWithConstantExpr4.Sort_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase5.1.result
                • testLeftOuterJoinWithConstantExpr1.Hash.plan
                • testLeftOuterWithEmptyTable.1.Hash.plan
                • testLeftOuterJoinLeftSideSmallTable.1.Sort_NoBroadcast.plan
                • testOuterJoinAndCaseWhen1.Sort_NoBroadcast.plan
                • testRightOuterJoin1.Sort.plan
                • testRightOuterJoinPredicationCaseByCase3.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithConstantExpr1.Hash_NoBroadcast.plan
                • testJoinFilterOfRowPreservedTable1.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase3.1.Sort.plan
                • testFullOuterJoinWithEmptyTable1.result
                • testLeftOuterJoinPredicationCaseByCase6.1.Sort_NoBroadcast.plan
                • testOuterJoinAndCaseWhen1.result
                • testRightOuterJoinWithThetaJoinConditionInWhere.Sort.plan
                • testLeftOuterJoinWithNull1.Sort.plan
                • testFullOuterJoinWithEmptyTable1.Hash.plan
                • testLeftOuterWithEmptyTable.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithThetaJoinConditionInWhere.result
                • testFullOuterJoinPredicationCaseByCase1.1.Hash.plan
                • testLeftOuterJoinWithEmptyTable3.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase2.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable1.result
                • testLeftOuterJoin3.result
                • testLeftOuterJoinPredicationCaseByCase5.1.Sort.plan
                • testFullOuterJoinPredicationCaseByCase1.1.result
                • testLeftOuterJoinWithConstantExpr5.Sort.plan
                • testLeftOuterJoinPredicationCaseByCase2_1.1.result
                • testLeftOuterJoin3.Sort.plan
                • testLeftOuterJoinWithEmptyTable1.Sort_NoBroadcast.plan
                • testLeftOuterJoin2.Sort.plan
                • testLeftOuterJoinLeftSideSmallTable.1.result
                • testLeftOuterJoin3.Hash_NoBroadcast.plan
                • testMultipleBroadcastDataFileWithZeroLength.Hash_NoBroadcast.plan
                • testMultipleBroadcastDataFileWithZeroLength2.Hash_NoBroadcast.plan
                • testLeftOuterWithEmptyTable.1.result
                • testLeftOuterJoinWithNull2.Hash.plan
                • testMultipleBroadcastDataFileWithZeroLength2.Hash.plan
                • testLeftOuterJoinWithThetaJoinConditionInWhere.Sort_NoBroadcast.plan
                • testFullOuterJoinPredicationCaseByCase1.1.Sort.plan
                • testLeftOuterJoinWithEmptyTable4.Sort_NoBroadcast.plan
                • testFullOuterJoin1.Sort_NoBroadcast.plan
                • testFullOuterJoinWithEmptyTable1.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase3.1.Hash.plan
                • testLeftOuterJoinWithEmptyTable4.Hash.plan
                • testMultipleBroadcastDataFileWithZeroLength.Hash.plan
                • testMultipleBroadcastDataFileWithZeroLength.Sort_NoBroadcast.plan
                • testRightOuterJoinWithEmptyTable1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable2.result
                • testRightOuterJoin1.result
                • testRightOuterJoinPredicationCaseByCase2.1.Sort.plan
                • testLeftOuterJoinWithConstantExpr5.result
                • testLeftOuterJoinPredicationCaseByCase3.1.Hash_NoBroadcast.plan
                • testRightOuterJoinPredicationCaseByCase1.1.Hash.plan
                • testLeftOuterJoinPredicationCaseByCase4.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase4.1.result
                • testLeftOuterJoin3.Hash.plan
                • testLeftOuterJoinWithEmptyTable5.result
                • testLeftOuterJoinLeftSideSmallTable.1.Sort.plan
                • testLeftOuterWithEmptyTable.1.Sort.plan
                • testRightOuterJoinPredicationCaseByCase3.1.result
                • testLeftOuterJoinWithEmptyTable3.Hash.plan
                • testLeftOuterJoinPredicationCaseByCase6.1.Hash.plan
                • testLeftOuterJoinWithNull3.result
                • testFullOuterJoin1.result
                • testRightOuterJoinWithEmptyTable1.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase5.1.Sort_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase2_1.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable3.Sort.plan
                • testOuterJoinAndCaseWhen1.Hash_NoBroadcast.plan
                • testLeftOuterJoin1.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase5.1.Hash_NoBroadcast.plan
                • testFullOuterJoin1.Sort.plan
                • testJoinFilterOfRowPreservedTable1.Sort_NoBroadcast.plan
                • testRightOuterJoinPredicationCaseByCase1.1.Sort.plan
                • testMultipleBroadcastDataFileWithZeroLength2.Sort_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase5.1.Hash.plan
                • testRightOuterJoinPredicationCaseByCase1.1.result
                • testRightOuterJoinPredicationCaseByCase3.1.Sort.plan
                • testLeftOuterJoinPredicationCaseByCase1.1.Sort_NoBroadcast.plan
                • testRightOuterJoinPredicationCaseByCase2.1.Sort_NoBroadcast.plan
                • testRightOuterJoin1.Hash.plan
                • testLeftOuterWithEmptyTable.1.Sort_NoBroadcast.plan
                • testRightOuterJoinPredicationCaseByCase1.1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable5.Sort.plan
                • testLeftOuterJoinWithConstantExpr5.Hash_NoBroadcast.plan
                • testFullOuterJoinPredicationCaseByCase1.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinLeftSideSmallTable.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase6.1.result
                • testLeftOuterJoinPredicationCaseByCase6.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithEmptyTable1.Hash.plan
                • testLeftOuterJoinWithNull1.Hash_NoBroadcast.plan
                • testRightOuterJoinWithThetaJoinConditionInWhere.Sort_NoBroadcast.plan
                • testLeftOuterJoinPredicationCaseByCase3.1.result
                • testLeftOuterJoinPredicationCaseByCase2.1.Hash.plan
                • testLeftOuterJoinWithNull3.Hash.plan
                • testLeftOuterJoinWithConstantExpr4.Hash.plan
                • testFullOuterJoin1.Hash_NoBroadcast.plan
                • testMultipleBroadcastDataFileWithZeroLength2.Sort.plan
                • testLeftOuterJoinWithConstantExpr5.Sort_NoBroadcast.plan
                • testLeftOuterJoin1.Hash.plan
              • TestQueryUnitStatusUpdate
                • case3.result
              • TestInsertQuery
                • testInsertOverwriteWithAsteriskUsingParquet2.result
                • testInsertOverwriteWithAsteriskUsingParquet.result
                • testInsertOverwriteWithAsteriskAndMore.result
                • testInsertWithDifferentColumnOrder.result
              • TestIndexScan
                • testOnMultipleExprs.result
                • testOnMultipleKeys.result
                • testOnUnsortedTextKeys.result
                • testOnMultipleKeys2.result
                • testOnSortedNonUniqueKeys.result
                • testWithSort.result
                • testWithJoin.result
                • testWithGroupBy.result
              • TestQueryResult
                • testTableResultOnClose.result
                • testTemporalResultOnClose.result
              • TestInSubquery
                • testMultipleInSubQuery.result
                • testInSubQuery.result
                • testInSubQueryWithJoin.result
                • testNestedInAndNotInSubQuery.result
                • testInAndNotInSubQuery.result
                • testInSubQuery2.result
                • testMultipleNotInSubQuery.result
                • testNestedNotInSubQuery.result
                • testInSubQueryWithOtherConditions.result
                • testWithAsteriskAndJoin.result
                • testNestedInSubQuery.result
                • testSameKeyNameOfOuterAndInnerQueries.result
                • testNestedInSubQuery2.result
                • testInSubQueryWithTableSubQuery.result
                • testNotInSubQuery.result
              • TestSelectQuery
                • testTimezonedTable3.result
                • testInStrClause.result
                • testRealValueCompare.result
                • testSelectColumnAliasExistingInRelation2.result
                • testMultiBytesDelimiter4.result
                • testUnion1.result
                • testDatabaseRef.result
                • testStringCompare.result
                • testSumFloatOverflow.result
                • testSelect3.result
                • testSelectAsterisk4.result
                • testExplainSelectPhysical.3.result
                • testExplainSelect.result
                • testSimpleQueryWithLimitPartitionedTable.result
                • testWhereCond2.result
                • testSelectSameConstantsWithDifferentAliases3.result
                • testNotEqual.result
                • testSelectAsterisk3.result
                • testNotInClause.result
                • testSelectAsterisk5.result
                • testWhereCondWithAlias2.result
                • testSelectWithParentheses2.result
                • testInClause.result
                • testMultiBytesDelimiter3.result
                • testExplainSelectPhysical.1.result
                • testLikeClause.result
                • testExplainSelectPhysical.2.result
                • testTimezonedTable1.result
                • testUnion2.result
                • testCaseWhenWithoutElse.result
                • testSelectOnSessionTable.result
                • testSelectWithJson.result
                • testSelectPythonFuncs.result
                • testNonQualifiedNames.result
                • testCaseWhenRound.result
                • testWhereCond1.result
                • testSimpleQuery.result
                • testSimpleQueryWithPythonFuncs.result
                • testSumIntOverflow.result
                • testSelectColumnAliasExistingInRelation1.result
                • testSelectColumnAliasExistingInRelation3.result
                • testSelectAsterisk2.result
                • testNestedPythonFunction.result
                • testColumnEqualityButNotJoinCondition2.result
                • testColumnEqualityButNotJoinCondition1.result
                • testSelectDistinct.result
                • testSelect.result
                • testSelectSameExprsWithDifferentAliases.result
                • testSelectAsterisk1.result
                • testSelect2.result
                • testNotInStrClause.result
                • testTimezonedTable2.result
                • testNonFromSelect1.result
                • testSelectWithPredicateOnPythonFunc.result
                • testSelectSameConstantsWithDifferentAliases.result
                • testSelectColumnAlias1.result
                • testSimpleQueryWithLimit.result
                • testSelectWithParentheses1.result
                • testCaseWhen.result
                • testMultiBytesDelimiter2.result
                • testSelectSameConstantsWithDifferentAliases2.result
                • testWhereCondWithAlias1.result
                • testMultiBytesDelimiter1.result
                • testLimit.result
              • TestHBaseTable
                • testJoin.result
                • testRowFieldSelectQuery.result
                • testInsertIntoMultiRegionMultiRowFields.result
                • testInsertIntoRowField.result
                • testSimpleSelectQuery.result
                • testColumnKeyValueSelectQuery.result
                • testInsertIntoColumnKeyValue.result
                • testInsertIntoMultiRegion2.result
                • testCTAS.result
                • testIndexPredication.result
                • testInsertIntoBinaryMultiRegion.result
                • testInsertIntoUsingPut.result
                • testGetSplitsWhenRestartHBase.result
                • testNonForwardQuery.result
                • testBinaryMappedQuery.result
                • testInsertIntoMultiRegion.result
                • testInsertIntoMultiRegionWithSplitFile.result
                • testInsertValues1.result
                • testInsertInto.result
              • TestSimpleQuery
                • testPartitionColumnWhere.result
                • testNoWhere.result
                • testWhere.result
                • testLimit.result
              • TestTablePartitions
                • case12.result
                • case3.result
                • testColumnPartitionedTableWithSmallerExpressions5.result
                • case8.result
                • case10.result
                • TestSpecialCharPartitionKeys1.result
                • testColumnPartitionedTableWithSmallerExpressions6.result
                • case5.result
                • case11.result
                • case6.result
                • case9.result
                • case7.result
                • case15.result
                • case14.result
                • case13.result
                • case2.result
                • case1.result
                • TestSpecialCharPartitionKeys2.result
                • case4.result
              • TestQueryOnSelfDescTable
                • testJoinOfSelfDescTablesWithQualifiedColumns3.1.result
                • testSelectFromAliasedTable.1.result
                • testJoinAliasedTables.1.result
                • testTableSubquery2.1.result
                • testJoinWithSchemaFullTable.result
                • testInSubquery.1.result
                • testJoinWithSchemaFullTable4.result
                • testTableSubquery3.1.result
                • testJoinAliasedTables2.1.result
                • testSelect.result
                • testSelect2.result
                • testJoinWithSchemaFullTable2.result
                • testGroupby2.result
                • testJoinOfSelfDescTablesWithQualifiedColumns2.1.result
                • testGroupby3.result
                • testGroupby.result
                • testSort.result
                • testTableSubquery.1.result
                • testCrossJoin.result
                • testJoinOfSelfDescTablesWithQualifiedColumns.result
              • TestInnerJoinWithSubQuery
                • testBroadcastSubquery2.Sort_NoBroadcast.plan
                • testJoinWithMultipleJoinQual4.Hash.plan
                • testThetaJoinKeyPairs.Sort.plan
                • testComplexJoinCondition7.Hash_NoBroadcast.plan
                • testJoinWithMultipleJoinQual4.Sort.plan
                • testThetaJoinKeyPairs.Hash_NoBroadcast.plan
                • testBroadcastSubquery.Hash.plan
                • testThetaJoinKeyPairs.Hash.plan
                • testComplexJoinCondition7.Sort_NoBroadcast.plan
                • testJoinWithMultipleJoinQual2.Hash_NoBroadcast.plan
                • testJoinWithMultipleJoinQual2.Sort.plan
                • testComplexJoinCondition6.Sort.plan
                • testComplexJoinCondition7.Hash.plan
                • testBroadcastSubquery.Hash_NoBroadcast.plan
                • testComplexJoinCondition5.Sort_NoBroadcast.plan
                • testComplexJoinCondition6.Sort_NoBroadcast.plan
                • testThetaJoinKeyPairs.result
                • testJoinWithMultipleJoinQual2.result
                • testJoinWithMultipleJoinQual4.Sort_NoBroadcast.plan
                • testJoinWithJson2.result
                • testBroadcastSubquery.result
                • testComplexJoinCondition5.Sort.plan
                • testJoinWithMultipleJoinQual3.Hash_NoBroadcast.plan
                • testComplexJoinCondition5.Hash.plan
                • testBroadcastSubquery.Sort_NoBroadcast.plan
                • testJoinWithMultipleJoinQual2.Hash.plan
                • testComplexJoinCondition5.result
                • testThetaJoinKeyPairs.Sort_NoBroadcast.plan
                • testJoinWithMultipleJoinQual3.result
                • testJoinWithMultipleJoinQual4.result
                • testBroadcastSubquery2.Sort.plan
                • testJoinWithMultipleJoinQual3.Sort.plan
                • testBroadcastSubquery.Sort.plan
                • testComplexJoinCondition6.Hash_NoBroadcast.plan
                • testComplexJoinCondition7.result
                • testJoinWithMultipleJoinQual2.Sort_NoBroadcast.plan
                • testJoinWithMultipleJoinQual3.Hash.plan
                • testBroadcastSubquery2.Hash_NoBroadcast.plan
                • testComplexJoinCondition5.Hash_NoBroadcast.plan
                • testComplexJoinCondition7.Sort.plan
                • testBroadcastSubquery2.result
                • testJoinWithMultipleJoinQual4.Hash_NoBroadcast.plan
                • testJoinWithMultipleJoinQual3.Sort_NoBroadcast.plan
                • testComplexJoinCondition6.result
                • testBroadcastSubquery2.Hash.plan
                • testComplexJoinCondition6.Hash.plan
              • TestTajoCliNegatives
                • testQuerySyntax.result
                • testQueryFailure.result
              • TestOuterJoinWithSubQuery
                • testJoinWithDifferentShuffleKey.1.Hash.plan
                • testLeftOuterJoinWithConstantExpr2.Sort_NoBroadcast.plan
                • testFullOuterJoinWithEmptyIntermediateData.1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithEmptySubquery2.1.Sort.plan
                • testLeftOuterJoinWithConstantExpr2.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithConstantExpr3.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithEmptySubquery1.1.Hash_NoBroadcast.plan
                • testFullOuterJoinWithEmptyIntermediateData.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithEmptySubquery2.1.Sort_NoBroadcast.plan
                • testFullOuterJoinWithEmptyIntermediateData.1.result
                • testLeftOuterJoinWithConstantExpr2.Sort.plan
                • testLeftOuterJoinWithConstantExpr2.result
                • testLeftOuterJoinWithEmptySubquery1.1.Sort_NoBroadcast.plan
                • testFullOuterJoinWithEmptyIntermediateData.1.Sort.plan
                • testJoinWithDifferentShuffleKey.1.result
                • testLeftOuterJoinWithEmptySubquery1.1.Sort.plan
                • testLeftOuterJoinWithEmptySubquery1.1.result
                • testJoinWithDifferentShuffleKey.1.Sort_NoBroadcast.plan
                • testLeftOuterJoinWithEmptySubquery2.1.Hash.plan
                • testLeftOuterJoinWithEmptySubquery2.1.result
                • testLeftOuterJoinWithConstantExpr2.Hash.plan
                • testJoinWithDifferentShuffleKey.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithEmptySubquery1.1.Hash.plan
                • testLeftOuterJoinWithEmptySubquery2.1.Hash_NoBroadcast.plan
                • testLeftOuterJoinWithConstantExpr3.Sort.plan
                • testJoinWithDifferentShuffleKey.1.Sort.plan
                • testLeftOuterJoinWithConstantExpr3.Hash.plan
                • testFullOuterJoinWithEmptyIntermediateData.1.Hash.plan
                • testLeftOuterJoinWithConstantExpr3.result
                • testLeftOuterJoinWithConstantExpr3.Hash_NoBroadcast.plan
              • TestInnerJoinQuery
                • testWhereClauseJoin6.Sort_NoBroadcast.plan
                • testJoinWithMultipleJoinQual1.Sort_NoBroadcast.plan
                • testBroadcastTwoPartJoin.Hash_NoBroadcast.plan
                • testNaturalJoin.Hash.plan
                • testJoinAsterisk.Hash.plan
                • testJoinCoReferredEvalsWithSameExprs1.Hash.plan
                • testComplexJoinCondition1.result
                • testJoinOnMultipleDatabases.Hash_NoBroadcast.plan
                • testComplexJoinCondition1.Hash_NoBroadcast.plan
                • testWhereClauseJoin4.Sort.plan
                • testComplexJoinCondition4.Hash.plan
                • testTPCHQ2Join.Sort.plan
                • testJoinWithMultipleJoinQual1.Hash_NoBroadcast.plan
                • testWhereClauseJoin6.result
                • testComplexJoinCondition3.Sort_NoBroadcast.plan
                • testJoinCoReferredEvals1.Sort.plan
                • testBroadcastTwoPartJoin.Sort.plan
                • testWhereClauseJoin4.result
                • testJoinWithOrPredicates.Hash_NoBroadcast.plan
                • testInnerJoinWithEmptyTable.result
                • testInnerJoinWithThetaJoinConditionInWhere.Hash_NoBroadcast.plan
                • testJoinAsterisk.Hash_NoBroadcast.plan
                • testJoinWithOrPredicates.Sort.plan
                • testJoinCoReferredEvals1.result
                • testJoinCoReferredEvalsWithSameExprs2.Hash_NoBroadcast.plan
                • testJoinCoReferredEvalsWithSameExprs1.Hash_NoBroadcast.plan
                • testJoinWithMultipleJoinQual1.result
                • testComplexJoinCondition3.Sort.plan
                • testWhereClauseJoin4.Hash_NoBroadcast.plan
                • testComplexJoinCondition4.Sort_NoBroadcast.plan
                • testJoinCoReferredEvalsWithSameExprs2.Hash.plan
                • testWhereClauseJoin6.Sort.plan
                • testComplexJoinCondition1.Hash.plan
                • testTPCHQ2Join.Hash.plan
                • testInnerJoinWithEmptyTable.Sort_NoBroadcast.plan
                • testComplexJoinCondition4.Hash_NoBroadcast.plan
                • testComplexJoinCondition2.result
                • testJoinOnMultipleDatabases.Sort.plan
                • testInnerJoinWithThetaJoinConditionInWhere.result
                • testComplexJoinCondition3.Hash.plan
                • testJoinWithMultipleJoinQual1.Hash.plan
                • testJoinWithOrPredicates.Hash.plan
                • testWhereClauseJoin3.Hash.plan
                • testWhereClauseJoin6.Hash_NoBroadcast.plan
                • testComplexJoinCondition2.Sort_NoBroadcast.plan
                • testBroadcastJoinWithEmptyRows.result
                • testComplexJoinCondition3.Hash_NoBroadcast.plan
                • testJoinCoReferredEvalsWithSameExprs2.Sort.plan
                • testNaturalJoin.result
                • testWhereClauseJoin2.Sort_NoBroadcast.plan
                • testWhereClauseJoin1.Sort.plan
                • testWhereClauseJoin3.Sort.plan
                • testBroadcastTwoPartJoin.Hash.plan
                • testJoinCoReferredEvalsWithSameExprs2.result
                • testJoinAsterisk.Sort.plan
                • testWhereClauseJoin2.result
                • testTPCHQ2Join.Hash_NoBroadcast.plan
                • testWhereClauseJoin1.Hash.plan
                • testWhereClauseJoin5.Sort_NoBroadcast.plan
                • testJoinCoReferredEvals1.Sort_NoBroadcast.plan
                • testInnerJoinWithEmptyTable.Hash.plan
                • testTPCHQ2Join.result
                • testJoinCoReferredEvalsWithSameExprs1.Sort.plan
                • testInnerJoinAndCaseWhen.Hash.plan
                • testComplexJoinCondition1.Sort_NoBroadcast.plan
                • testJoinCoReferredEvalsWithSameExprs1.result
                • testInnerJoinWithThetaJoinConditionInWhere.Hash.plan
                • testJoinAsterisk.result
                • testWhereClauseJoin4.Sort_NoBroadcast.plan
                • testWhereClauseJoin4.Hash.plan
                • testWhereClauseJoin5.Sort.plan
                • testDifferentTypesJoinCondition.Sort_NoBroadcast.plan
                • testWhereClauseJoin3.Sort_NoBroadcast.plan
                • testJoinWithMultipleJoinQual1.Sort.plan
                • testWhereClauseJoin5.Hash.plan
                • testInnerJoinWithThetaJoinConditionInWhere.Sort.plan
                • testTPCHQ2Join.Sort_NoBroadcast.plan
                • testComplexJoinCondition2.Sort.plan
                • testComplexJoinCondition1.Sort.plan
                • testJoinCoReferredEvalsWithSameExprs2.Sort_NoBroadcast.plan
                • testComplexJoinCondition4.Sort.plan
                • testJoinWithOrPredicates.Sort_NoBroadcast.plan
                • testWhereClauseJoin2.Hash.plan
                • testDifferentTypesJoinCondition.Hash_NoBroadcast.plan
                • testDifferentTypesJoinCondition.Sort.plan
                • testWhereClauseJoin2.Sort.plan
                • testWhereClauseJoin1.Sort_NoBroadcast.plan
                • testJoinAsterisk.Sort_NoBroadcast.plan
                • testWhereClauseJoin5.Hash_NoBroadcast.plan
                • testWhereClauseJoin5.result
                • testWhereClauseJoin1.Hash_NoBroadcast.plan
                • testInnerJoinAndCaseWhen.Hash_NoBroadcast.plan
                • testWhereClauseJoin3.Hash_NoBroadcast.plan
                • testNaturalJoin.Sort.plan
                • testComplexJoinCondition2.Hash_NoBroadcast.plan
                • testJoinOnMultipleDatabases.result
                • testDifferentTypesJoinCondition.Hash.plan
                • testInnerJoinAndCaseWhen.Sort.plan
                • testInnerJoinAndCaseWhen.Sort_NoBroadcast.plan
                • testJoinCoReferredEvals1.Hash_NoBroadcast.plan
                • testWhereClauseJoin3.result
                • testComplexJoinCondition3.result
                • testNaturalJoin.Hash_NoBroadcast.plan
                • testDifferentTypesJoinCondition.result
                • testJoinOnMultipleDatabases.Hash.plan
                • testJoinOnMultipleDatabases.Sort_NoBroadcast.plan
                • testJoinWithJson.result
                • testWhereClauseJoin1.result
                • testInnerJoinWithThetaJoinConditionInWhere.Sort_NoBroadcast.plan
                • testBroadcastTwoPartJoin.result
                • testInnerJoinWithEmptyTable.Sort.plan
                • testComplexJoinCondition2.Hash.plan
                • testWhereClauseJoin6.Hash.plan
                • testJoinOnMultipleDatabasesWithJson.result
                • testBroadcastTwoPartJoin.Sort_NoBroadcast.plan
                • testJoinCoReferredEvalsWithSameExprs1.Sort_NoBroadcast.plan
                • testInnerJoinAndCaseWhen.result
                • testComplexJoinCondition4.result
                • testWhereClauseJoin2.Hash_NoBroadcast.plan
                • testJoinWithOrPredicates.result
                • testJoinCoReferredEvals1.Hash.plan
                • testInnerJoinWithEmptyTable.Hash_NoBroadcast.plan
                • testNaturalJoin.Sort_NoBroadcast.plan
              • TestNonForwardQueryResultSystemScanner
                • testGetNextRowsForAggregateFunction.result
                • testGetNextRowsForTable.result
                • testGetClusterDetails.result
              • TestJoinQuery
                • testWhereClauseJoin6.result
              • TestSortQuery
                • testSortWithAlias2.result
                • testSortWithAscDescKeys.result
                • testSortDesc.result
                • testSortAfterGroupby.result
                • testSortWithAlias1.result
                • testSortWithAliasButOriginalName.result
                • testSubQuerySortAfterGroupMultiBlocks.plan
                • testSortOnUnicodeTextAsc.result
                • testSortWithDate.result
                • testSortWithJson.result
                • testTopK.result
                • testSortWithConstKeys.result
                • testSortWithExpr1.result
                • testSortWithAlias3.result
                • testAsterisk.result
                • testSortOnNullColumn.result
                • testSortOnUnicodeTextDesc.result
                • testSortWithExpr2.result
                • testSubQuerySortAfterGroupMultiBlocks.result
                • testTopkWithJson.result
                • testSort.result
                • testSortFirstDesc.result
                • testOutOfScope.result
                • testSortAfterGroupbyWithAlias.result
              • TestBuiltinFunctions
                • testMaxLong.result
                • testMinString.result
                • testMinLong.result
                • testAvgInt.result
                • testMaxString.result
                • testSplitPartNested.result
                • testCount.result
                • testAvgLongOverflow.result
                • testAvgLong.result
                • testSplitPartByString.result
                • testAvgDouble.result
                • testSplitPart.result
              • TestFunctionLoader
                • testFindScalarFunctions.result
              • TestTPCH
                • testTPCHQ5.result
                • testQ2FourJoins.plan
                • testTPCHQ5.plan
                • testQ1OrderBy.plan
                • testFirstJoinInQ7.result
                • testQ1OrderBy.result
                • testTPCH14Expr.plan
                • testQ2FourJoins.result
                • testTPCH14Expr.result
                • testFirstJoinInQ7.plan
              • TestCrossJoin
                • testCrossJoinAndCaseWhen.Sort.plan
                • testCrossJoinWithEmptyTable1.Sort_NoBroadcast.plan
                • testCrossJoin.4.Sort.plan
                • testCrossJoin.5.result
                • testCrossJoinAndCaseWhen.Hash_NoBroadcast.plan
                • testCrossJoinAndCaseWhen.Hash.plan
                • testCrossJoinWithAsterisk3.Hash_NoBroadcast.plan
                • testCrossJoin.5.Sort.plan
                • testCrossJoinOfOneSmallTable.1.Hash_NoBroadcast.plan
                • testCrossJoinWithAsterisk3.Sort_NoBroadcast.plan
                • testCrossJoin.2.Sort_NoBroadcast.plan
                • testCrossJoin.3.Hash.plan
                • testCrossJoin.3.Sort_NoBroadcast.plan
                • testCrossJoin.1.Sort_NoBroadcast.plan
                • testCrossJoin.5.Hash_NoBroadcast.plan
                • testCrossJoinWithAsterisk4.Hash.plan
                • testCrossJoinWithThetaJoinConditionInWhere.result
                • testCrossJoin.4.result
                • testCrossJoin.3.Sort.plan
                • testCrossJoinWithThetaJoinConditionInWhere.Hash.plan
                • testCrossJoinOfOneSmallTableAndJoin.1.Hash.plan
                • testCrossJoinWithAsterisk2.Hash_NoBroadcast.plan
                • testCrossJoin.4.Hash.plan
                • testCrossJoinWithThetaJoinConditionInWhere.Hash_NoBroadcast.plan
                • testCrossJoinOftwoSmallTables.1.Sort_NoBroadcast.plan
                • testCrossJoinOfOneSmallTable.1.Hash.plan
                • testCrossJoinWithAsterisk2.Sort.plan
                • testCrossJoinOfOneSmallTableAndJoin.1.Sort_NoBroadcast.plan
                • testCrossJoinOfOneSmallTable.1.Sort_NoBroadcast.plan
                • testCrossJoinOfOneSmallTable.1.Sort.plan
                • testCrossJoinAndCaseWhen.Sort_NoBroadcast.plan
                • testCrossJoinWithAsterisk1.Hash.plan
                • testCrossJoin.3.Hash_NoBroadcast.plan
                • testCrossJoinOfOneSmallTable.1.result
                • testCrossJoinWithThetaJoinConditionInWhere.Sort_NoBroadcast.plan
                • testCrossJoin.1.result
                • testCrossJoin.2.result
                • testCrossJoinWithEmptyTable1.Hash.plan
                • testCrossJoinWithAsterisk3.Hash.plan
                • testCrossJoinOftwoSmallTables.1.Hash.plan
                • testCrossJoin.1.Hash_NoBroadcast.plan
                • testCrossJoin.4.Hash_NoBroadcast.plan
                • testCrossJoinWithAsterisk2.Sort_NoBroadcast.plan
                • testCrossJoin.2.Sort.plan
                • testCrossJoinAndCaseWhen.result
                • testCrossJoinWithAsterisk2.result
                • testCrossJoin.5.Sort_NoBroadcast.plan
                • testCrossJoinOftwoSmallTables.1.Hash_NoBroadcast.plan
                • testCrossJoinWithAsterisk3.Sort.plan
                • testCrossJoinWithThetaJoinConditionInWhere.Sort.plan
                • testCrossJoin.1.Hash.plan
                • testCrossJoin.3.result
                • testCrossJoinWithAsterisk1.Sort.plan
                • testCrossJoin.5.Hash.plan
                • testCrossJoin.1.Sort.plan
                • testCrossJoinWithAsterisk1.Hash_NoBroadcast.plan
                • testCrossJoinOftwoSmallTables.1.Sort.plan
                • testCrossJoinWithAsterisk4.Sort_NoBroadcast.plan
                • testCrossJoinWithAsterisk1.result
                • testCrossJoinOfOneSmallTableAndJoin.1.Sort.plan
                • testCrossJoinWithAsterisk4.result
                • testCrossJoinOfOneSmallTableAndJoin.1.Hash_NoBroadcast.plan
                • testCrossJoinWithAsterisk3.result
                • testCrossJoin.4.Sort_NoBroadcast.plan
                • testCrossJoinOftwoSmallTables.1.result
                • testCrossJoinWithEmptyTable1.result
                • testCrossJoin.2.Hash.plan
                • testCrossJoinWithAsterisk4.Sort.plan
                • testCrossJoinWithAsterisk4.Hash_NoBroadcast.plan
                • testCrossJoin.2.Hash_NoBroadcast.plan
                • testCrossJoinWithAsterisk2.Hash.plan
                • testCrossJoinWithEmptyTable1.Sort.plan
                • testCrossJoinWithEmptyTable1.Hash_NoBroadcast.plan
                • testCrossJoinWithAsterisk1.Sort_NoBroadcast.plan
                • testCrossJoinOfOneSmallTableAndJoin.1.result
              • TestJsonWithTimezone
                • testTimezonedTable3.result
                • testTimezonedTable1.result
                • testTimezonedTable2.result
              • TestSQLAnalyzer
                • alter_table_add_partition_3.result
                • alter_table_add_partition_2.result
                • window1.result
                • create_table_maptype_1.result
                • window7.result
                • window5.result
                • alter_table_repair_partition_1.result
                • alter_table_add_partition_1.result
                • create_table_partition_by_list.result
                • window3.result
                • alter_table_set_property_1.result
                • create_table_partition_by_column.result
                • window6.result
                • create_table_like_1.result
                • settimezone1.result
                • create_table_partition_by_hash_2.result
                • alter_table_set_property_2.result
                • setsession7.result
                • create_table_partition_by_hash_1.result
                • setcatalog2.result
                • create_table_nested_2.result
                • setsession4.result
                • settimezone3.result
                • setsession1.result
                • setsession5.result
                • window2.result
                • alter_table_drop_partition_4.result
                • alter_table_add_partition_5.result
                • create_table_nested_1.result
                • case_sensitivity1.result
                • create_table_maptype_2.result
                • setcatalog1.result
                • window4.result
                • insert_values_1.result
                • create_table_partition_by_range.result
                • settimezone2.result
                • alter_table_set_property_3.result
                • setsession3.result
                • alter_table_drop_partition_2.result
                • window8.result
                • alter_table_drop_partition_1.result
                • alter_table_drop_partition_3.result
                • errors
                  • join_1.result
                  • identifier1.result
                  • in_subquery_1.result
                • alter_table_add_partition_4.result
                • setsession6.result
                • setsession2.result
                • window9.result
                • create_table_maptype_3.result
              • TestJoinOnPartitionedTables
                • testBroadcastPartitionTable.result
                • testPartitionMultiplePartitionFilter.1.result
                • testFilterPushDownPartitionColumnCaseWhen.result
                • testPartialFilterPushDownOuterJoin.result
                • testPartialFilterPushDown.result
                • selfJoinOfPartitionedTable.result
                • testMultiplePartitionedBroadcastDataFileWithZeroLength.result
                • testMultiplePartitionedBroadcastDataFileWithZeroLength2.result
                • testPartialFilterPushDownOuterJoin2.result
                • testPartitionTableJoinSmallTable.result
                • testNoProjectionJoinQual.result
              • TestSelectNestedRecord
                • testInsertType1.result
                • testSelect3.result
                • testSelect0.result
                • testSelect1.result
                • testInsertType2.result
                • testTAJO_1610.result
                • testSelect2.result
                • testNestedFieldAsGroupbyKey1.result
                • testNestedFieldAsJoinKey1.result
              • TestTajoCli
                • testSelectResultWithNullTrueDeprecated.result
                • testResultRowNumWhenSelectingOnPartitionedTable.result
                • testDescTable2.result
                • testStopWhenErrorDeprecated.result
                • testSelectResultWithNullTrue.result
                • testAddPartitionNotimplementedException.result
                • testSetTimezone1.result
                • testHelpSessionVars.result
                • testDescTable1.result
                • testAddPartitionNotimplementedException.err
                • testLocalQueryWithoutFrom.result
                • testAlterTableAddDropPartition.result
                • testStopWhenError.result
                • testDescTableForNestedSchema.result
                • testSelectResultWithNullFalse.result
                • testNonForwardQueryPause.result
                • testStopWhenErrorDeprecated.err
                • testStopWhenError.err
                • testSelectResultWithNullTrueDeprecated.err
              • TestAlterTable
                • before_set_property_delimiter.result
                • after_set_property_delimiter.result
              • TestNetTypes
                • testJoin.result
                • testSort2.result
                • testSelect.result
                • testGroupby2.result
                • testGroupby.result
                • testSort.result
              • TestWindowQuery
                • testWindowWithSubQuery5.result
                • testWindowBeforeLimit.result
                • testLagWithDefault.result
                • testWindowWithOrderBy1.result
                • testWindowWithAggregation2.result
                • testWindow7.result
                • testStdDevPop1.result
                • testComplexOrderBy1.result
                • testWindowWithSubQuery3.result
                • testWindowWithAggregation5.result
                • testWindowWithOrderBy4.result
                • testWindowWithSubQuery.result
                • testWindow6.result
                • testStdDevSamp1.result
                • testWindowWithSubQuery6.result
                • testLagWithNoArgs.result
                • testWindowWithAggregation4.result
                • testLag1.result
                • testLead1.result
                • testLeadWithDefault.result
                • testLeadWithNoArgs.result
                • testWindow1.result
                • testWindow4.result
                • testWindowWithOrderBy5.result
                • testWindowWithSubQuery2.result
                • testLastValue1.result
                • testRowNumber2.result
                • testWindowWithOrderBy3.result
                • testWindow3.result
                • testFirstValue1.result
                • testWindowWithAggregation3.result
                • testWindowWithAggregation1.result
                • testWindow5.result
                • testWindowWithOrderBy2.result
                • testWindowWithAggregation6.result
                • testWindow2.result
                • testWindow8.result
                • testWindowWithSubQuery4.result
                • testRowNumber1.result
                • testRowNumber3.result
              • TestCTASQuery
                • testCtasWithTextFile.result
                • testCtasWithStoreType.result
                • testCtasWithOptions.result
                • testCtasWithUnion.result
                • testCtasWithOrderby.result
                • testCtasWithGroupby.result
                • testCtasWithLimit.result
              • TestCommonConditionReduce
                • test81.plan
                • test51.result
                • test41.result
                • test31.result
                • test21.plan
                • test11.plan
                • test11.result
                • test41.plan
                • test61.plan
                • test71.plan
                • test51.plan
                • test21.result
                • test31.plan
                • test71.result
                • test81.result
                • test61.result
              • TestGroupByQuery
                • testGroupbyWithLimit1.result
                • testDistinctAggregationCaseByCase3.result
                • testDistinctAggregationCaseByCase4.result
                • testGroupByWithConstantKeys3.result
                • testHavingWithAggFunction.result
                • testGroupByWithSameConstantKeys1.result
                • testGroupBy.result
                • testGroupByWithNullData11.result
                • testPythonUdaf2.result
                • testGroupByWithSameExprs1.result
                • testPythonUdaf.result
                • testPythonUdaf3.result
                • testGroupBy2.result
                • testDistinctAggregationWithUnion1.result
                • testGroupByWithConstantKeys1.result
                • testGroupBy3.result
                • testGroupByWithNullData5.result
                • testDistinctAggregation3.result
                • testComplexTargetWithPythonUdaf.result
                • testGroupByWithExpressionKeys1.result
                • testGroupByWithNullData8.result
                • testDistinctAggregation_case5.result
                • testGroupByWithNullData12.result
                • testGroupbyWithLimit3.result
                • testDistinctAggregation_case7.result
                • testGroupByWithSameExprs2.result
                • testGroupByNested2.result
                • testGroupByNested1.result
                • testDistinctAggregation_case3.result
                • testDistinctAggregation2.result
                • testDistinctAggregation6.result
                • testDistinctAggregation_case4.result
                • testPythonUdafWithHaving.result
                • testDistinctAggregation_case1.result
                • testDistinctAggregation7.result
                • testGroupBy4.result
                • testDistinctAggregationWithHaving1.result
                • testGroupByWithConstantKeys4.result
                • testGroupBy5.result
                • testGroupByWithNullData6.result
                • testComplexParameter.result
                • testDistinctAggregation_case2.result
                • testDistinctAggregation_case10.result
                • testGroupByWithNullData3.result
                • testComplexParameter2.result
                • testGroupbyWithPythonFunc.result
                • testDistinctAggregation_case8.result
                • testPythonUdafWithNullData.result
                • testGroupByWithNullData7.result
                • testDistinctAggregation4.result
                • testDistinctAggregation1.result
                • testDistinctAggregation_case6.result
                • testComplexParameterWithSubQuery.result
                • testDistinctAggregation5.result
                • testGroupByWithConstantKeys5.result
                • testDistinctPythonUdafWithUnion1.result
                • testHavingWithNamedTarget.result
                • testGroupByWithNullData10.result
                • testDistinctAggregation_case9.result
                • testGroupbyWithLimit2.result
                • testGroupByWithNullData1.result
                • testGroupByWithNullData2.result
                • testGroupByWithNullData4.result
                • testGroupbyWithJson.result
                • testGroupbyWithPythonFunc2.result
                • testGroupByWithNullData9.result
                • testGroupByWithConstantKeys2.result
                • testGroupByWithExpressionKeys2.result
                • testDistinctAggregation8.result
              • TestCaseByCases
                • testTAJO_1600.plan
                • testTAJO739Case.result
                • testTAJO_1600.result
                • testTAJO418Case.result
                • testTAJO914Case3.result
                • testTAJO914Case2.result
                • testTAJO1224Case1.result
                • testTAJO917Case1.result
                • testTAJO619Case.result
                • testTAJO914Case1.result
                • testTAJO718Case.result
                • testTAJO415Case.result
                • testTAJO914Case4.result
              • TestTajoClientV2
                • testExecuteQueryAsync.result
                • testExecuteQueryType1.result
                • testExecuteQueryAsyncWithListener.result
                • testExecuteQueryType2.result
                • testExecuteQueryType3.result
              • TestQueryOnOrcFile
                • testTimezone3.result
                • testTimezone2.result
                • testTimezone4.result
                • testTimezone1.result
              • TestMultipleJoinTypes
                • testExceedBroadcastThreshold.Hash.Plan
                • testInnerAndOuterWithEmpty.1.Hash_NoBroadcast.plan
                • testComplexJoinsWithCaseWhen.Sort.plan
                • testExceedBroadcastThreshold.1.result
                • testExceedBroadcastThreshold.1.Sort.plan
                • testInnerAndOuterWithEmpty.1.Hash.plan
                • testComplexJoinsWithCaseWhen2.Hash_NoBroadcast.plan
                • testJoinWithMultipleJoinTypes.Hash.plan
                • testComplexJoinsWithCaseWhen.Hash.plan
                • testComplexJoinsWithCaseWhen2.Hash.plan
                • testExceedBroadcastThreshold.1.Hash_NoBroadcast.plan
                • testInnerAndOuterWithEmpty.1.result
                • testComplexJoinsWithCaseWhen2.result
                • testExceedBroadcastThreshold.1.Sort_NoBroadcast.plan
                • testInnerAndOuterWithEmpty.1.Sort.plan
                • testJoinWithMultipleJoinTypes.Sort.plan
                • testComplexJoinsWithCaseWhen2.Sort_NoBroadcast.plan
                • testInnerAndOuterWithEmpty.1.Sort_NoBroadcast.plan
                • testComplexJoinsWithCaseWhen.Sort_NoBroadcast.plan
                • testJoinWithMultipleJoinTypes.result
                • testComplexJoinsWithCaseWhen2.Sort.plan
                • testJoinWithMultipleJoinTypes.Sort_NoBroadcast.plan
                • testComplexJoinsWithCaseWhen.result
                • testComplexJoinsWithCaseWhen.Hash_NoBroadcast.plan
                • testExceedBroadcastThreshold.1.Hash.plan
                • testJoinWithMultipleJoinTypes.Hash_NoBroadcast.plan
              • TestTableSubQuery
                • testGroupBySubQuery.result
                • testJoinSubQuery2.result
                • testTableSubquery1.result
                • testGroupbyOnUnion.result
                • testJoinSubqueryWithJson.result
                • testMultipleSubqueriesWithAggregation.1.result
                • testGroupbySubqueryWithJson.result
                • testJoinSubQuery.result
            • log4j.properties
            • dataset
              • TestDropTable
                • table1.tbl
              • TestCreateTable
                • table2
                  • table2.tbl
                • table1
                  • table1.tbl
                • json_table
                  • table1.json
              • TestSelectQuery
                • timezoned
                  • timezoned1.tbl
                • multibytes_delimiter2
                  • table2.tbl
                • multibytes_delimiter1
                  • table1.tbl
              • TestHBaseTable
                • splits.data
              • TestTruncateTable
                • truncate_table2
                  • table2.tbl
              • TestTablePartitions
                • lineitemspecial.tbl
              • TestQueryOnSelfDescTable
                • sample2
                  • sample2.json
                • sample1
                  • table.json
                • github
                  • github.json
                • tweets
                  • sample1.json
              • TestJoinQuery
                • table2
                  • table2.tbl
                • customer_parquet
                  • customer3
                  • customer1
                  • customer2
                  • customer
                  • customer_5rows
                • table1
                  • table1.tbl
                • nation_parquet
                  • nation1
                  • nation
                  • nation_24rows
                  • nation2
                  • nation3
              • TestSortQuery
                • table2
                  • table2.tbl
                • table1
                  • table1.tbl
                • table3
                  • table1.tbl
                  • table3.tbl
                  • table4.tbl
                  • table2.tbl
                  • table5.tbl
              • TestJsonWithTimezone
                • timezoned
                  • TestJsonWithTimezone.json
              • TestSelectNestedRecord
                • sample2
                  • sample2.json
                • sample1
                  • table.json
                • tweets
                  • sample1.json
              • TestAlterTable
                • table1.tbl
                • table2.tbl
              • TestNetTypes
                • table2
                  • table2.tbl
                • table1
                  • table1.tbl
              • TestQueryOnOrcFile
                • timezoned
                  • timezoned1.tbl
            • pyudf
              • test_funcs2.py
              • test_udaf.py
              • test_funcs.py
              • __init__.py
            • hiveudf
            • queries
              • TestDropTable
                • drop_table_ddl.sql
                • table1_ddl.sql
              • TestLogicalPlanner
                • window1.sql
              • TestCreateTable
                • quoted_identifier_non_ascii_ddl.sql
                • quoted_identifier_mixed_chars_1.sql
                • create_table_various_types.sql
                • table1_ddl.sql
                • testNestedRecord1.sql
                • quoted_identifier_non_ascii_2.sql
                • quoted_identifier_mixed_chars_ddl_1.sql
                • negative
                  • type_mismatch.sql
                  • create_table_on_absent_tablespace.sql
                  • map_type.sql
                  • create_table_on_already_exist_tables.sql
                • positive
                  • create_table_if_not_exists.sql
                • quoted_identifier_mixed_chars_ddl_2.sql
                • create_table_various_types_for_hive_catalog.sql
                • testNestedRecord2.sql
                • quoted_identifier_non_ascii_3.sql
                • quoted_identifier_non_ascii_1.sql
                • testSelfDescTable1.sql
                • quoted_identifier_mixed_chars_2.sql
                • testComplexType1.sql
                • quoted_identifier_mixed_chars_3.sql
              • TestUnionQuery
                • testUnion16.sql
                • testUnionWithDifferentAliasAndFunction.sql
                • testLeftUnionWithJoin.sql
                • testUnion10.sql
                • testUnionAllWithSameAliasNames.sql
                • testUnionAll5.sql
                • testUnion7.sql
                • testUnion13.sql
                • testUnion8.sql
                • testUnionAll13.sql
                • testUnionAll2.sql
                • testUnionAll16.sql
                • testComplexUnion1.sql
                • testUnion5.sql
                • testComplexUnion2.sql
                • testUnionWithDifferentAlias.sql
                • testUnion15.sql
                • testUnionAll14.sql
                • testUnionAndFilter.sql
                • testRightUnionWithJoin.sql
                • testUnionAll12.sql
                • testUnionAll7.sql
                • testUnion2.sql
                • testUnion3.sql
                • testUnionWithSameAliasNames.sql
                • testUnionAll9.sql
                • testUnion6.sql
                • testUnionAll4.sql
                • testUnion12.sql
                • testUnion11.sql
                • testAllUnionWithJoin.sql
                • testTajo1368Case2.sql
                • testUnion4.sql
                • testUnionAll3.sql
                • testUnionAll11.sql